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 X Y Z _ 

A

AbstractChannelizer() - Constructor for class org.apache.tinkerpop.gremlin.driver.Channelizer.AbstractChannelizer
 
AbstractChannelizer - Class in org.apache.tinkerpop.gremlin.server
A base implementation for the Channelizer which does a basic configuration of the pipeline, one that is generally common to virtually any Gremlin Server operation (i.e.
AbstractChannelizer() - Constructor for class org.apache.tinkerpop.gremlin.server.AbstractChannelizer
 
AbstractClient - Class in org.apache.tinkerpop.gremlin.driver.simple
 
AbstractClient(String) - Constructor for class org.apache.tinkerpop.gremlin.driver.simple.AbstractClient
 
AbstractEvalOpProcessor - Class in org.apache.tinkerpop.gremlin.server.op
A base OpProcessor implementation that helps with operations that deal with script evaluation functions.
AbstractEvalOpProcessor(boolean) - Constructor for class org.apache.tinkerpop.gremlin.server.op.AbstractEvalOpProcessor
 
AbstractEvalOpProcessor.BindingSupplier - Interface in org.apache.tinkerpop.gremlin.server.op
 
AbstractGenerator - Class in org.apache.tinkerpop.gremlin.algorithm.generator
Base class for all synthetic network generators.
AbstractGenerator.AbstractGeneratorBuilder<T extends AbstractGenerator.AbstractGeneratorBuilder> - Class in org.apache.tinkerpop.gremlin.algorithm.generator
 
AbstractGeneratorTest - Class in org.apache.tinkerpop.gremlin.algorithm.generator
 
AbstractGeneratorTest() - Constructor for class org.apache.tinkerpop.gremlin.algorithm.generator.AbstractGeneratorTest
 
AbstractGraphProvider - Class in org.apache.tinkerpop.gremlin
A basic GraphProvider which simply requires the implementer to supply their base configuration for their Graph instance.
AbstractGraphProvider() - Constructor for class org.apache.tinkerpop.gremlin.AbstractGraphProvider
 
AbstractGraphSONMessageSerializerV1d0 - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGraphSONMessageSerializerV1d0() - Constructor for class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV1d0
 
AbstractGraphSONMessageSerializerV1d0(GraphSONMapper) - Constructor for class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV1d0
 
AbstractGraphSONMessageSerializerV1d0.GremlinServerModule - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGraphSONMessageSerializerV1d0.JsonBuilderJacksonSerializer - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGraphSONMessageSerializerV1d0.ResponseMessageSerializer - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGraphSONMessageSerializerV2d0 - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGraphSONMessageSerializerV2d0() - Constructor for class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV2d0
 
AbstractGraphSONMessageSerializerV2d0(GraphSONMapper) - Constructor for class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV2d0
 
AbstractGraphSONMessageSerializerV2d0.GremlinServerModule - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGraphSONMessageSerializerV2d0.JsonBuilderJacksonSerializer - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGraphSONMessageSerializerV2d0.RequestMessageDeserializer - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGraphSONMessageSerializerV2d0.RequestMessageSerializer - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGraphSONMessageSerializerV2d0.ResponseMessageDeserializer - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGraphSONMessageSerializerV2d0.ResponseMessageSerializer - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGremlinPlugin - Class in org.apache.tinkerpop.gremlin.groovy.plugin
Deprecated.
As of release 3.2.4, replaced by AbstractGremlinPlugin.
AbstractGremlinPlugin() - Constructor for class org.apache.tinkerpop.gremlin.groovy.plugin.AbstractGremlinPlugin
Deprecated.
Creates a new instance that does not force the plugin to require the console.
AbstractGremlinPlugin(boolean) - Constructor for class org.apache.tinkerpop.gremlin.groovy.plugin.AbstractGremlinPlugin
Deprecated.
Creates a new instance that allows the plugin to specify whether the console is required or not.
AbstractGremlinPlugin - Class in org.apache.tinkerpop.gremlin.jsr223
 
AbstractGremlinPlugin(String, Customizer...) - Constructor for class org.apache.tinkerpop.gremlin.jsr223.AbstractGremlinPlugin
Creates a base GremlinPlugin that will apply to all GremlinScriptEngine instances.
AbstractGremlinPlugin(String, Set<String>, Customizer...) - Constructor for class org.apache.tinkerpop.gremlin.jsr223.AbstractGremlinPlugin
Creates a base GremlinPlugin that will apply to specific GremlinScriptEngine instances.
AbstractGremlinProcessTest - Class in org.apache.tinkerpop.gremlin.process
Base test class for Gremlin Process tests.
AbstractGremlinProcessTest() - Constructor for class org.apache.tinkerpop.gremlin.process.AbstractGremlinProcessTest
 
AbstractGremlinSuite - Class in org.apache.tinkerpop.gremlin
Base Gremlin test suite from which different classes of tests can be exposed to implementers.
AbstractGremlinSuite(Class<?>, RunnerBuilder, Class<?>[], Class<?>[], boolean, TraversalEngine.Type) - Constructor for class org.apache.tinkerpop.gremlin.AbstractGremlinSuite
Constructs a Gremlin Test Suite implementation.
AbstractGremlinSuite.OptOutTestFilter - Class in org.apache.tinkerpop.gremlin
Filter for tests in the suite which is controlled by the Graph.OptOut annotation.
AbstractGremlinTest - Class in org.apache.tinkerpop.gremlin
Sets up g based on the current graph configuration and checks required features for the test.
AbstractGremlinTest() - Constructor for class org.apache.tinkerpop.gremlin.AbstractGremlinTest
 
AbstractGryoMessageSerializerV1d0 - Class in org.apache.tinkerpop.gremlin.driver.ser
 
AbstractGryoMessageSerializerV1d0(GryoMapper) - Constructor for class org.apache.tinkerpop.gremlin.driver.ser.AbstractGryoMessageSerializerV1d0
Creates an instance with a provided mapper configured GryoMapper instance.
AbstractHadoopGraphComputer - Class in org.apache.tinkerpop.gremlin.hadoop.process.computer
 
AbstractHadoopGraphComputer(HadoopGraph) - Constructor for class org.apache.tinkerpop.gremlin.hadoop.process.computer.AbstractHadoopGraphComputer
 
AbstractHadoopGraphComputer.Features - Class in org.apache.tinkerpop.gremlin.hadoop.process.computer
 
AbstractImportCustomizerProvider - Class in org.apache.tinkerpop.gremlin.groovy
 
AbstractImportCustomizerProvider() - Constructor for class org.apache.tinkerpop.gremlin.groovy.AbstractImportCustomizerProvider
 
AbstractIoRegistry - Class in org.apache.tinkerpop.gremlin.structure.io
Base implementation of the IoRegistry interface that provides implementation of the methods using a a HashMap.
AbstractIoRegistry() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.AbstractIoRegistry
 
AbstractLambdaTraversal<S,E> - Class in org.apache.tinkerpop.gremlin.process.traversal.lambda
 
AbstractLambdaTraversal() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.lambda.AbstractLambdaTraversal
 
AbstractMessageSerializer - Class in org.apache.tinkerpop.gremlin.driver.ser
Base MessageSerializer that serializers can implement to get some helper methods around configuring a Mapper.Builder.
AbstractMessageSerializer() - Constructor for class org.apache.tinkerpop.gremlin.driver.ser.AbstractMessageSerializer
 
AbstractObjectDeserializer<T> - Class in org.apache.tinkerpop.gremlin.structure.io.graphson
Base class for creating deserializers which parses JSON to a Map to more easily reconstruct an object.
AbstractObjectDeserializer(Class<T>) - Constructor for class org.apache.tinkerpop.gremlin.structure.io.graphson.AbstractObjectDeserializer
 
AbstractOpProcessor - Class in org.apache.tinkerpop.gremlin.server.op
A base OpProcessor implementation that processes an Iterator of results in a generalized way while ensuring that graph transactions are properly managed.
AbstractOpProcessor(boolean) - Constructor for class org.apache.tinkerpop.gremlin.server.op.AbstractOpProcessor
 
AbstractRemoteTraversal<S,E> - Class in org.apache.tinkerpop.gremlin.process.remote.traversal
This is a stub implementation for RemoteTraversal and requires that the AbstractRemoteTraversal.nextTraverser() method is implemented from Traversal.Admin.
AbstractRemoteTraversal() - Constructor for class org.apache.tinkerpop.gremlin.process.remote.traversal.AbstractRemoteTraversal
 
AbstractRemoteTraversalSideEffects - Class in org.apache.tinkerpop.gremlin.process.remote.traversal
 
AbstractRemoteTraversalSideEffects() - Constructor for class org.apache.tinkerpop.gremlin.process.remote.traversal.AbstractRemoteTraversalSideEffects
 
AbstractRemoteTraverser<T> - Class in org.apache.tinkerpop.gremlin.process.remote.traversal
 
AbstractRemoteTraverser(T, long) - Constructor for class org.apache.tinkerpop.gremlin.process.remote.traversal.AbstractRemoteTraverser
 
AbstractStep<S,E> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.util
 
AbstractStep(Traversal.Admin) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.util.AbstractStep
 
AbstractThreadedTransaction - Class in org.apache.tinkerpop.gremlin.structure.util
A base implementation of Transaction that provides core functionality for transaction listeners using a shared set of transaction listeners.
AbstractThreadedTransaction(Graph) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.AbstractThreadedTransaction
 
AbstractThreadLocalTransaction - Class in org.apache.tinkerpop.gremlin.structure.util
A base implementation of Transaction that provides core functionality for transaction listeners using ThreadLocal.
AbstractThreadLocalTransaction(Graph) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.AbstractThreadLocalTransaction
 
AbstractTransaction - Class in org.apache.tinkerpop.gremlin.structure.util
A simple base class for Transaction that provides some common functionality and default behavior.
AbstractTransaction(Graph) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.AbstractTransaction
 
AbstractTransaction.TransactionException - Exception in org.apache.tinkerpop.gremlin.structure.util
An "internal" exception thrown by providers when calls to AbstractTransaction.doCommit() or AbstractTransaction.doRollback() fail.
AbstractTraversalStrategy<S extends TraversalStrategy> - Class in org.apache.tinkerpop.gremlin.process.traversal.strategy
 
AbstractTraversalStrategy() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.strategy.AbstractTraversalStrategy
 
AbstractTraverser<T> - Class in org.apache.tinkerpop.gremlin.process.traversal.traverser.util
 
AbstractTraverser() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.AbstractTraverser
 
AbstractTraverser(T) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.AbstractTraverser
 
AbstractVertexProgramBuilder<B extends VertexProgram.Builder> - Class in org.apache.tinkerpop.gremlin.process.computer.util
 
AbstractVertexProgramBuilder() - Constructor for class org.apache.tinkerpop.gremlin.process.computer.util.AbstractVertexProgramBuilder
 
AbstractVertexProgramBuilder(Class<? extends VertexProgram>) - Constructor for class org.apache.tinkerpop.gremlin.process.computer.util.AbstractVertexProgramBuilder
 
accept(Path) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.HiddenFileFilter
 
accept(Event) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategy.EventStrategyCallback
 
accept(A) - Method in class org.apache.tinkerpop.gremlin.util.function.Lambda.OneArgLambda
 
accept(Object) - Method in class org.apache.tinkerpop.gremlin.util.function.ScriptEngineLambda
 
accept(Object, Object) - Method in class org.apache.tinkerpop.gremlin.util.function.ScriptEngineLambda
 
accept(Object, Object, Object) - Method in class org.apache.tinkerpop.gremlin.util.function.ScriptEngineLambda
 
accept(A, B) - Method in interface org.apache.tinkerpop.gremlin.util.function.ThrowingBiConsumer
 
accept(A) - Method in interface org.apache.tinkerpop.gremlin.util.function.ThrowingConsumer
 
accept(A, B, C) - Method in interface org.apache.tinkerpop.gremlin.util.function.TriConsumer
Performs this operation on the given arguments.
acceptingRequests() - Method in class org.apache.tinkerpop.gremlin.server.op.session.Session
 
ACTIVE_TRAVERSERS - Static variable in class org.apache.tinkerpop.gremlin.process.computer.traversal.TraversalVertexProgram
 
add(Object...) - Method in class org.apache.tinkerpop.gremlin.driver.message.RequestMessage.Builder
 
add(<any>) - Method in class org.apache.tinkerpop.gremlin.giraph.process.computer.EmptyOutEdges
 
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphMemory
 
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.giraph.process.computer.PassThroughMemory
 
add(String, Object) - Method in interface org.apache.tinkerpop.gremlin.process.computer.Memory
Set the value of the provided key.
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.MemoryTraversalSideEffects
 
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.EmptyMemory
 
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.ImmutableMemory
 
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.MapMemory
 
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.process.remote.traversal.AbstractRemoteTraversalSideEffects
 
add - Variable in class org.apache.tinkerpop.gremlin.process.traversal.NumberHelper
 
add(Number, Number) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.NumberHelper
 
add(Number, long) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MeanGlobalStep.MeanNumber
 
add(MeanGlobalStep.MeanNumber) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MeanGlobalStep.MeanNumber
 
add(S) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.BulkSet
 
add(S, long) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.BulkSet
 
add(Iterator<Traverser.Admin<S>>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ExpandableStepIterator
 
add(Traverser.Admin<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ExpandableStepIterator
 
add(String, Object) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalSideEffects
Add a value to the global side-effect value.
add(Traverser.Admin<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.TraverserSet
 
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversalSideEffects
Add a value to the global side-effect value.
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversalSideEffects
 
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.spark.process.computer.SparkMemory
 
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerMemory
 
add(String, Object) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerWorkerMemory
 
addAccumulator(ObjectWritable<A>, ObjectWritable<A>) - Method in class org.apache.tinkerpop.gremlin.spark.process.computer.MemoryAccumulator
 
addAll(Collection<? extends S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.BulkSet
 
addArg(String, Object) - Method in class org.apache.tinkerpop.gremlin.driver.message.RequestMessage.Builder
 
addBarrier(B) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.Barrier
Add a barrier to the step.
addBarrier(Map<Object, Traverser.Admin<S>>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.DedupGlobalStep
 
addBarrier(TraverserSet<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.RangeGlobalStep
 
addBarrier(TraverserSet<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.TailGlobalStep
 
addBarrier(TraverserSet<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.NoOpBarrierStep
 
addBarrier(TraverserSet<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.AggregateStep
 
addBarrier(TraverserSet<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.CollectingBarrierStep
 
addBarrier(E) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ReducingBarrierStep
 
addBarrier(Boolean) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.SupplyingBarrierStep
 
addBinding(String, Object) - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.ScriptEnginePluginAcceptor
Deprecated.
Adds global bindings to the ScriptEngine that will be applied to every evaluated script.
addBinding(String, Object) - Method in interface org.apache.tinkerpop.gremlin.groovy.plugin.PluginAcceptor
Deprecated.
Add a variable binding for the plugin host.
addBinding(String, Object) - Method in class org.apache.tinkerpop.gremlin.groovy.util.TestableConsolePluginAcceptor
 
addBinding(String, Object) - Method in interface org.apache.tinkerpop.gremlin.jsr223.console.PluginAcceptor
Add a variable binding for the plugin host.
addCallback(EventCallback<E>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.util.event.CallbackRegistry
 
addCallback(EventCallback<E>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.event.ListCallbackRegistry
 
addClassImports(Class...) - Method in class org.apache.tinkerpop.gremlin.jsr223.DefaultImportCustomizer.Builder
 
addClassImports(Collection<Class>) - Method in class org.apache.tinkerpop.gremlin.jsr223.DefaultImportCustomizer.Builder
 
addComparator(Traversal.Admin<S, C>, Comparator<C>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.ComparatorHolder
Add a Traversal-based Comparator to the holder.
addComparator(Traversal.Admin<S, C>, Comparator<C>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.OrderGlobalStep
 
addComparator(Traversal.Admin<S, C>, Comparator<C>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.OrderLocalStep
 
addConsoleReporter(long) - Method in enum org.apache.tinkerpop.gremlin.server.util.MetricManager
Create a ConsoleReporter attached to the Titan Metrics registry.
addContactPoint(String) - Method in class org.apache.tinkerpop.gremlin.driver.Cluster.Builder
Adds the address of a Gremlin Server to the list of servers a Client will try to contact to send requests to.
addContactPoints(String...) - Method in class org.apache.tinkerpop.gremlin.driver.Cluster.Builder
Add one or more the addresses of a Gremlin Servers to the list of servers a Client will try to contact to send requests to.
addCsvReporter(long, String) - Method in enum org.apache.tinkerpop.gremlin.server.util.MetricManager
Create a CsvReporter attached to the Titan Metrics registry.
addCustom(Class...) - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoMapper.Builder
Register custom classes to serializes with gryo using default serialization.
addCustom(Class, Serializer) - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoMapper.Builder
Register custom class to serialize with a custom serialization class.
addCustom(Class, Function<Kryo, Serializer>) - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoMapper.Builder
Register a custom class to serialize with a custom serializer as returned from a Function.
addCustomModule(SimpleModule) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONMapper.Builder
Supply a mapper module for serialization/deserialization.
addCustomModule(SimpleModule) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.LegacyGraphSONReader.Builder
Supply a mapper module for serialization/deserialization.
addCustomType(String, Class) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTypeIdResolver
 
addE(Direction, String, String, Object...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
Deprecated.
addE(String) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
addE(String) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
addE(Direction, String, String, Object...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Deprecated.
As of release 3.1.0, replaced by GraphTraversal.addE(String)
addE - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
addEdge(Vertex, Vertex) - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.AbstractGenerator
 
addEdge(String, Vertex, Object...) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopVertex
 
addEdge(String, Vertex, Object...) - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jVertex
 
addEdge(String, Vertex, Object...) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph.ComputerAdjacentVertex
 
addEdge(String, Vertex, Object...) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph.ComputerVertex
 
addEdge(String, Vertex, Object...) - Method in class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedVertex
 
addEdge(String, Vertex, Object...) - Method in class org.apache.tinkerpop.gremlin.structure.util.reference.ReferenceVertex
 
addEdge(String, Vertex, Object...) - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph.StarAdjacentVertex
 
addEdge(String, Vertex, Object...) - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph.StarVertex
 
addEdge(String, Vertex, Object...) - Method in interface org.apache.tinkerpop.gremlin.structure.Vertex
Add an outgoing edge to the vertex with provided label and edge properties as key/value pairs.
addEdge(TinkerGraph, TinkerVertex, TinkerVertex, String, Object...) - Static method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerHelper
 
addEdge(String, Vertex, Object...) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerVertex
 
addEdgeEventRecorded() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategyProcessTest.StubMutationListener
 
AddEdgeStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
AddEdgeStep(Traversal.Admin, String) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddEdgeStep
 
AddEdgeTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
AddEdgeTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddEdgeTest
 
AddEdgeTest() - Constructor for class org.apache.tinkerpop.gremlin.structure.VertexTest.AddEdgeTest
 
AddEdgeTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
addEmitToTraversal(C, Traversal.Admin<B, ?>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.RepeatStep
 
addEngineSettings(String, List<String>, List<String>, List<String>, Map<String, Object>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.Builder
Deprecated.
As of release 3.2.4, replaced by GremlinExecutor.Builder.addPlugins(String, Map).
addEnumImports(Enum...) - Method in class org.apache.tinkerpop.gremlin.jsr223.DefaultImportCustomizer.Builder
 
addEnumImports(Collection<Enum>) - Method in class org.apache.tinkerpop.gremlin.jsr223.DefaultImportCustomizer.Builder
 
addEvent(Event) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategy.DefaultEventQueue
 
addEvent(Event) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategy.EventQueue
Add an event to the event queue.
addEvent(Event) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategy.TransactionalEventQueue
 
addFrom(Object) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddEdgeStep
 
addGangliaReporter(String, int, GMetric.UDPAddressingMode, int, Boolean, UUID, String, long) - Method in enum org.apache.tinkerpop.gremlin.server.util.MetricManager
Create a GangliaReporter attached to the Titan Metrics registry.
addGlobalChild(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchStep
 
addGlobalChild(Traversal.Admin<?, ?>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.TraversalParent
 
addGlobalChildOption(M, Traversal.Admin<S, E>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.BranchStep
 
addGlobalChildOption(M, Traversal.Admin<S, E>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.ChooseStep
 
addGlobalChildOption(TraversalOptionParent.Pick, Traversal.Admin<S, E>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.UnionStep
 
addGlobalChildOption(M, Traversal.Admin<S, E>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.TraversalOptionParent
 
addGraphComputerStrategies(TraversalSource) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.decoration.VertexProgramStrategy
 
addGraphiteReporter(String, int, String, long) - Method in enum org.apache.tinkerpop.gremlin.server.util.MetricManager
Create a GraphiteReporter attached to the Titan Metrics registry.
addHasContainer(HasContainer) - Method in class org.apache.tinkerpop.gremlin.neo4j.process.traversal.step.sideEffect.Neo4jGraphStep
 
addHasContainer(HasContainer) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.HasStep
 
addHasContainer(HasContainer) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.HasContainerHolder
 
addHasContainer(T, HasContainer) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalHelper
Used to left-fold a HasContainer to a HasContainerHolder if it exists.
addHasContainer(HasContainer) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.traversal.step.sideEffect.TinkerGraphStep
 
addHostOption(String, Object) - Method in class org.apache.tinkerpop.gremlin.server.util.ServerGremlinExecutor
 
addIds(Object...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GraphStep
 
addImports(Set<String>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.ScriptEngines
Deprecated.
Perform append to the existing import list for all ScriptEngine instances that implement the DependencyManager interface.
addImports(Set<String>) - Method in interface org.apache.tinkerpop.gremlin.groovy.jsr223.DependencyManager
Deprecated.
Perform class imports for the ScriptEngine.
addImports(Set<String>) - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GremlinGroovyScriptEngine
Perform class imports for the ScriptEngine.
addImports(Set<String>) - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.ScriptEnginePluginAcceptor
Deprecated.
If the ScriptEngine implements the DependencyManager interface it will try to import the specified import statements.
addImports(Set<String>) - Method in interface org.apache.tinkerpop.gremlin.groovy.plugin.PluginAcceptor
Deprecated.
If the PluginAcceptor implements the DependencyManager interface it will try to import the specified import statements.
addImports(Set<String>) - Method in class org.apache.tinkerpop.gremlin.groovy.util.TestableConsolePluginAcceptor
 
addImports(Set<String>) - Method in interface org.apache.tinkerpop.gremlin.jsr223.console.PluginAcceptor
 
addInE(String, String, Object...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
Deprecated.
addInE(String, String, Object...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Deprecated.
As of release 3.1.0, replaced by GraphTraversal.addE(String)
addInEdge(TinkerVertex, String, Edge) - Static method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerHelper
 
addInPlace(ObjectWritable<A>, ObjectWritable<A>) - Method in class org.apache.tinkerpop.gremlin.spark.process.computer.MemoryAccumulator
 
addIoRegistries(Map<String, Object>, Mapper.Builder) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractMessageSerializer
Reads a list of fully qualified class names from the value of the AbstractMessageSerializer.TOKEN_IO_REGISTRIES configuration key.
addIterator(Iterator<T>) - Method in class org.apache.tinkerpop.gremlin.util.iterator.MultiIterator
 
addJmxReporter(String, String) - Method in enum org.apache.tinkerpop.gremlin.server.util.MetricManager
Create a JmxReporter attached to the Titan Metrics registry.
addLabel(String) - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jVertex
 
addLabel(String) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Step
Add a label to this step.
addLabel(String) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.AbstractStep
 
addLabel(String) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.EmptyStep
 
addLabels(Set<String>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traverser.Admin
 
addLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_LP_O_P_S_SE_SL_Traverser
 
addLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_LP_O_S_SE_SL_Traverser
 
addLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.LP_O_OB_P_S_SE_SL_Traverser
 
addLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.LP_O_OB_S_SE_SL_Traverser
 
addLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.ProjectedTraverser
 
addLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.AbstractTraverser
 
addLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.EmptyTraverser
 
addListener(MutationListener) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategy.Builder
 
addLocalChild(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.ConnectiveStep
 
addLocalChild(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GroupCountStep
 
addLocalChild(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.GroupCountSideEffectStep
 
addLocalChild(Traversal.Admin<?, ?>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.TraversalParent
 
addMapReduceMemoryKey(MapReduce) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.MapMemory
 
addMethodImports(Method...) - Method in class org.apache.tinkerpop.gremlin.jsr223.DefaultImportCustomizer.Builder
 
addMethodImports(Collection<Method>) - Method in class org.apache.tinkerpop.gremlin.jsr223.DefaultImportCustomizer.Builder
 
addModule(GremlinModule) - Method in class org.apache.tinkerpop.gremlin.jsr223.DefaultGremlinScriptEngineManager
Deprecated.
addModule(GremlinModule) - Method in interface org.apache.tinkerpop.gremlin.jsr223.GremlinScriptEngineManager
Deprecated.
As of release 3.2.4, replaced by GremlinScriptEngineManager.addPlugin(GremlinPlugin).
addNested(MutableMetrics) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.MutableMetrics
 
addOutE(String, String, Object...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
Deprecated.
addOutE(String, String, Object...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Deprecated.
As of release 3.1.0, replaced by GraphTraversal.addE(String)
addOutEdge(TinkerVertex, String, Edge) - Static method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerHelper
 
addPlugin(GremlinPlugin) - Method in class org.apache.tinkerpop.gremlin.jsr223.DefaultGremlinScriptEngineManager
 
addPlugin(GremlinPlugin) - Method in interface org.apache.tinkerpop.gremlin.jsr223.GremlinScriptEngineManager
Add GremlinPlugin instances to customize newly created GremlinScriptEngine instances.
addPlugins(String, Map<String, Map<String, Object>>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.Builder
Add a configuration for a GremlinPlugin to the executor.
addProperty(TinkerVertex, String, V) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerGraphComputerView
 
addPropertyDirect(String, Object) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopConfiguration
 
addPropertyMutations(Object...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.DropStep
This method doesn't do anything as drop() doesn't take property mutation arguments.
addPropertyMutations(Object...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddEdgeStep
 
addPropertyMutations(Object...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddVertexStartStep
 
addPropertyMutations(Object...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddVertexStep
 
addPropertyMutations(Object...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.Mutating
 
addPropertyMutations(Object...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.AddPropertyStep
 
AddPropertyStep<S extends Element> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect
 
AddPropertyStep(Traversal.Admin, VertexProperty.Cardinality, Object, Object) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.AddPropertyStep
 
addReadPartition(String) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.PartitionStrategy.Builder
Deprecated.
As of release 3.2.3, replaced by PartitionStrategy.Builder.readPartitions(List).
addRegistry(IoRegistry) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLMapper.Builder
 
addRegistry(IoRegistry) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONMapper.Builder
Adds a vendor supplied IoRegistry to the Mapper.Builder which enables it to check for vendor custom serializers to add to the Mapper.
addRegistry(IoRegistry) - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoMapper.Builder
Adds a vendor supplied IoRegistry to the Mapper.Builder which enables it to check for vendor custom serializers to add to the Mapper.
addRegistry(IoRegistry) - Method in interface org.apache.tinkerpop.gremlin.structure.io.Mapper.Builder
Adds a vendor supplied IoRegistry to the Mapper.Builder which enables it to check for vendor custom serializers to add to the Mapper.
addRepeatToTraversal(C, Traversal.Admin<B, B>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.RepeatStep
 
addRequirement(TraverserRequirement) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.RequirementsStep
 
addRequirements(TraversalStrategies, TraverserRequirement...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.RequirementsStrategy
 
addressingMode - Variable in class org.apache.tinkerpop.gremlin.server.Settings.GangliaReporterMetrics
 
addResultToMemory(Memory.Admin, Iterator<KeyValue<RK, RV>>) - Method in interface org.apache.tinkerpop.gremlin.process.computer.MapReduce
The final result can be generated and added to Memory and accessible via DefaultComputerResult.
addSideEffect(TraversalStrategies, String, A, BinaryOperator<A>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SideEffectStrategy
 
addSlf4jReporter(long, String) - Method in enum org.apache.tinkerpop.gremlin.server.util.MetricManager
Create a Slf4jReporter attached to the Titan Metrics registry.
addSource(String, Object...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.Bytecode
Add a TraversalSource instruction to the bytecode.
addStart(Traverser.Admin<Vertex>) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.lambda.HaltedTraversersCountTraversal
 
addStart(Traverser.Admin<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.lambda.AbstractLambdaTraversal
 
addStart(Traverser.Admin) - Method in class org.apache.tinkerpop.gremlin.process.traversal.lambda.ColumnTraversal
 
addStart(Traverser.Admin<Element>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.lambda.ElementValueTraversal
 
addStart(Traverser.Admin<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.lambda.IdentityTraversal
 
addStart(Traverser.Admin<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.lambda.LoopTraversal
 
addStart(Traverser.Admin<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.lambda.TokenTraversal
 
addStart(Traverser.Admin<S>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Step
Add a single Traverser.Admin to the step.
addStart(Traverser.Admin<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.AbstractStep
 
addStart(Traverser.Admin<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.EmptyStep
 
addStart(Traverser.Admin<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.SupplyingBarrierStep
 
addStart(Traverser.Admin<S>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traversal.Admin
Add a single Traverser.Admin object to the head of the traversal.
addStart(Traverser.Admin<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversal
 
addStart(Traverser.Admin<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversal
 
addStarts(Iterator<Traverser.Admin<S>>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Step
Add a iterator of Traverser.Admin objects of type S to the step.
addStarts(Iterator<Traverser.Admin<S>>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.AbstractStep
 
addStarts(Iterator<Traverser.Admin<S>>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.EmptyStep
 
addStarts(Iterator<Traverser.Admin<S>>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.SupplyingBarrierStep
 
addStarts(Iterator<Traverser.Admin<S>>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traversal.Admin
Add an iterator of Traverser.Admin objects to the head/start of the traversal.
addStarts(Iterator<Traverser.Admin<S>>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversal
 
addStarts(Iterator<Traverser.Admin<S>>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversal
 
addStep(int, Step<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.remote.traversal.AbstractRemoteTraversal
 
addStep(String, Object...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.Bytecode
Add a Traversal instruction to the bytecode.
addStep(Step<?, E2>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Admin
 
addStep(int, Step<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.lambda.AbstractLambdaTraversal
 
addStep(Step<?, E2>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traversal.Admin
Add a Step to the end of the traversal.
addStep(int, Step<?, ?>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traversal.Admin
Add a Step to an arbitrary point in the traversal.
addStep(int, Step<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversal
 
addStep(Step<?, E2>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversal
 
addStep(int, Step<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversal
 
addStrategies(TraversalStrategy<?>...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategies
Add all the provided TraversalStrategy instances to the current collection.
addStrategies(TraversalStrategy<?>...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversalStrategies
 
addStrategies(TraversalStrategy<?>...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversalStrategies
 
addTo(Object) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddEdgeStep
 
addToCollection(Collection<S>, S, long) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalHelper
 
addToCollectionUnrollIterator(Collection<S>, S, long) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalHelper
Deprecated.
As of release 3.2.3, not replaced - only used by GroupStepV3d0.
addTransactionListener(Consumer<Transaction.Status>) - Method in interface org.apache.tinkerpop.gremlin.structure.Transaction
Adds a listener that is called back with a status when a commit or rollback is successful.
addTransactionListener(Consumer<Transaction.Status>) - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractThreadedTransaction
 
addTransactionListener(Consumer<Transaction.Status>) - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractThreadLocalTransaction
 
addTraversal(Traversal.Admin<A, B>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalRing
 
addTree(Tree<T>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.Tree
 
addUntilToTraversal(C, Traversal.Admin<B, ?>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.RepeatStep
 
addV(String) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
addV() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
addV(Object...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
Deprecated.
addV(String) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
addV() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
addV(Object...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Deprecated.
As of release 3.1.0, replaced by GraphTraversal.addV()
addV - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
addV(Object...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource
Deprecated.
As of release 3.1.0, replaced by GraphTraversalSource.addV()
addV(String) - Method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource
 
addV() - Method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource
 
addVertex(Object...) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph
 
addVertex(Object...) - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
 
addVertex(Object...) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph
 
addVertex(Object...) - Method in class org.apache.tinkerpop.gremlin.process.remote.RemoteGraph
Deprecated.
 
addVertex(Object...) - Method in interface org.apache.tinkerpop.gremlin.structure.Graph
Add a Vertex to the graph given an optional series of key/value pairs.
addVertex(String) - Method in interface org.apache.tinkerpop.gremlin.structure.Graph
Add a Vertex to the graph with provided vertex label.
addVertex(Object...) - Method in class org.apache.tinkerpop.gremlin.structure.util.empty.EmptyGraph
 
addVertex(Object...) - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph
 
addVertex(Object...) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
 
addVertexEventRecorded() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategyProcessTest.StubMutationListener
 
addVertexProgramMemoryComputeKeys(VertexProgram<?>) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.MapMemory
 
AddVertexStartStep - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
AddVertexStartStep(Traversal.Admin, String) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddVertexStartStep
 
AddVertexStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
AddVertexStep(Traversal.Admin, String) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddVertexStep
 
AddVertexTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
AddVertexTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddVertexTest
 
AddVertexTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
AdjacentToIncidentStrategy - Class in org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization
This strategy looks for vertex- and value-emitting steps followed by a CountGlobalStep and replaces the pattern with an edge- or property-emitting step followed by a CountGlobalStep.
adjacentVertexEdgesAndVerticesCanNotBeReadOrUpdated() - Static method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputer.Exceptions
 
adjacentVertexLabelsCanNotBeRead() - Static method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputer.Exceptions
 
adjacentVertexPropertiesCanNotBeReadOrUpdated() - Static method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputer.Exceptions
 
afterFailure(BiConsumer<Bindings, Throwable>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.Builder
A Consumer to execute in the event of failure.
afterFailure(BiConsumer<Bindings, Throwable>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.LifeCycle.Builder
Specifies the function to execute if the script evaluation fails.
afterLoadGraphWith(Graph) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
 
afterLoadGraphWith(Graph) - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGeneratorTest.DifferentDistributionsTest
 
afterLoadGraphWith(Graph) - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGeneratorTest.ProcessorTest
 
afterLoadGraphWith(Graph) - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.DistributionGeneratorTest.DifferentDistributionsTest
 
afterLoadGraphWith(Graph) - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.DistributionGeneratorTest.ProcessorTest
 
afterLoadGraphWith(Graph) - Method in class org.apache.tinkerpop.gremlin.structure.GraphReadPerformanceTest.ReadFromGraph
Deprecated.
 
afterPluginTo(PluginAcceptor) - Method in class org.apache.tinkerpop.gremlin.giraph.groovy.plugin.GiraphGremlinPlugin
Deprecated.
 
afterPluginTo(PluginAcceptor) - Method in class org.apache.tinkerpop.gremlin.groovy.plugin.AbstractGremlinPlugin
Deprecated.
Called after the AbstractGremlinPlugin.pluginTo(PluginAcceptor) method is executed which sets the AbstractGremlinPlugin.io and AbstractGremlinPlugin.shell member variables.
afterPluginTo(PluginAcceptor) - Method in class org.apache.tinkerpop.gremlin.groovy.plugin.dsl.credential.CredentialGraphGremlinPlugin
Deprecated.
Called after the AbstractGremlinPlugin.pluginTo(PluginAcceptor) method is executed which sets the AbstractGremlinPlugin.io and AbstractGremlinPlugin.shell member variables.
afterPluginTo(PluginAcceptor) - Method in class org.apache.tinkerpop.gremlin.groovy.plugin.SugarGremlinPlugin
Deprecated.
Called after the AbstractGremlinPlugin.pluginTo(PluginAcceptor) method is executed which sets the AbstractGremlinPlugin.io and AbstractGremlinPlugin.shell member variables.
afterPluginTo(PluginAcceptor) - Method in class org.apache.tinkerpop.gremlin.hadoop.groovy.plugin.HadoopGremlinPlugin
Deprecated.
 
afterPluginTo(PluginAcceptor) - Method in class org.apache.tinkerpop.gremlin.neo4j.groovy.plugin.Neo4jGremlinPlugin
Deprecated.
 
afterPluginTo(PluginAcceptor) - Method in class org.apache.tinkerpop.gremlin.spark.groovy.plugin.SparkGremlinPlugin
Deprecated.
 
afterPluginTo(PluginAcceptor) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.groovy.plugin.TinkerGraphGremlinPlugin
Deprecated.
 
afterSuccess(Consumer<Bindings>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.Builder
A Consumer to execute just after successful script evaluation.
afterSuccess(Consumer<Bindings>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.LifeCycle.Builder
Specifies the function to execute after result transformations.
afterTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinSuite
Called just after test class execution.
afterTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.groovy.GroovyEnvironmentIntegrateSuite
Deprecated.
 
afterTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.groovy.GroovyEnvironmentPerformanceSuite
Deprecated.
 
afterTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.groovy.GroovyEnvironmentSuite
Deprecated.
 
afterTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.process.GroovyProcessComputerSuite
Deprecated.
 
afterTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.process.GroovyProcessStandardSuite
Deprecated.
 
afterTimeout(Consumer<Bindings>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.Builder
A Consumer to execute if the script times out.
afterTimeout(Consumer<Bindings>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.LifeCycle.Builder
Specifies the function to execute if the script evaluation times out.
agentId - Variable in class org.apache.tinkerpop.gremlin.server.Settings.JmxReporterMetrics
 
aggregate(ObjectWritable<<any>>) - Method in class org.apache.tinkerpop.gremlin.giraph.process.computer.MemoryAggregator
 
aggregate(String) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
aggregate(String) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
aggregate - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
aggregate(MutableMetrics) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.MutableMetrics
 
AggregateStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect
 
AggregateStep(Traversal.Admin, String) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.AggregateStep
 
AggregateTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect
 
AggregateTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.AggregateTest
 
AggregateTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect
 
algorithm(Class<? extends MatchStep.MatchAlgorithm>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.finalization.MatchAlgorithmStrategy.Builder
 
alias(String) - Method in class org.apache.tinkerpop.gremlin.driver.Client
Create a new Client that aliases the specified Graph or TraversalSource name on the server to a variable called "g" for the context of the requests made through that Client.
alias(Map<String, String>) - Method in class org.apache.tinkerpop.gremlin.driver.Client
Creates a Client that supplies the specified set of aliases, thus allowing the user to re-name one or more globally defined Graph or TraversalSource server bindings for the context of the created Client.
alias(String) - Method in class org.apache.tinkerpop.gremlin.driver.Client.ClusteredClient
Create a new Client that aliases the specified Graph or TraversalSource name on the server to a variable called "g" for the context of the requests made through that Client.
alias(Map<String, String>) - Method in class org.apache.tinkerpop.gremlin.driver.Client.ClusteredClient
Creates a Client that supplies the specified set of aliases, thus allowing the user to re-name one or more globally defined Graph or TraversalSource server bindings for the context of the created Client.
alias(Map<String, String>) - Method in class org.apache.tinkerpop.gremlin.driver.Client.ReboundClusteredClient
Deprecated.
Creates a Client that supplies the specified set of aliases, thus allowing the user to re-name one or more globally defined Graph or TraversalSource server bindings for the context of the created Client.
AliasClusteredClient(Client, Map<String, String>, Client.Settings) - Constructor for class org.apache.tinkerpop.gremlin.driver.Client.AliasClusteredClient
 
all() - Method in class org.apache.tinkerpop.gremlin.driver.ResultSet
The returned CompletableFuture completes when all reads are complete for this request and the entire result has been accounted for on the client.
allHosts() - Method in class org.apache.tinkerpop.gremlin.driver.Cluster
Gets a list of all the configured hosts.
allItemsAvailable() - Method in class org.apache.tinkerpop.gremlin.driver.ResultSet
Determines if all items have been returned to the client.
allItemsAvailableAsync() - Method in class org.apache.tinkerpop.gremlin.driver.ResultSet
Returns a future that will complete when all items have been returned from the server.
allMatch(Iterator<T>, Predicate<T>) - Static method in class org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils
 
allow(Object) - Method in interface org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph.IdManager
Determine if an identifier is allowed by this manager given its type.
AllowAllAuthenticator - Class in org.apache.tinkerpop.gremlin.server.auth
Allows all requests to be authenticated.
AllowAllAuthenticator() - Constructor for class org.apache.tinkerpop.gremlin.server.auth.AllowAllAuthenticator
 
allowLoops(boolean) - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.DistributionGenerator.Builder
Sets whether loops, i.e.
allowRemoteConsole() - Method in interface org.apache.tinkerpop.gremlin.groovy.plugin.RemoteAcceptor
Deprecated.
If the RemoteAcceptor is used in the Gremlin Console, then this method might be called to determine if it can be used in a fashion that supports the :remote console command.
allowRemoteConsole() - Method in class org.apache.tinkerpop.gremlin.hadoop.groovy.plugin.HadoopRemoteAcceptor
Deprecated.
 
allowRemoteConsole() - Method in class org.apache.tinkerpop.gremlin.hadoop.jsr223.HadoopRemoteAcceptor
 
allowRemoteConsole() - Method in interface org.apache.tinkerpop.gremlin.jsr223.console.RemoteAcceptor
If the RemoteAcceptor is used in the Gremlin Console, then this method might be called to determine if it can be used in a fashion that supports the :remote console command.
alpha(double) - Method in class org.apache.tinkerpop.gremlin.process.computer.ranking.pagerank.PageRankVertexProgram.Builder
 
and(Traversal<?, ?>...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
and(Traversal<?, ?>...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
and - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
and(Predicate<? super V>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.P
 
and(Predicate<? super V>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.AndP
 
and(Predicate<? super V>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.ConnectiveP
 
AND - Static variable in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTokens
 
AndP<V> - Class in org.apache.tinkerpop.gremlin.process.traversal.util
 
AndP(List<P<V>>) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.AndP
 
AndP(P<V>...) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.AndP
Deprecated.
AndStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
AndStep(Traversal.Admin, Traversal<S, ?>...) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.AndStep
 
AndTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
AndTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.AndTest
 
AndTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
andThen(TriConsumer<? super A, ? super B, ? super C>) - Method in interface org.apache.tinkerpop.gremlin.util.function.TriConsumer
Returns a composed @{link TriConsumer} that performs, in sequence, this operation followed by the after operation.
andThen(Function<? super R, ? extends V>) - Method in interface org.apache.tinkerpop.gremlin.util.function.TriFunction
Returns a composed function that first applies this function to its input, and then applies the after function to the result.
annotations - Variable in class org.apache.tinkerpop.gremlin.process.traversal.util.ImmutableMetrics
 
ANNOTATIONS - Static variable in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTokens
 
ANONYMOUS_USER - Static variable in class org.apache.tinkerpop.gremlin.server.auth.AuthenticatedUser
 
ANONYMOUS_USERNAME - Static variable in class org.apache.tinkerpop.gremlin.server.auth.AuthenticatedUser
 
anyMatch(Iterator<T>, Predicate<T>) - Static method in class org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils
 
anyStepRecursively(Predicate<Step>, Traversal.Admin<?, ?>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalHelper
Determine if any step in Traversal or its children match the step given the provided Predicate.
anyStepRecursively(Predicate<Step>, TraversalParent) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalHelper
 
appliesTo - Variable in class org.apache.tinkerpop.gremlin.jsr223.AbstractGremlinPlugin
 
appliesTo(Collection<String>) - Method in class org.apache.tinkerpop.gremlin.jsr223.BindingsGremlinPlugin.Builder
The name of the GremlinScriptEngine that this module will apply to.
appliesTo(Collection<String>) - Method in class org.apache.tinkerpop.gremlin.jsr223.ImportGremlinPlugin.Builder
The name of the GremlinScriptEngine that this module will apply to.
appliesTo(Collection<String>) - Method in class org.apache.tinkerpop.gremlin.jsr223.ScriptFileGremlinPlugin.Builder
The name of the GremlinScriptEngine that this module will apply to.
apply(A, A) - Method in class org.apache.tinkerpop.gremlin.groovy.function.GBinaryOperator
Deprecated.
 
apply(A) - Method in class org.apache.tinkerpop.gremlin.groovy.function.GFunction
Deprecated.
 
apply(A) - Method in class org.apache.tinkerpop.gremlin.groovy.function.GUnaryOperator
Deprecated.
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.neo4j.process.traversal.strategy.optimization.Neo4jGraphStepStrategy
 
apply(Graph) - Method in class org.apache.tinkerpop.gremlin.process.computer.Computer
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.decoration.VertexProgramStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.optimization.GraphFilterStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.optimization.MessagePassingReductionStrategy
 
apply(V, G, M) - Method in interface org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.VertexProgramInterceptor
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.remote.traversal.strategy.decoration.RemoteStrategy
 
apply(Traverser<A>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.lambda.FunctionTraverser
 
apply(TraverserSet<S>, TraverserSet<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.RangeGlobalStep.RangeBiOperator
 
apply(E, E) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.FoldStep.FoldBiOperator
 
apply(Map<E, Long>, Map<E, Long>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GroupCountStep.GroupCountBiOperator
 
apply(Map<K, V>, Map<K, V>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GroupStep.GroupBiOperator
 
apply(Map<K, V>, Map<K, V>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GroupStepV3d0.GroupBiOperatorV3d0
Deprecated.
 
apply(Traverser.Admin<Object>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchStep.CountMatchAlgorithm
 
apply(Traverser.Admin<Object>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchStep.GreedyMatchAlgorithm
 
apply(S, S) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MeanGlobalStep.MeanGlobalBiOperator
 
apply(TraverserSet<S>, TraverserSet<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.OrderGlobalStep.OrderBiOperator
 
apply(Tree, Tree) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.TreeStep.TreeBiOperator
 
apply(MutableMetrics, MutableMetrics) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ProfileStep.ProfileBiOperator
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.ConnectiveStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.ElementIdStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.HaltedTraverserStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.PartitionStrategy
 
apply(Traverser<Map<String, List<Property>>>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.PartitionStrategy.MapPropertiesConverter
 
apply(Traverser<Map<String, List<Property>>>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.PartitionStrategy.MapPropertiesFilter
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.RequirementsStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SackStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SideEffectStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SubgraphStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.TranslationStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.finalization.LazyBarrierStrategy
Deprecated.
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.finalization.MatchAlgorithmStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.finalization.ProfileStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.AdjacentToIncidentStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.FilterRankingStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.IdentityRemovalStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.IncidentToAdjacentStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.InlineFilterStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.LazyBarrierStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.MatchPredicateStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.OrderLimitStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.PathProcessorStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.PathRetractionStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.RangeByIsCountStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.RepeatUnrollStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.verification.ComputerVerificationStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.verification.LambdaRestrictionStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.verification.ReadOnlyStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.verification.StandardVerificationStrategy
 
apply(Traversal.Admin<?, ?>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategy
 
apply(Graph) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalClassFunction
 
apply(Graph) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalObjectFunction
 
apply(Graph) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalScriptFunction
Deprecated.
 
apply(Traverser.Admin<S>, Traversal.Admin<S, E>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalUtil
 
apply(S, Traversal.Admin<S, E>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalUtil
 
apply(TraversalVertexProgram, <any>, SparkMemory) - Method in class org.apache.tinkerpop.gremlin.spark.process.computer.traversal.strategy.optimization.interceptor.SparkStarBarrierInterceptor
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.spark.process.computer.traversal.strategy.optimization.SparkInterceptorStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.spark.process.computer.traversal.strategy.optimization.SparkSingleIterationStrategy
 
apply(Element) - Method in enum org.apache.tinkerpop.gremlin.structure.T
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.traversal.strategy.optimization.TinkerGraphCountStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.traversal.strategy.optimization.TinkerGraphStepStrategy
 
apply(A) - Method in class org.apache.tinkerpop.gremlin.util.function.Lambda.OneArgLambda
 
apply(A, B) - Method in class org.apache.tinkerpop.gremlin.util.function.Lambda.TwoArgLambda
 
apply(Object) - Method in class org.apache.tinkerpop.gremlin.util.function.ScriptEngineLambda
 
apply(T) - Method in interface org.apache.tinkerpop.gremlin.util.function.ThrowingFunction
 
apply(A, B, C) - Method in interface org.apache.tinkerpop.gremlin.util.function.TriFunction
Applies this function to the given arguments.
applyAll(Traverser.Admin<S>, Traversal.Admin<S, E>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalUtil
 
applyAll(S, Traversal.Admin<S, E>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalUtil
 
applyConfiguration(Configuration) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.HadoopPoolShimService
 
applyConfiguration(Configuration) - Method in class org.apache.tinkerpop.gremlin.spark.structure.io.gryo.kryoshim.unshaded.UnshadedKryoShimService
 
applyConfiguration(Configuration) - Method in interface org.apache.tinkerpop.gremlin.structure.io.gryo.kryoshim.KryoShimService
Attempt to incorporate the supplied configuration in future read/write calls.
applyConfiguration(Configuration) - Static method in class org.apache.tinkerpop.gremlin.structure.io.gryo.kryoshim.KryoShimServiceLoader
 
applyCustomization(CompilerConfiguration) - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.ConfigurationCustomizerProvider
Deprecated.
 
applyGraphFilter(<any>, GraphFilter) - Static method in class org.apache.tinkerpop.gremlin.spark.process.computer.SparkExecutor
 
applyGraphFilter(GraphFilter) - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph
 
applyGraphFilter(GraphFilter) - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph.StarVertex
 
applyNullable(Traverser.Admin<S>, Traversal.Admin<S, E>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalUtil
 
applyNullable(S, Traversal.Admin<S, E>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalUtil
 
applyPost() - Method in class org.apache.tinkerpop.gremlin.process.remote.traversal.strategy.decoration.RemoteStrategy
 
applyPost() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.RequirementsStrategy
 
applyPost() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SubgraphStrategy
 
applyPost() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.TranslationStrategy
 
applyPost() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.finalization.LazyBarrierStrategy
Deprecated.
 
applyPost() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.InlineFilterStrategy
 
applyPost() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.MatchPredicateStrategy
 
applyPost() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.PathProcessorStrategy
 
applyPost() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.verification.ReadOnlyStrategy
 
applyPost() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategy
The set of strategies that must be executed after this strategy is executed.
applyPost() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.traversal.strategy.optimization.TinkerGraphCountStrategy
 
applyPrior() - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.optimization.MessagePassingReductionStrategy
 
applyPrior() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.finalization.LazyBarrierStrategy
Deprecated.
 
applyPrior() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.AdjacentToIncidentStrategy
 
applyPrior() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.FilterRankingStrategy
 
applyPrior() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.IncidentToAdjacentStrategy
 
applyPrior() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.InlineFilterStrategy
 
applyPrior() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.LazyBarrierStrategy
 
applyPrior() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.MatchPredicateStrategy
 
applyPrior() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.PathProcessorStrategy
 
applyPrior() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.optimization.PathRetractionStrategy
 
applyPrior() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.verification.StandardVerificationStrategy
 
applyPrior() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategy
The set of strategies that must be executed before this strategy is executed.
applySingleLevelStrategies(Traversal.Admin<?, ?>, Traversal.Admin<?, ?>, Class<? extends TraversalStrategy>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalHelper
 
applyStrategies() - Method in class org.apache.tinkerpop.gremlin.process.remote.traversal.AbstractRemoteTraversal
 
applyStrategies() - Method in class org.apache.tinkerpop.gremlin.process.traversal.lambda.AbstractLambdaTraversal
 
applyStrategies() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traversal.Admin
Apply the registered TraversalStrategies to the traversal.
applyStrategies(Traversal.Admin<?, ?>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategies
Apply all the TraversalStrategy optimizers to the Traversal for the stated TraversalEngine.
applyStrategies() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversal
 
applyStrategies(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversalStrategies
 
applyStrategies() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversal
 
applyStrategies(Traversal.Admin<?, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversalStrategies
 
applyStrategies() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.ScriptTraversal
 
applyTraversalRecursively(Consumer<Traversal.Admin<?, ?>>, Traversal.Admin<?, ?>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalHelper
Apply the provider Consumer function to the provided Traversal and all of its children.
areEqual(MapReduce, Object) - Static method in class org.apache.tinkerpop.gremlin.process.computer.util.GraphComputerHelper
 
areEqual(Element, Object) - Static method in class org.apache.tinkerpop.gremlin.structure.util.ElementHelper
A standard method for determining if two Element objects are equal.
areEqual(Vertex, Vertex) - Static method in class org.apache.tinkerpop.gremlin.structure.util.ElementHelper
 
areEqual(Edge, Edge) - Static method in class org.apache.tinkerpop.gremlin.structure.util.ElementHelper
 
areEqual(VertexProperty, VertexProperty) - Static method in class org.apache.tinkerpop.gremlin.structure.util.ElementHelper
 
areEqual(VertexProperty, Object) - Static method in class org.apache.tinkerpop.gremlin.structure.util.ElementHelper
A standard method for determining if two VertexProperty objects are equal.
areEqual(Property, Object) - Static method in class org.apache.tinkerpop.gremlin.structure.util.ElementHelper
A standard method for determining if two Property objects are equal.
ARGS_AGGREGATE_TO - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_ALIASES - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_BATCH_SIZE - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_BINDINGS - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_COORDINATES - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
Deprecated.
As for release 3.2.2, not replaced as this feature was never really published as official.
ARGS_COORDINATES_ARTIFACT - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
Deprecated.
As for release 3.2.2, not replaced as this feature was never really published as official.
ARGS_COORDINATES_GROUP - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
Deprecated.
As for release 3.2.2, not replaced as this feature was never really published as official.
ARGS_COORDINATES_VERSION - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
Deprecated.
As for release 3.2.2, not replaced as this feature was never really published as official.
ARGS_FORCE - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_GREMLIN - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_HOST - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_IMPORTS - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
Deprecated.
As for release 3.2.2, not replaced as this feature was never really published as official.
ARGS_INFO_TYPE - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
Deprecated.
As for release 3.2.2, not replaced as this feature was never really published as official.
ARGS_INFO_TYPE_DEPDENENCIES - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
Deprecated.
As of release 3.1.1-incubating, replaced by Tokens.ARGS_INFO_TYPE_DEPENDENCIES
ARGS_INFO_TYPE_DEPENDENCIES - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
Deprecated.
As for release 3.2.2, not replaced as this feature was never really published as official.
ARGS_INFO_TYPE_IMPORTS - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
Deprecated.
As for release 3.2.2, not replaced as this feature was never really published as official.
ARGS_LANGUAGE - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_MANAGE_TRANSACTION - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_REBINDINGS - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
Deprecated.
As of release 3.1.0-incubating, replaced by Tokens.ARGS_ALIASES.
ARGS_SASL - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_SASL_MECHANISM - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_SCRIPT_EVAL_TIMEOUT - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_SESSION - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_SIDE_EFFECT - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
ARGS_SIDE_EFFECT_KEY - Static variable in class org.apache.tinkerpop.gremlin.driver.Tokens
 
argumentCanNotBeNull(String) - Static method in class org.apache.tinkerpop.gremlin.structure.Graph.Exceptions
 
ARGUMENTS - Static variable in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTokens
 
arguments - Variable in class org.apache.tinkerpop.gremlin.structure.PropertyTest.PropertyValidationOnAddExceptionConsistencyTest
 
ArrayIterator<T> - Class in org.apache.tinkerpop.gremlin.util.iterator
 
ArrayIterator(T[]) - Constructor for class org.apache.tinkerpop.gremlin.util.iterator.ArrayIterator
 
ArrayListSupplier<A> - Class in org.apache.tinkerpop.gremlin.util.function
 
Artifact - Class in org.apache.tinkerpop.gremlin.groovy.plugin
Deprecated.
As of release 3.2.4, replaced by Artifact
Artifact(String, String, String) - Constructor for class org.apache.tinkerpop.gremlin.groovy.plugin.Artifact
Deprecated.
Create a new instance.
Artifact - Class in org.apache.tinkerpop.gremlin.groovy.util
A software artifact identified by its maven coordinates.
Artifact(String, String, String) - Constructor for class org.apache.tinkerpop.gremlin.groovy.util.Artifact
Create a new instance.
as(String, String...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
as(String, String...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
as - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
asAdmin() - Method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.DefaultGraphTraversal
 
asAdmin() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
asAdmin() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traversal
Get access to administrative methods of the traversal via its accompanying Traversal.Admin.
asAdmin() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traverser
Typecast the traverser to a "system traverser" so Traverser.Admin methods can be accessed.
asAdmin() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversal
 
asAdmin() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversal
 
asBulk() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.BulkSet
 
asCloseable(Iterator<T>) - Static method in interface org.apache.tinkerpop.gremlin.structure.util.CloseableIterator
Wraps an existing Iterator in a CloseableIterator.
asImmutable() - Method in interface org.apache.tinkerpop.gremlin.process.computer.Memory.Admin
 
asImmutable() - Method in class org.apache.tinkerpop.gremlin.process.computer.util.EmptyMemory
 
asIterator(Object) - Static method in class org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils
 
asList(Object) - Static method in class org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils
 
asMap() - Method in interface org.apache.tinkerpop.gremlin.process.computer.Memory
A helper method that generates a Map of the memory key/values.
asMap() - Method in interface org.apache.tinkerpop.gremlin.structure.Graph.Variables
Gets the variables of the Graph as a Map.
asMap(Object...) - Static method in class org.apache.tinkerpop.gremlin.structure.util.ElementHelper
Converts a set of key values to a Map.
asPairs(Object...) - Static method in class org.apache.tinkerpop.gremlin.structure.util.ElementHelper
Convert a set of key values to a list of Pair objects.
assert_g_VX1X_out_hasXid_2_3X(Object, Object, Traversal<Vertex, Vertex>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.HasTest
 
assertClassicGraph(Graph, boolean, boolean) - Static method in class org.apache.tinkerpop.gremlin.structure.io.IoTest
 
assertCrewGraph(Graph, boolean) - Static method in class org.apache.tinkerpop.gremlin.structure.io.IoTest
 
assertDouble - Variable in class org.apache.tinkerpop.gremlin.structure.io.IoEdgeTest
 
assertDouble - Variable in class org.apache.tinkerpop.gremlin.structure.io.IoGraphTest
 
assertDouble - Variable in class org.apache.tinkerpop.gremlin.structure.io.IoPropertyTest
 
assertEdgesAtSameTimeAsVertex - Variable in class org.apache.tinkerpop.gremlin.structure.io.IoVertexTest
 
assertIdDirectly - Variable in class org.apache.tinkerpop.gremlin.structure.io.IoCustomTest
 
assertIdDirectly - Variable in class org.apache.tinkerpop.gremlin.structure.io.IoEdgeTest
 
assertIdDirectly - Variable in class org.apache.tinkerpop.gremlin.structure.io.IoPropertyTest
 
assertModernGraph(Graph, boolean, boolean) - Static method in class org.apache.tinkerpop.gremlin.structure.io.IoTest
 
assertNoEdgeGraph(Graph, boolean, boolean) - Static method in class org.apache.tinkerpop.gremlin.structure.io.IoTest
 
assertVertexEdgeCounts(Graph, int, int) - Static method in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
 
assertViaDirectEquality - Variable in class org.apache.tinkerpop.gremlin.structure.io.IoVertexTest
 
asStep() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.TraversalParent
 
assumeNonDeterministic() - Static method in class org.apache.tinkerpop.gremlin.TestHelper
Used at the start of a test to make it one that should only be executed when the assertNonDeterministic system property is set to true.
atMaster(boolean) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.DedupGlobalStep
 
atMaster(boolean) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.GraphComputing
Some steps should behave different whether they are executing at the master traversal or distributed across the worker traversals.
atMaster(Step<?, ?>, boolean) - Static method in interface org.apache.tinkerpop.gremlin.process.traversal.step.GraphComputing
 
attach(Iterator<Traverser.Admin<S>>, Graph) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.step.map.ComputerResultStep
 
attach(Function<Attachable<T>, T>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traverser.Admin
Regenerate the detached traverser given its location at a particular vertex.
attach(Function<Attachable<T>, T>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.ProjectedTraverser
 
attach(Function<Attachable<T>, T>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.AbstractTraverser
 
attach(Function<Attachable<T>, T>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.EmptyTraverser
 
attach(Function<Attachable<V>, V>) - Method in interface org.apache.tinkerpop.gremlin.structure.util.Attachable
Provide a way to attach an Attachable implementation to a host.
attach(Function<Attachable<Path>, Path>) - Method in class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedPath
 
attach(Function<Attachable<Path>, Path>) - Method in class org.apache.tinkerpop.gremlin.structure.util.reference.ReferencePath
 
Attachable<V> - Interface in org.apache.tinkerpop.gremlin.structure.util
An interface that provides methods for detached properties and elements to be re-attached to the Graph.
Attachable.Exceptions - Class in org.apache.tinkerpop.gremlin.structure.util
 
Attachable.Method - Class in org.apache.tinkerpop.gremlin.structure.util
A collection of general methods of attachment.
attachProperties(Element, Object...) - Static method in class org.apache.tinkerpop.gremlin.structure.util.ElementHelper
Assign key/value pairs as properties to an Element.
attachProperties(Vertex, Object...) - Static method in class org.apache.tinkerpop.gremlin.structure.util.ElementHelper
Assign key/value pairs as properties to an Vertex.
attachProperties(Vertex, VertexProperty.Cardinality, Object...) - Static method in class org.apache.tinkerpop.gremlin.structure.util.ElementHelper
Assign key/value pairs as properties to a Vertex.
attempt(BiFunction<Graph, Function<Graph, R>, R>) - Method in class org.apache.tinkerpop.gremlin.structure.Transaction.Workload
Try to execute a Transaction.Workload with a mapper retry strategy.
attemptCommit(RequestMessage, GraphManager, boolean) - Static method in class org.apache.tinkerpop.gremlin.server.op.AbstractOpProcessor
 
attemptRollback(RequestMessage, GraphManager, boolean) - Static method in class org.apache.tinkerpop.gremlin.server.op.AbstractOpProcessor
 
authenticate(Map<String, String>) - Method in class org.apache.tinkerpop.gremlin.server.auth.AllowAllAuthenticator
 
authenticate(Map<String, String>) - Method in interface org.apache.tinkerpop.gremlin.server.auth.Authenticator
A "standard" authentication implementation that can be used more generically without SASL support.
authenticate(Map<String, String>) - Method in class org.apache.tinkerpop.gremlin.server.auth.SimpleAuthenticator
 
AuthenticatedUser - Class in org.apache.tinkerpop.gremlin.server.auth
 
AuthenticatedUser(String) - Constructor for class org.apache.tinkerpop.gremlin.server.auth.AuthenticatedUser
 
authentication - Variable in class org.apache.tinkerpop.gremlin.server.Settings
 
AuthenticationException - Exception in org.apache.tinkerpop.gremlin.server.auth
An exception that occurs when during authentication such as a failed login.
AuthenticationException() - Constructor for exception org.apache.tinkerpop.gremlin.server.auth.AuthenticationException
 
AuthenticationException(String) - Constructor for exception org.apache.tinkerpop.gremlin.server.auth.AuthenticationException
 
AuthenticationException(String, Throwable) - Constructor for exception org.apache.tinkerpop.gremlin.server.auth.AuthenticationException
 
AuthenticationException(Throwable) - Constructor for exception org.apache.tinkerpop.gremlin.server.auth.AuthenticationException
 
AuthenticationException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.tinkerpop.gremlin.server.auth.AuthenticationException
 
AuthenticationSettings() - Constructor for class org.apache.tinkerpop.gremlin.server.Settings.AuthenticationSettings
 
authenticator - Variable in class org.apache.tinkerpop.gremlin.server.AbstractChannelizer
 
Authenticator - Interface in org.apache.tinkerpop.gremlin.server.auth
Provides methods related to authentication of a request.
Authenticator.SaslNegotiator - Interface in org.apache.tinkerpop.gremlin.server.auth
Performs the actual SASL negotiation for a single authentication attempt.
AuthProperties - Class in org.apache.tinkerpop.gremlin.driver
Properties to supply to the Cluster for authentication purposes.
AuthProperties() - Constructor for class org.apache.tinkerpop.gremlin.driver.AuthProperties
 
authProperties(AuthProperties) - Method in class org.apache.tinkerpop.gremlin.driver.Cluster.Builder
Specifies parameters for authentication to Gremlin Server.
AuthProperties.Property - Enum in org.apache.tinkerpop.gremlin.driver
An enum of the available authorization properties.
autoUpdateIndex(TinkerEdge, String, Object, Object) - Static method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerHelper
 
autoUpdateIndex(TinkerVertex, String, Object, Object) - Static method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerHelper
 
availableHosts() - Method in class org.apache.tinkerpop.gremlin.driver.Cluster
Gets the list of hosts that the Cluster was able to connect to.

B

B_LP_O_P_S_SE_SL_Traverser<T> - Class in org.apache.tinkerpop.gremlin.process.traversal.traverser
 
B_LP_O_P_S_SE_SL_Traverser() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_LP_O_P_S_SE_SL_Traverser
 
B_LP_O_P_S_SE_SL_Traverser(T, Step<T, ?>, long) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_LP_O_P_S_SE_SL_Traverser
 
B_LP_O_P_S_SE_SL_TraverserGenerator - Class in org.apache.tinkerpop.gremlin.process.traversal.traverser
 
B_LP_O_S_SE_SL_Traverser<T> - Class in org.apache.tinkerpop.gremlin.process.traversal.traverser
 
B_LP_O_S_SE_SL_Traverser() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_LP_O_S_SE_SL_Traverser
 
B_LP_O_S_SE_SL_Traverser(T, Step<T, ?>, long) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_LP_O_S_SE_SL_Traverser
 
B_LP_O_S_SE_SL_TraverserGenerator - Class in org.apache.tinkerpop.gremlin.process.traversal.traverser
 
B_O_S_SE_SL_Traverser<T> - Class in org.apache.tinkerpop.gremlin.process.traversal.traverser
 
B_O_S_SE_SL_Traverser() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_O_S_SE_SL_Traverser
 
B_O_S_SE_SL_Traverser(T, Step<T, ?>, long) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_O_S_SE_SL_Traverser
 
B_O_S_SE_SL_TraverserGenerator - Class in org.apache.tinkerpop.gremlin.process.traversal.traverser
 
B_O_Traverser<T> - Class in org.apache.tinkerpop.gremlin.process.traversal.traverser
 
B_O_Traverser() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_O_Traverser
 
B_O_Traverser(T, long) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_O_Traverser
 
B_O_TraverserGenerator - Class in org.apache.tinkerpop.gremlin.process.traversal.traverser
 
BadGraphComputer() - Constructor for class org.apache.tinkerpop.gremlin.process.computer.GraphComputerTest.BadGraphComputer
 
barrier() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
barrier(int) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
barrier(Consumer<TraverserSet<Object>>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
barrier() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
barrier(int) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
barrier(Consumer<TraverserSet<Object>>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
barrier - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
Barrier<B> - Interface in org.apache.tinkerpop.gremlin.process.traversal.step
A Barrier is any step that requires all left traversers to be processed prior to emitting result traversers to the right.
barrierConsumer(TraverserSet<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.SampleGlobalStep
 
barrierConsumer(TraverserSet<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.LambdaCollectingBarrierStep
 
barrierConsumer(TraverserSet<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.OrderGlobalStep
 
barrierConsumer(TraverserSet<S>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.CollectingBarrierStep
 
baseElement - Variable in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopElement
 
baseElement - Variable in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jElement
 
baseGraph - Variable in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
 
BaseMetrics() - Constructor for class org.apache.tinkerpop.gremlin.server.Settings.BaseMetrics
 
BasicEdgeTest() - Constructor for class org.apache.tinkerpop.gremlin.structure.EdgeTest.BasicEdgeTest
 
BasicPropertyTest() - Constructor for class org.apache.tinkerpop.gremlin.structure.PropertyTest.BasicPropertyTest
 
BasicVertexProperty() - Constructor for class org.apache.tinkerpop.gremlin.structure.VertexPropertyTest.BasicVertexProperty
 
BasicVertexTest() - Constructor for class org.apache.tinkerpop.gremlin.structure.VertexTest.BasicVertexTest
 
batchSize(long) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLReader.Builder
Number of mutations to perform before a commit is executed.
batchSize(long) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONReader.Builder
Number of mutations to perform before a commit is executed when using GraphSONReader.readGraph(InputStream, Graph).
batchSize(long) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.LegacyGraphSONReader.Builder
Number of mutations to perform before a commit is executed.
batchSize(long) - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoReader.Builder
Number of mutations to perform before a commit is executed when using GryoReader.readGraph(InputStream, Graph).
beforeEval(Consumer<Bindings>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.Builder
A Consumer to execute just before the script evaluation.
beforeEval(Consumer<Bindings>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.LifeCycle.Builder
Specifies the function to execute prior to the script being evaluated.
beforeLoadGraphWith(Graph) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
 
beforeProcessing(Graph, Context) - Method in class org.apache.tinkerpop.gremlin.server.op.traversal.TraversalOpProcessor
 
beforeTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinSuite
Called just prior to test class execution.
beforeTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.groovy.GroovyEnvironmentIntegrateSuite
Deprecated.
 
beforeTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.groovy.GroovyEnvironmentPerformanceSuite
Deprecated.
 
beforeTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.groovy.GroovyEnvironmentSuite
Deprecated.
 
beforeTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.process.GroovyProcessComputerSuite
Deprecated.
 
beforeTestExecution(Class<? extends AbstractGremlinTest>) - Method in class org.apache.tinkerpop.gremlin.process.GroovyProcessStandardSuite
Deprecated.
 
benchmarkRun - Variable in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutorPerformanceTest
Deprecated.
 
benchmarkRun - Variable in class org.apache.tinkerpop.gremlin.process.TraversalPerformanceTest
Deprecated.
 
benchmarkRun - Variable in class org.apache.tinkerpop.gremlin.structure.GraphReadPerformanceTest.ReadFromGraph
Deprecated.
 
benchmarkRun - Variable in class org.apache.tinkerpop.gremlin.structure.GraphWritePerformanceTest.WriteToGraph
Deprecated.
 
benchmarkRun - Variable in class org.apache.tinkerpop.gremlin.structure.GraphWritePerformanceTest.WriteToIO
Deprecated.
 
between(V, V) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.P
 
biFunction(String, String) - Static method in interface org.apache.tinkerpop.gremlin.util.function.Lambda
 
biFunction(String) - Static method in interface org.apache.tinkerpop.gremlin.util.function.Lambda
 
Binding(String, V) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.Bytecode.Binding
 
bindingMaker - Variable in class org.apache.tinkerpop.gremlin.server.op.standard.StandardOpProcessor
 
bindings(Map<String, Object>) - Method in class org.apache.tinkerpop.gremlin.jsr223.BindingsGremlinPlugin.Builder
 
Bindings - Class in org.apache.tinkerpop.gremlin.process.traversal
Bindings are used to associate a variable with a value.
Bindings() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.Bindings
Deprecated.
As of release 3.2.4, replaced by Bindings.instance().
BindingsCustomizer - Interface in org.apache.tinkerpop.gremlin.jsr223
Provides a way to alter the bindings on a GremlinScriptEngine.
BindingSerializer() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoSerializers.BindingSerializer
 
BindingsGremlinPlugin - Class in org.apache.tinkerpop.gremlin.jsr223
A module that allows Bindings to be applied to a GremlinScriptEngine.
BindingsGremlinPlugin(Bindings, int) - Constructor for class org.apache.tinkerpop.gremlin.jsr223.BindingsGremlinPlugin
 
BindingsGremlinPlugin(Supplier<Bindings>, int) - Constructor for class org.apache.tinkerpop.gremlin.jsr223.BindingsGremlinPlugin
 
BindingsGremlinPlugin.Builder - Class in org.apache.tinkerpop.gremlin.jsr223
 
BindingsScriptEngineTest - Class in org.apache.tinkerpop.gremlin.jsr223
 
BindingsScriptEngineTest() - Constructor for class org.apache.tinkerpop.gremlin.jsr223.BindingsScriptEngineTest
 
biPredicate - Variable in class org.apache.tinkerpop.gremlin.process.traversal.P
 
both(String...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
both(String...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Map the Vertex to its adjacent vertices given the edge labels.
both - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
bothE(String...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
bothE(String...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Map the Vertex to its incident edges given the edge labels.
bothE - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
bothV() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
bothV() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Map the Edge to its incident vertices.
bothV - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
bothVertices() - Method in interface org.apache.tinkerpop.gremlin.structure.Edge
Get both the outgoing and incoming vertices of this edge.
branch(Function<Traverser<A>, M>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
branch(Traversal<?, M>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
branch(Traversal<?, M>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
branch(Function<Traverser<E>, M>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
branch - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
BranchStep<S,E,M> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.branch
 
BranchStep(Traversal.Admin) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.branch.BranchStep
 
BranchTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.branch
 
BranchTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.branch.BranchTest
 
BranchTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.branch
 
branchTraversal - Variable in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.BranchStep
 
broadcastMemory(JavaSparkContext) - Method in class org.apache.tinkerpop.gremlin.spark.process.computer.SparkMemory
 
build(Graph) - Static method in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGenerator
 
build(Graph) - Static method in class org.apache.tinkerpop.gremlin.algorithm.generator.DistributionGenerator
 
build() - Static method in class org.apache.tinkerpop.gremlin.driver.Client.SessionSettings
 
build() - Static method in class org.apache.tinkerpop.gremlin.driver.Client.Settings
 
build() - Static method in class org.apache.tinkerpop.gremlin.driver.Cluster
 
build(String) - Static method in class org.apache.tinkerpop.gremlin.driver.Cluster
 
build(File) - Static method in class org.apache.tinkerpop.gremlin.driver.Cluster
 
build(String) - Static method in class org.apache.tinkerpop.gremlin.driver.message.RequestMessage
 
build(RequestMessage) - Static method in class org.apache.tinkerpop.gremlin.driver.message.ResponseMessage
 
build(UUID) - Static method in class org.apache.tinkerpop.gremlin.driver.message.ResponseMessage
 
build() - Static method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor
Create a Builder with the gremlin-groovy ScriptEngine configured.
build(String, List<String>, List<String>, List<String>, Map<String, Object>) - Static method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor
Deprecated.
As of release 3.2.4, replaced by GremlinExecutor.build().
build() - Static method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.LifeCycle
 
build() - Static method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GroovyCompilerGremlinPlugin
 
build() - Static method in class org.apache.tinkerpop.gremlin.jsr223.BindingsGremlinPlugin
 
build() - Static method in class org.apache.tinkerpop.gremlin.jsr223.DefaultImportCustomizer
 
build() - Static method in class org.apache.tinkerpop.gremlin.jsr223.ImportGremlinPlugin
 
build() - Static method in class org.apache.tinkerpop.gremlin.jsr223.ScriptFileGremlinPlugin
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.computer.bulkdumping.BulkDumperVertexProgram
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoaderVertexProgram
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.ClusterCountMapReduce
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.ClusterPopulationMapReduce
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.PeerPressureVertexProgram
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.computer.ranking.pagerank.PageRankMapReduce
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.computer.ranking.pagerank.PageRankVertexProgram
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.decoration.VertexProgramStrategy
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.computer.traversal.TraversalVertexProgram
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
build() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.engine.ComputerTraversalEngine
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
build() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.engine.StandardTraversalEngine
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
build() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.ElementIdStrategy
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategy
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.PartitionStrategy
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SackStrategy
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SubgraphStrategy
 
build() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.finalization.MatchAlgorithmStrategy
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLIo
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLMapper
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLReader
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLWriter
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONIo
Create a new builder using the default version of GraphSON.
build(GraphSONVersion) - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONIo
Create a new builder using the specified version of GraphSON.
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONMapper
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONReader
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONWriter
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONXModuleV2d0
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphson.LegacyGraphSONReader
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoIo
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoMapper
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoPool
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoReader
 
build() - Static method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoWriter
 
Builder() - Constructor for class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.LifeCycle.Builder
 
Builder() - Constructor for class org.apache.tinkerpop.gremlin.groovy.jsr223.GroovyCompilerGremlinPlugin.Builder
 
Builder() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.engine.ComputerTraversalEngine.Builder
Deprecated.
 
Builder() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.engine.StandardTraversalEngine.Builder
Deprecated.
 
Builder() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLIo.Builder
 
Builder() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLMapper.Builder
 
Builder() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoIo.Builder
 
Builder() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoPool.Builder
 
buildMessage(RequestMessage.Builder) - Method in class org.apache.tinkerpop.gremlin.driver.Client
Makes any final changes to the builder and returns the constructed RequestMessage.
buildMessage(RequestMessage.Builder) - Method in class org.apache.tinkerpop.gremlin.driver.Client.ReboundClusteredClient
Deprecated.
 
buildMessage(RequestMessage.Builder) - Method in class org.apache.tinkerpop.gremlin.driver.Client.SessionedClient
Adds the Tokens.ARGS_SESSION value to every RequestMessage.
buildTypeDeserializer(DeserializationConfig, JavaType, Collection<NamedType>) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTypeResolverBuilder
 
buildTypeSerializer(SerializationConfig, JavaType, Collection<NamedType>) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTypeResolverBuilder
 
bulk() - Method in class org.apache.tinkerpop.gremlin.process.remote.traversal.AbstractRemoteTraverser
 
bulk - Variable in class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_O_Traverser
 
bulk() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_O_Traverser
 
bulk() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traverser
A traverser may represent a grouping of traversers to allow for more efficient data propagation.
bulk - Variable in class org.apache.tinkerpop.gremlin.process.traversal.traverser.O_OB_S_SE_SL_Traverser
 
bulk() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.O_OB_S_SE_SL_Traverser
 
bulk() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.ProjectedTraverser
 
bulk() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.AbstractTraverser
 
bulk() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.EmptyTraverser
 
BULK - Static variable in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTokens
 
BULK_LOADER_CLASS_CFG_KEY - Static variable in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoaderVertexProgram
 
BULK_LOADER_VERTEX_ID_CFG_KEY - Static variable in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoaderVertexProgram
 
BULK_LOADER_VERTEX_PROGRAM_CFG_PREFIX - Static variable in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoaderVertexProgram
 
BulkDumperVertexProgram - Class in org.apache.tinkerpop.gremlin.process.computer.bulkdumping
 
BulkDumperVertexProgram.Builder - Class in org.apache.tinkerpop.gremlin.process.computer.bulkdumping
 
BulkDumperVertexProgramTest - Class in org.apache.tinkerpop.gremlin.process.computer.bulkdumping
 
BulkDumperVertexProgramTest() - Constructor for class org.apache.tinkerpop.gremlin.process.computer.bulkdumping.BulkDumperVertexProgramTest
 
BulkLoader - Interface in org.apache.tinkerpop.gremlin.process.computer.bulkloading
 
bulkLoader(String) - Method in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoaderVertexProgram.Builder
Sets the class name of the BulkLoader implementation to be used.
bulkLoader(Class<? extends BulkLoader>) - Method in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoaderVertexProgram.Builder
Sets the class of the BulkLoader implementation to be used.
BulkLoaderVertexProgram - Class in org.apache.tinkerpop.gremlin.process.computer.bulkloading
 
BulkLoaderVertexProgram.Builder - Class in org.apache.tinkerpop.gremlin.process.computer.bulkloading
 
BulkLoaderVertexProgramTest - Class in org.apache.tinkerpop.gremlin.process.computer.bulkloading
 
BulkLoaderVertexProgramTest() - Constructor for class org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoaderVertexProgramTest
 
BulkSet<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.util
BulkSet is a weighted set (i.e.
BulkSet() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.util.BulkSet
 
BulkSetSupplier<A> - Class in org.apache.tinkerpop.gremlin.util.function
 
bulkSize() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.TraverserSet
 
Bundle(Traversal.Admin<Object, Object>) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchStep.CountMatchAlgorithm.Bundle
 
bundles - Variable in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchStep.CountMatchAlgorithm
 
by() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
by(Traversal<?, ?>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
by(T) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
by(String) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
by(Function<V, Object>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
by(Traversal<?, ?>, Comparator<V>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
by(Comparator<E>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
by(Order) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
by(String, Comparator<V>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
by(Function<U, Object>, Comparator) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
by - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
ByModulating - Interface in org.apache.tinkerpop.gremlin.process.traversal.step
A ByModulating step is able to take GraphTraversal.by() calls.
Bypassing - Interface in org.apache.tinkerpop.gremlin.process.traversal.step
A ByPassing step can be stated (at runtime) to simply enact the identity function.
bypassTraversal - Variable in class org.apache.tinkerpop.gremlin.process.traversal.lambda.AbstractLambdaTraversal
 
Bytecode - Class in org.apache.tinkerpop.gremlin.process.traversal
When a TraversalSource is manipulated and then a Traversal is spawned and mutated, a language agnostic representation of those mutations is recorded in a bytecode instance.
Bytecode() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.Bytecode
 
bytecode - Variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource
 
bytecode - Variable in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversal
 
Bytecode.Binding<V> - Class in org.apache.tinkerpop.gremlin.process.traversal
 
Bytecode.Instruction - Class in org.apache.tinkerpop.gremlin.process.traversal
 
BytecodeHelper - Class in org.apache.tinkerpop.gremlin.process.traversal.util
 
BytecodeSerializer() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoSerializers.BytecodeSerializer
 

C

cache - Static variable in class org.apache.tinkerpop.gremlin.server.op.traversal.TraversalOpProcessor
 
CachedGremlinScriptEngineManager - Class in org.apache.tinkerpop.gremlin.jsr223
An implementation of the GremlinScriptEngineManager that caches the instances of the GremlinScriptEngine instances that are created by it.
CachedGremlinScriptEngineManager() - Constructor for class org.apache.tinkerpop.gremlin.jsr223.CachedGremlinScriptEngineManager
 
CachedGremlinScriptEngineManager(ClassLoader) - Constructor for class org.apache.tinkerpop.gremlin.jsr223.CachedGremlinScriptEngineManager
 
CachedGremlinScriptEngineManagerTest - Class in org.apache.tinkerpop.gremlin.jsr223
 
CachedGremlinScriptEngineManagerTest() - Constructor for class org.apache.tinkerpop.gremlin.jsr223.CachedGremlinScriptEngineManagerTest
 
call(SourceUnit, GeneratorContext, ClassNode) - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.VariableIdentificationCustomizer
Deprecated.
 
callbackCalled - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.step.map.ProfileTest.MockStep
 
CallbackRegistry<E extends Event> - Interface in org.apache.tinkerpop.gremlin.process.traversal.step.util.event
 
callbackResponseHandler - Variable in class org.apache.tinkerpop.gremlin.driver.simple.AbstractClient
 
canNotGetAttachableFromHostGraph(Attachable<?>, Graph) - Static method in class org.apache.tinkerpop.gremlin.structure.util.Attachable.Exceptions
 
canNotGetAttachableFromHostVertex(Attachable<?>, Vertex) - Static method in class org.apache.tinkerpop.gremlin.structure.util.Attachable.Exceptions
 
cap(String, String...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
cap(String, String...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
cap - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
CATEGORY - Static variable in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTokens
 
ChainedComparator<S,C extends Comparable> - Class in org.apache.tinkerpop.gremlin.util.function
 
ChainedComparator(boolean, List<<any>>) - Constructor for class org.apache.tinkerpop.gremlin.util.function.ChainedComparator
 
channelActive(ChannelHandlerContext) - Method in class org.apache.tinkerpop.gremlin.driver.handler.WebSocketClientHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.tinkerpop.gremlin.driver.handler.WebSocketClientHandler
 
Channelizer - Interface in org.apache.tinkerpop.gremlin.driver
Client-side channel initializer interface.
channelizer(String) - Method in class org.apache.tinkerpop.gremlin.driver.Cluster.Builder
Specify the Channelizer implementation to use on the client when creating a Connection.
channelizer(Class) - Method in class org.apache.tinkerpop.gremlin.driver.Cluster.Builder
Specify the Channelizer implementation to use on the client when creating a Connection.
Channelizer - Interface in org.apache.tinkerpop.gremlin.server
An interface that makes it possible to plugin different Netty pipelines to Gremlin Server, enabling the use of different protocols, mapper security and other such functions.
channelizer - Variable in class org.apache.tinkerpop.gremlin.server.Settings
The full class name of the Channelizer to use in Gremlin Server.
Channelizer.AbstractChannelizer - Class in org.apache.tinkerpop.gremlin.driver
Base implementation of the client side Channelizer.
Channelizer.NioChannelizer - Class in org.apache.tinkerpop.gremlin.driver
NIO Channelizer implementation.
Channelizer.WebSocketChannelizer - Class in org.apache.tinkerpop.gremlin.driver
WebSocket Channelizer implementation.
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.tinkerpop.gremlin.server.handler.HttpBasicAuthenticationHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.tinkerpop.gremlin.server.handler.HttpGremlinEndpointHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.tinkerpop.gremlin.server.handler.SaslAuthenticationHandler
 
channelRead0(ChannelHandlerContext, Object) - Method in class org.apache.tinkerpop.gremlin.driver.handler.WebSocketClientHandler
 
channelRead0(ChannelHandlerContext, <any>) - Method in class org.apache.tinkerpop.gremlin.server.handler.OpExecutorHandler
 
checkEdgeLegality(Direction, String) - Method in class org.apache.tinkerpop.gremlin.process.computer.GraphFilter
Get the legality of a particular edge direction and label.
checkEdgeLegality(Direction) - Method in class org.apache.tinkerpop.gremlin.process.computer.GraphFilter
Get the legality of a particular edge direction.
checkInputSpecs(Configuration) - Method in class org.apache.tinkerpop.gremlin.giraph.structure.io.GiraphVertexInputFormat
 
checkKeyValue(String, Object) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerMemory
 
checkMap(Map<A, B>, Map<A, B>) - Static method in class org.apache.tinkerpop.gremlin.process.AbstractGremlinProcessTest
 
checkOrderedResults(List<T>, Traversal<?, T>) - Static method in class org.apache.tinkerpop.gremlin.process.AbstractGremlinProcessTest
 
checkOutputSpecs(JobContext) - Method in class org.apache.tinkerpop.gremlin.giraph.structure.io.GiraphVertexOutputFormat
 
checkResults(List<T>, Traversal<?, T>) - Static method in class org.apache.tinkerpop.gremlin.process.AbstractGremlinProcessTest
 
checkResults(Map<T, Long>, Traversal<?, T>) - Static method in class org.apache.tinkerpop.gremlin.process.AbstractGremlinProcessTest
 
checkSideEffects(TraversalSideEffects, Object...) - Static method in class org.apache.tinkerpop.gremlin.process.AbstractGremlinProcessTest
 
choose(Predicate<A>, Traversal<?, B>, Traversal<?, B>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
choose(Predicate<A>, Traversal<?, B>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
choose(Function<A, M>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
choose(Traversal<?, M>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
choose(Traversal<?, M>, Traversal<?, B>, Traversal<?, B>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
choose(Traversal<?, M>, Traversal<?, B>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
choose(Traversal<?, M>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
choose(Traversal<?, ?>, Traversal<?, E2>, Traversal<?, E2>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
choose(Traversal<?, ?>, Traversal<?, E2>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
choose(Function<E, M>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
choose(Predicate<E>, Traversal<?, E2>, Traversal<?, E2>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
choose(Predicate<E>, Traversal<?, E2>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
choose - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
chooseConnection(RequestMessage) - Method in class org.apache.tinkerpop.gremlin.driver.Client
Chooses a Connection to write the message to.
chooseConnection(RequestMessage) - Method in class org.apache.tinkerpop.gremlin.driver.Client.ClusteredClient
Uses a LoadBalancingStrategy to choose the best Host and then selects the best connection from that host's connection pool.
chooseConnection(RequestMessage) - Method in class org.apache.tinkerpop.gremlin.driver.Client.ReboundClusteredClient
Deprecated.
Delegates to the underlying Client.ClusteredClient.
chooseConnection(RequestMessage) - Method in class org.apache.tinkerpop.gremlin.driver.Client.SessionedClient
Since the session is bound to a single host, simply borrow a connection from that pool.
ChooseStep<S,E,M> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.branch
A step which offers a choice of two or more Traversals to take.
ChooseStep(Traversal.Admin, Traversal.Admin<S, M>) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.branch.ChooseStep
 
ChooseStep(Traversal.Admin, Traversal.Admin<S, ?>, Traversal.Admin<S, E>, Traversal.Admin<S, E>) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.branch.ChooseStep
 
ChooseTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.branch
 
ChooseTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.branch.ChooseTest
 
ChooseTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.branch
 
CLASS - Static variable in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTokens
 
ClassFilterStep<S,T> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
ClassFilterStep(Traversal.Admin, Class<T>, boolean) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.ClassFilterStep
 
classicRecommendation() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.ComplexTest
 
classImports(Class<?>...) - Method in class org.apache.tinkerpop.gremlin.jsr223.ImportGremlinPlugin.Builder
 
classImports(Collection<String>) - Method in class org.apache.tinkerpop.gremlin.jsr223.ImportGremlinPlugin.Builder
 
className - Variable in class org.apache.tinkerpop.gremlin.server.Settings.AuthenticationSettings
The fully qualified class name of the Authenticator implementation.
className - Variable in class org.apache.tinkerpop.gremlin.server.Settings.ProcessorSettings
The fully qualified class name of an OpProcessor implementation.
className - Variable in class org.apache.tinkerpop.gremlin.server.Settings.SerializerSettings
The fully qualified class name of the MessageSerializer implementation.
classResolver(Supplier<ClassResolver>) - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoMapper.Builder
Provides a custom Kryo ClassResolver to be supplied to a Kryo instance.
classToNameId - Variable in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoClassResolver
 
classToRegistration - Variable in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoClassResolver
 
cleanParameters(String) - Method in class org.apache.tinkerpop.gremlin.AbstractGraphProvider
 
cleanPathSegment(String) - Static method in class org.apache.tinkerpop.gremlin.TestHelper
Removes characters that aren't acceptable in a file path (mostly for windows).
cleanup(<any>.Context) - Method in class org.apache.tinkerpop.gremlin.hadoop.process.computer.HadoopCombine
 
cleanup(<any>.Context) - Method in class org.apache.tinkerpop.gremlin.hadoop.process.computer.HadoopMap
 
cleanup(<any>.Context) - Method in class org.apache.tinkerpop.gremlin.hadoop.process.computer.HadoopReduce
 
cleanup() - Method in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoaderVertexProgramTest
 
clear(Configuration) - Method in class org.apache.tinkerpop.gremlin.GraphManager.ManagedGraphProvider
 
clear(Graph, Configuration) - Method in class org.apache.tinkerpop.gremlin.GraphManager.ManagedGraphProvider
 
clear(Configuration) - Method in interface org.apache.tinkerpop.gremlin.GraphProvider
If possible (usually with persisted graph) clear the space on disk given the configuration that would be used to construct the graph.
clear(Graph, Configuration) - Method in interface org.apache.tinkerpop.gremlin.GraphProvider
Clears a Graph of all data and settings.
clear() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.Bindings
 
clear() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.BulkSet
 
clear() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ExpandableStepIterator
 
clear() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.TraverserSet
 
clear() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
 
clear() - Method in class org.apache.tinkerpop.gremlin.util.iterator.MultiIterator
 
clearCallbacks() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.util.event.CallbackRegistry
 
clearCallbacks() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.event.ListCallbackRegistry
 
clearHostOptions() - Method in class org.apache.tinkerpop.gremlin.server.util.ServerGremlinExecutor
 
clearIds() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GraphStep
 
clearPropertyDirect(String) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopConfiguration
 
clearTransactionListeners() - Method in interface org.apache.tinkerpop.gremlin.structure.Transaction
Removes all transaction listeners.
clearTransactionListeners() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractThreadedTransaction
 
clearTransactionListeners() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractThreadLocalTransaction
 
clearVariables() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.VariableIdentificationCustomizer
Deprecated.
 
Client - Class in org.apache.tinkerpop.gremlin.driver
A Client is constructed from a Cluster and represents a way to send messages to Gremlin Server.
Client.AliasClusteredClient - Class in org.apache.tinkerpop.gremlin.driver
Uses a Client.ClusteredClient that rebinds requests to a specified Graph or TraversalSource instances on the server-side.
Client.ClusteredClient - Class in org.apache.tinkerpop.gremlin.driver
A Client implementation that does not operate in a session.
Client.ReboundClusteredClient - Class in org.apache.tinkerpop.gremlin.driver
Deprecated.
As of release 3.1.1-incubating, replaced by Client.AliasClusteredClient.
Client.SessionedClient - Class in org.apache.tinkerpop.gremlin.driver
A Client implementation that operates in the context of a session.
Client.SessionSettings - Class in org.apache.tinkerpop.gremlin.driver
Settings for a Client that involve a session.
Client.SessionSettings.Builder - Class in org.apache.tinkerpop.gremlin.driver
 
Client.Settings - Class in org.apache.tinkerpop.gremlin.driver
Settings given to Cluster.connect(Client.Settings) that configures how a Client will behave.
Client.Settings.Builder - Class in org.apache.tinkerpop.gremlin.driver
 
clock(Runnable) - Static method in class org.apache.tinkerpop.gremlin.util.TimeUtil
 
clock(int, Runnable) - Static method in class org.apache.tinkerpop.gremlin.util.TimeUtil
 
clockWithResult(Supplier<S>) - Static method in class org.apache.tinkerpop.gremlin.util.TimeUtil
 
clockWithResult(int, Supplier<S>) - Static method in class org.apache.tinkerpop.gremlin.util.TimeUtil
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.bulkdumping.BulkDumperVertexProgram
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoaderVertexProgram
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.Computer
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputerTest.VertexProgramL
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputerTest.VertexProgramM
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.GraphFilter
 
clone() - Method in interface org.apache.tinkerpop.gremlin.process.computer.MapReduce
When multiple workers on a single machine need MapReduce instances, it is possible to use clone.
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.MemoryComputeKey
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.ranking.pagerank.PageRankVertexProgram
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.MemoryTraversalSideEffects
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.step.map.ComputerResultStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.step.map.PageRankVertexProgramStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.step.map.PeerPressureVertexProgramStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.step.map.TraversalVertexProgramStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.TraversalVertexProgram
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.util.StaticMapReduce
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.computer.util.StaticVertexProgram
 
clone() - Method in interface org.apache.tinkerpop.gremlin.process.computer.VertexProgram
When multiple workers on a single machine need VertexProgram instances, it is possible to use clone.
clone() - Method in class org.apache.tinkerpop.gremlin.process.remote.traversal.AbstractRemoteTraversal
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.remote.traversal.AbstractRemoteTraversalSideEffects
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.Bytecode
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.DefaultGraphTraversal
 
clone() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Admin
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.lambda.AbstractLambdaTraversal
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.lambda.TrueTraversal
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.P
 
clone() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Path
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.BranchStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.LocalStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.RepeatStep
 
clone() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Step
Cloning is used to duplicate steps for the purpose of traversal optimization and OLTP replication.
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.ConnectiveStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.DedupGlobalStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.HasStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.IsStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.NotStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.RangeGlobalStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.SampleGlobalStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.TailGlobalStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.TimeLimitStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.TraversalFilterStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.WherePredicateStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.filter.WhereTraversalStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddEdgeStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddVertexStartStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.AddVertexStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.CoalesceStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GroupCountStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GroupStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GroupStepV3d0
Deprecated.
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.NoOpBarrierStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.OrderGlobalStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.OrderLocalStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.PathStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.ProgramTest.TestProgram
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.ProjectStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.PropertyMapStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.SelectOneStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.SelectStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.TraversalFlatMapStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.TraversalMapStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.TreeStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.AddPropertyStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.AggregateStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.GroupCountSideEffectStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.GroupSideEffectStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.GroupSideEffectStepV3d0
Deprecated.
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.InjectStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.SackValueStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.SideEffectCapStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.StartStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.StoreStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.SubgraphStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.TraversalSideEffectStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.TreeSideEffectStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.AbstractStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.CollectingBarrierStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ComputerAwareStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.EmptyPath
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.EmptyStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.HasContainer
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ImmutablePath
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.MutablePath
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.Parameters
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ProfileStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ReducingBarrierStep
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.SupplyingBarrierStep
 
clone() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traversal.Admin
Cloning is used to duplicate the traversal typically in OLAP environments.
clone() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalSideEffects
Cloning is used to duplicate the sideEffects typically in distributed execution environments.
clone() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalSource
The clone-method should be used to create immutable traversal sources with each call to a configuration "withXXX"-method.
clone() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategies
 
clone() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traverser
Traverser cloning is important when splitting a traverser at a bifurcation point in a traversal.
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.ProjectedTraverser
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.AbstractTraverser
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.EmptyTraverser
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.AndP
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.ConnectiveP
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversal
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversalSideEffects
Cloning is used to duplicate the sideEffects typically in distributed execution environments.
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversalStrategies
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversal
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversalSideEffects
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.EmptyTraversalStrategies
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.MutableMetrics
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.OrP
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.PureTraversal
 
clone() - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalRing
 
clone() - Method in class org.apache.tinkerpop.gremlin.util.function.ChainedComparator
 
clone() - Method in interface org.apache.tinkerpop.gremlin.util.function.TraversableLambda
 
cloneObject(V) - Static method in class org.apache.tinkerpop.gremlin.util.Serializer
 
cloneRegistrations() - Method in enum org.apache.tinkerpop.gremlin.structure.io.gryo.GryoVersion
 
close(Channel) - Method in class org.apache.tinkerpop.gremlin.driver.Channelizer.AbstractChannelizer
 
close(Channel) - Method in interface org.apache.tinkerpop.gremlin.driver.Channelizer
Called on Connection.close() to perform an Channelizer specific functions.
close(Channel) - Method in class org.apache.tinkerpop.gremlin.driver.Channelizer.WebSocketChannelizer
Sends a CloseWebSocketFrame to the server for the specified channel.
close() - Method in class org.apache.tinkerpop.gremlin.driver.Client
Closes the client by making a synchronous call to Client.closeAsync().
close() - Method in class org.apache.tinkerpop.gremlin.driver.Cluster
 
close() - Method in class org.apache.tinkerpop.gremlin.driver.remote.DriverRemoteConnection
 
close() - Method in class org.apache.tinkerpop.gremlin.driver.remote.DriverRemoteTraversal
Releases server-side resources related to this traversal (i.e.
close() - Method in class org.apache.tinkerpop.gremlin.driver.remote.DriverRemoteTraversalSideEffects
 
close() - Method in class org.apache.tinkerpop.gremlin.driver.simple.NioClient
 
close() - Method in class org.apache.tinkerpop.gremlin.driver.simple.WebSocketClient
 
close() - Method in class org.apache.tinkerpop.gremlin.giraph.structure.io.GiraphVertexReader
 
close(TaskAttemptContext) - Method in class org.apache.tinkerpop.gremlin.giraph.structure.io.GiraphVertexWriter
 
close() - Method in class org.apache.tinkerpop.gremlin.GraphManager.ManagedGraphProvider
 
close() - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor

Executors are only closed if they were not supplied externally in the GremlinExecutor.Builder

close() - Method in class org.apache.tinkerpop.gremlin.groovy.engine.ScriptEngines
Deprecated.
Iterate through all the ScriptEngine implementations and if they implement AutoCloseable then call the AutoCloseable.close() method.
close() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GremlinGroovyScriptEngine
Deprecated.
As of release 3.2.4, not replaced as this class will not implement AutoCloseable in the future.
close() - Method in class org.apache.tinkerpop.gremlin.hadoop.groovy.plugin.HadoopRemoteAcceptor
Deprecated.
 
close() - Method in class org.apache.tinkerpop.gremlin.hadoop.jsr223.HadoopRemoteAcceptor
 
close() - Method in class org.apache.tinkerpop.gremlin.hadoop.process.computer.GraphFilterRecordReader
 
close() - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph
 
close() - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.graphson.GraphSONRecordReader
 
close(TaskAttemptContext) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.graphson.GraphSONRecordWriter
 
close() - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.gryo.GryoRecordReader
 
close(TaskAttemptContext) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.gryo.GryoRecordWriter
 
close() - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.HadoopElementIterator
 
close() - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.script.ScriptRecordReader
 
close(TaskAttemptContext) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.script.ScriptRecordWriter
 
close() - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
This implementation of close will also close the current transaction on the thread, but it is up to the caller to deal with dangling transactions in other threads prior to calling this method.
close() - Method in interface org.apache.tinkerpop.gremlin.process.computer.ComputerResult
Close the computed GraphComputer result.
close() - Method in class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph
 
close() - Method in class org.apache.tinkerpop.gremlin.process.computer.util.DefaultComputerResult
 
close() - Method in class org.apache.tinkerpop.gremlin.process.remote.RemoteGraph
Deprecated.
Closes the underlying RemoteConnection.
close() - Method in interface org.apache.tinkerpop.gremlin.process.remote.traversal.RemoteTraversalSideEffects
If the "remote" that actually executed the traversal maintained resources that can be released, when the user is done with the side-effects, then this method can be used to trigger that release.
close() - Method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource
 
close() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.EdgeVertexStep
 
close() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GraphStep
Attempts to close an underlying iterator if it is of type CloseableIterator.
close() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.PropertiesStep
 
close() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.VertexStep
 
close() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.TraversalParent
 
close() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traversal
Releases resources opened in any steps that implement AutoCloseable.
close() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalSideEffects
Invalidate the side effect cache for traversal.
close() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalSource
 
close() - Method in class org.apache.tinkerpop.gremlin.server.op.control.ControlOpProcessor
Deprecated.
 
close() - Method in class org.apache.tinkerpop.gremlin.server.op.session.SessionOpProcessor
 
close() - Method in class org.apache.tinkerpop.gremlin.server.op.standard.StandardOpProcessor
 
close() - Method in class org.apache.tinkerpop.gremlin.server.op.traversal.TraversalOpProcessor
 
close() - Method in class org.apache.tinkerpop.gremlin.spark.structure.io.gryo.GryoSerializationStream
 
close() - Static method in class org.apache.tinkerpop.gremlin.spark.structure.Spark
 
close() - Method in interface org.apache.tinkerpop.gremlin.structure.Graph
Closing a Graph is equivalent to "shutdown" and implies that no futher operations can be executed on the instance.
close() - Method in interface org.apache.tinkerpop.gremlin.structure.Transaction
Closes the transaction where the default close behavior defined by {Transaction.onClose(Consumer)} will be executed.
close() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractTransaction
Closes the transaction where the default close behavior defined by {Transaction.onClose(Consumer)} will be executed.
close() - Method in interface org.apache.tinkerpop.gremlin.structure.util.CloseableIterator
 
close() - Method in class org.apache.tinkerpop.gremlin.structure.util.empty.EmptyGraph
 
close() - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph
 
close() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerWorkerPool
 
close() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
 
CloseableIterator<T> - Interface in org.apache.tinkerpop.gremlin.structure.util
An extension of Iterator that implements Closeable which allows a Graph implementation that hold open resources to provide the user the option to release those resources.
closeAsync() - Method in class org.apache.tinkerpop.gremlin.driver.Client
Asynchronous close of the Client.
closeAsync() - Method in class org.apache.tinkerpop.gremlin.driver.Client.ClusteredClient
Closes all the connection pools on all hosts.
closeAsync() - Method in class org.apache.tinkerpop.gremlin.driver.Client.ReboundClusteredClient
Deprecated.
Prevents messages from being sent from this Client.
closeAsync() - Method in class org.apache.tinkerpop.gremlin.driver.Client.SessionedClient
Close the bound ConnectionPool.
closeAsync() - Method in class org.apache.tinkerpop.gremlin.driver.Cluster
 
closeAsync() - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor
Executors are only closed if they were not supplied externally in the GremlinExecutor.Builder
closeConsumerInternal - Variable in class org.apache.tinkerpop.gremlin.structure.util.AbstractThreadLocalTransaction
 
closeIterator() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.FlatMapStep
 
closeIterator(Iterator<T>) - Static method in interface org.apache.tinkerpop.gremlin.structure.util.CloseableIterator
 
closeNow() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerWorkerPool
 
cluster - Variable in class org.apache.tinkerpop.gremlin.driver.Channelizer.AbstractChannelizer
 
cluster - Variable in class org.apache.tinkerpop.gremlin.driver.Client
 
Cluster - Class in org.apache.tinkerpop.gremlin.driver
A connection to a set of one or more Gremlin Server instances.
CLUSTER - Static variable in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.PeerPressureVertexProgram
 
Cluster.Builder - Class in org.apache.tinkerpop.gremlin.driver
 
CLUSTER_COUNT_MEMORY_KEY - Static variable in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.ClusterCountMapReduce
 
CLUSTER_POPULATION_MEMORY_KEY - Static variable in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.ClusterPopulationMapReduce
 
ClusterCountMapReduce - Class in org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure
 
ClusterCountMapReduce.Builder - Class in org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure
 
ClusterPopulationMapReduce - Class in org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure
 
ClusterPopulationMapReduce.Builder - Class in org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure
 
coalesce(Traversal<?, B>...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
coalesce(Traversal<?, E2>...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
coalesce - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
CoalesceStep<S,E> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
CoalesceStep(Traversal.Admin, Traversal.Admin<S, E>...) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.CoalesceStep
 
CoalesceTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
CoalesceTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.CoalesceTest
 
CoalesceTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
code(ResponseStatusCode) - Method in class org.apache.tinkerpop.gremlin.driver.message.ResponseMessage.Builder
 
coin(double) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
coin(double) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Filter the E object given a biased coin toss.
coin - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
CoinStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
CoinStep(Traversal.Admin, double) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.CoinStep
 
CoinTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
CoinTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.CoinTest
 
CoinTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
COLLECTED_BOUND_VARS_MAP_VARNAME - Static variable in class org.apache.tinkerpop.gremlin.groovy.jsr223.GremlinGroovyScriptEngine
Name of variable that holds local variables to be globally bound if "interpreter mode" is enabled with InterpreterModeCustomizerProvider.
CollectingBarrierStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.util
 
CollectingBarrierStep(Traversal.Admin) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.util.CollectingBarrierStep
 
CollectingBarrierStep(Traversal.Admin, int) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.util.CollectingBarrierStep
 
collectMap(Iterator<S>, Function<S, K>) - Static method in class org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils
 
collectMap(Iterator<S>, Function<S, K>, Function<S, V>) - Static method in class org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils
 
Column - Enum in org.apache.tinkerpop.gremlin.structure
Column references a particular type of column in a complex data structure such as a Map, a Map.Entry, or a Path.
ColumnTraversal - Class in org.apache.tinkerpop.gremlin.process.traversal.lambda
 
ColumnTraversal(Column) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.lambda.ColumnTraversal
 
combine(ObjectWritable, ObjectWritable, ObjectWritable) - Method in class org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphMessageCombiner
 
combine(Serializable, Iterator<Long>, MapReduce.ReduceEmitter<Serializable, Long>) - Method in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.ClusterPopulationMapReduce
 
combine(MK, Iterator<MV>, MapReduce.ReduceEmitter<RK, RV>) - Method in interface org.apache.tinkerpop.gremlin.process.computer.MapReduce
The combine() method is logically executed at all "machines" in parallel.
combine(M, M) - Method in interface org.apache.tinkerpop.gremlin.process.computer.MessageCombiner
Combine two messages and return a message containing the combination.
combine(Double, Double) - Method in class org.apache.tinkerpop.gremlin.process.computer.ranking.pagerank.PageRankMessageCombiner
 
combine(TraverserSet<Object>, TraverserSet<Object>) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.TraversalVertexProgramMessageCombiner
 
CombineIterator<K,V,OK,OV> - Class in org.apache.tinkerpop.gremlin.spark.process.computer
 
CombineIterator(MapReduce<K, V, OK, OV, ?>, Iterator<<any>>) - Constructor for class org.apache.tinkerpop.gremlin.spark.process.computer.CombineIterator
 
commit(Set<String>) - Method in class org.apache.tinkerpop.gremlin.server.GraphManager
Selectively commit transactions on the specified graphs or the graphs of traversal sources.
commit() - Method in interface org.apache.tinkerpop.gremlin.structure.Transaction
Commits a transaction.
commit() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractTransaction
Commits a transaction.
commitAll() - Method in class org.apache.tinkerpop.gremlin.server.GraphManager
Commit transactions across all Graph objects.
CommonFileInputFormat - Class in org.apache.tinkerpop.gremlin.hadoop.structure.io
 
CommonFileInputFormat() - Constructor for class org.apache.tinkerpop.gremlin.hadoop.structure.io.CommonFileInputFormat
 
CommonFileOutputFormat - Class in org.apache.tinkerpop.gremlin.hadoop.structure.io
 
CommonFileOutputFormat() - Constructor for class org.apache.tinkerpop.gremlin.hadoop.structure.io.CommonFileOutputFormat
 
communityDistribution(Distribution) - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGenerator.Builder
Sets the distribution to be used to generate the sizes of communities.
communityDistribution - Variable in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGeneratorTest.DifferentDistributionsTest
 
CommunityGenerator - Class in org.apache.tinkerpop.gremlin.algorithm.generator
Generates a synthetic network with a community structure, that is, several densely connected sub-networks that are loosely connected with one another.
CommunityGenerator.Builder - Class in org.apache.tinkerpop.gremlin.algorithm.generator
 
CommunityGeneratorTest - Class in org.apache.tinkerpop.gremlin.algorithm.generator
 
CommunityGeneratorTest() - Constructor for class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGeneratorTest
 
CommunityGeneratorTest.DifferentDistributionsTest - Class in org.apache.tinkerpop.gremlin.algorithm.generator
 
CommunityGeneratorTest.ProcessorTest - Class in org.apache.tinkerpop.gremlin.algorithm.generator
 
comparator - Variable in class org.apache.tinkerpop.gremlin.hadoop.structure.io.ObjectWritableComparator
 
comparator(String, String) - Static method in interface org.apache.tinkerpop.gremlin.util.function.Lambda
 
comparator(String) - Static method in interface org.apache.tinkerpop.gremlin.util.function.Lambda
 
ComparatorHolder<S,C extends Comparable> - Interface in org.apache.tinkerpop.gremlin.process.traversal.step
 
Comparators - Class in org.apache.tinkerpop.gremlin.structure.util
A collection of commonly used Comparator instances.
compare(A, A) - Method in class org.apache.tinkerpop.gremlin.groovy.function.GComparator
Deprecated.
 
compare(ObjectWritable, ObjectWritable) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.ObjectWritableComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.ObjectWritableComparator
 
Compare - Enum in org.apache.tinkerpop.gremlin.process.traversal
Compare is a BiPredicate that determines whether the first argument is ==, !=, >, >=, <, <= to the second argument.
compare(Object, Object) - Method in enum org.apache.tinkerpop.gremlin.process.traversal.Order
compare(Element, Element) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ElementFunctionComparator
 
compare(Element, Element) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ElementValueComparator
 
compare(A, A) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.FunctionComparator
 
compare(S, S) - Method in class org.apache.tinkerpop.gremlin.util.function.ChainedComparator
 
compare(A, A) - Method in class org.apache.tinkerpop.gremlin.util.function.Lambda.TwoArgLambda
 
compare(C, C) - Method in class org.apache.tinkerpop.gremlin.util.function.MultiComparator
 
compareTo(ObjectWritable) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.ObjectWritable
 
compareTo(MapReduce.NullObject) - Method in class org.apache.tinkerpop.gremlin.process.computer.MapReduce.NullObject
 
compareTo(Number) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MeanGlobalStep.MeanNumber
 
compareTo(Class<? extends TraversalStrategy>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategy
 
compareTo(Class<? extends TraversalStrategy>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategy.DecorationStrategy
 
compareTo(Class<? extends TraversalStrategy>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategy.FinalizationStrategy
 
compareTo(Class<? extends TraversalStrategy>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategy.OptimizationStrategy
 
compareTo(Class<? extends TraversalStrategy>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategy.ProviderOptimizationStrategy
 
compareTo(Class<? extends TraversalStrategy>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalStrategy.VerificationStrategy
 
compareTo(Traverser<T>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traverser
If the underlying object of the traverser is comparable, compare it with the other traverser.
compilation(GroovyCompilerGremlinPlugin.Compilation) - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GroovyCompilerGremlinPlugin.Builder
 
compilation(String) - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GroovyCompilerGremlinPlugin.Builder
 
compile(String) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor
Attempts to compile a script and cache it in the default ScriptEngine.
compile(String, Optional<String>) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor
Attempts to compile a script and cache it in the request ScriptEngine.
compile(String, String) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.ScriptEngines
Deprecated.
Compiles a script without executing it.
compile(Reader, String) - Method in class org.apache.tinkerpop.gremlin.groovy.engine.ScriptEngines
Deprecated.
Compiles a script without executing it.
compile(String) - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GremlinGroovyScriptEngine
compile(Reader) - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GremlinGroovyScriptEngine
COMPILE_OPTIONS - Static variable in class org.apache.tinkerpop.gremlin.groovy.jsr223.GremlinGroovyScriptEngine
 
COMPILE_OPTIONS_VAR_TYPES - Static variable in class org.apache.tinkerpop.gremlin.groovy.jsr223.GremlinGroovyScriptEngine
An "internal" key for sandboxing the script engine - technically not for public use.
compilerConfigurationOptions(Map<String, Object>) - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GroovyCompilerGremlinPlugin.Builder
 
CompilerCustomizerProvider - Interface in org.apache.tinkerpop.gremlin.groovy
Provides a way to plugin Groovy CompilationCustomizer implementations to the GremlinGroovyScriptEngine.
CompileStaticCustomizerProvider - Class in org.apache.tinkerpop.gremlin.groovy.jsr223.customizer
Deprecated.
As of release 3.2.4, not replaced by a public class.
CompileStaticCustomizerProvider() - Constructor for class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.CompileStaticCustomizerProvider
Deprecated.
 
CompileStaticCustomizerProvider(String) - Constructor for class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.CompileStaticCustomizerProvider
Deprecated.
 
complete() - Method in class org.apache.tinkerpop.gremlin.spark.process.computer.SparkMemory
 
complete() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerGraphComputerView
 
complete(MapReduce<K, V, ?, ?, ?>) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerMapEmitter
 
complete() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerMemory
 
complete(MapReduce<?, ?, OK, OV, ?>) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerReduceEmitter
 
complete() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerWorkerMemory
 
completeSubRound() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerMemory
 
ComplexTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step
 
ComplexTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.ComplexTest
 
ComplexTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step
 
compute(<any>, Iterable<ObjectWritable>) - Method in class org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphComputation
 
compute() - Method in class org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphMemory
 
compute(Class<C>) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph
 
compute() - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph
 
compute(Class<C>) - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
 
compute() - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
 
compute() - Static method in class org.apache.tinkerpop.gremlin.process.computer.Computer
 
compute(Class<? extends GraphComputer>) - Static method in class org.apache.tinkerpop.gremlin.process.computer.Computer
 
compute(Class<C>) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph
 
compute() - Method in class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph
 
compute(Class<C>) - Method in class org.apache.tinkerpop.gremlin.process.remote.RemoteGraph
Deprecated.
 
compute() - Method in class org.apache.tinkerpop.gremlin.process.remote.RemoteGraph
Deprecated.
 
compute(Graph, TraversalSource, String, String, Object...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalScriptHelper
Deprecated.
compute(String, GraphTraversalSource, Object...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalScriptHelper
Deprecated.
compute(Class<C>) - Method in interface org.apache.tinkerpop.gremlin.structure.Graph
Declare the GraphComputer to use for OLAP operations on the graph.
compute() - Method in interface org.apache.tinkerpop.gremlin.structure.Graph
Generate a GraphComputer using the default engine of the underlying graph system.
compute(Class<C>) - Method in class org.apache.tinkerpop.gremlin.structure.util.empty.EmptyGraph
 
compute() - Method in class org.apache.tinkerpop.gremlin.structure.util.empty.EmptyGraph
 
compute(Class<C>) - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph
 
compute() - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph
 
compute(Class<C>) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
 
compute() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
 
computeKeys - Variable in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerGraphComputerView
 
Computer - Class in org.apache.tinkerpop.gremlin.process.computer
 
computer - Variable in class org.apache.tinkerpop.gremlin.process.computer.traversal.step.map.VertexProgramStep
 
computer(Computer) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.decoration.VertexProgramStrategy.Builder
 
computer() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
computer(Class<? extends GraphComputer>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
computer(Class<? extends GraphComputer>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.engine.ComputerTraversalEngine.Builder
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
ComputerAdjacentVertex(Vertex) - Constructor for class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph.ComputerAdjacentVertex
 
computerAlgorithm() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.BranchStep
 
computerAlgorithm() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.RepeatStep
 
computerAlgorithm() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.RepeatStep.RepeatEndStep
 
computerAlgorithm() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchStep
 
computerAlgorithm() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ComputerAwareStep
 
ComputerAwareStep<S,E> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.util
 
ComputerAwareStep(Traversal.Admin) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.util.ComputerAwareStep
 
ComputerAwareStep.EndStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.util
 
ComputerEdge(Edge) - Constructor for class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph.ComputerEdge
 
ComputerElement(Element) - Constructor for class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph.ComputerElement
 
computeResultString(ComputerResult) - Static method in class org.apache.tinkerpop.gremlin.structure.util.StringFactory
 
ComputerGraph - Class in org.apache.tinkerpop.gremlin.process.computer.util
 
ComputerGraph.ComputerAdjacentVertex - Class in org.apache.tinkerpop.gremlin.process.computer.util
 
ComputerGraph.ComputerEdge - Class in org.apache.tinkerpop.gremlin.process.computer.util
 
ComputerGraph.ComputerElement - Class in org.apache.tinkerpop.gremlin.process.computer.util
 
ComputerGraph.ComputerProperty<V> - Class in org.apache.tinkerpop.gremlin.process.computer.util
 
ComputerGraph.ComputerVertex - Class in org.apache.tinkerpop.gremlin.process.computer.util
 
ComputerGraph.ComputerVertexProperty<V> - Class in org.apache.tinkerpop.gremlin.process.computer.util
 
computerHasAlreadyBeenSubmittedAVertexProgram() - Static method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputer.Exceptions
 
computerHasNoVertexProgramNorMapReducers() - Static method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputer.Exceptions
 
ComputerProperty(Property<V>) - Constructor for class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph.ComputerProperty
 
computerRequiresMoreWorkersThanSupported(int, int) - Static method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputer.Exceptions
 
ComputerResult - Interface in org.apache.tinkerpop.gremlin.process.computer
The result of the GraphComputer's computation.
ComputerResultStep<S> - Class in org.apache.tinkerpop.gremlin.process.computer.traversal.step.map
 
ComputerResultStep(Traversal.Admin) - Constructor for class org.apache.tinkerpop.gremlin.process.computer.traversal.step.map.ComputerResultStep
 
ComputerSubmissionHelper - Class in org.apache.tinkerpop.gremlin.hadoop.process.computer.util
 
ComputerSubmissionHelper() - Constructor for class org.apache.tinkerpop.gremlin.hadoop.process.computer.util.ComputerSubmissionHelper
 
computerTraversal - Variable in class org.apache.tinkerpop.gremlin.process.computer.traversal.step.map.TraversalVertexProgramStep
 
ComputerTraversalEngine - Class in org.apache.tinkerpop.gremlin.process.traversal.engine
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
ComputerTraversalEngine.Builder - Class in org.apache.tinkerpop.gremlin.process.traversal.engine
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
ComputerVerificationStrategy - Class in org.apache.tinkerpop.gremlin.process.traversal.strategy.verification
 
ComputerVertex(Vertex) - Constructor for class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph.ComputerVertex
 
ComputerVertexProperty(VertexProperty<V>) - Constructor for class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph.ComputerVertexProperty
 
computeStartLabel(List<Traversal.Admin<Object, Object>>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchStep.Helper
 
concat(Iterator<S>...) - Static method in class org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils
 
ConcurrentBindings - Class in org.apache.tinkerpop.gremlin.groovy.engine
Deprecated.
As of release 3.2.2, replaced by ConcurrentBindings.
ConcurrentBindings() - Constructor for class org.apache.tinkerpop.gremlin.groovy.engine.ConcurrentBindings
Deprecated.
 
ConcurrentBindings(Map<String, Object>) - Constructor for class org.apache.tinkerpop.gremlin.groovy.engine.ConcurrentBindings
Deprecated.
 
ConcurrentBindings - Class in org.apache.tinkerpop.gremlin.jsr223
A Bindings that can be accessed concurrently by multiple threads.
ConcurrentBindings() - Constructor for class org.apache.tinkerpop.gremlin.jsr223.ConcurrentBindings
 
ConcurrentBindings(Map<String, Object>) - Constructor for class org.apache.tinkerpop.gremlin.jsr223.ConcurrentBindings
 
config - Variable in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
 
config - Variable in class org.apache.tinkerpop.gremlin.server.Settings.AuthenticationSettings
A Map containing Authenticator specific configurations.
config - Variable in class org.apache.tinkerpop.gremlin.server.Settings.ProcessorSettings
A set of configurations as expected by the OpProcessor.
config - Variable in class org.apache.tinkerpop.gremlin.server.Settings.ScriptEngineSettings
A Map of configuration settings for the ScriptEngine.
config - Variable in class org.apache.tinkerpop.gremlin.server.Settings.SerializerSettings
A Map containing MessageSerializer specific configurations.
CONFIG_CACHE_EXPIRATION_TIME - Static variable in class org.apache.tinkerpop.gremlin.server.op.traversal.TraversalOpProcessor
Configuration setting for how long a cached side-effect will be available before it is evicted from the cache.
CONFIG_CACHE_MAX_SIZE - Static variable in class org.apache.tinkerpop.gremlin.server.op.traversal.TraversalOpProcessor
Configuration setting for the maximum number of entries the cache will have.
CONFIG_CONF - Static variable in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
 
CONFIG_CREDENTIALS_DB - Static variable in class org.apache.tinkerpop.gremlin.server.auth.SimpleAuthenticator
The location of the configuration file that contains the credentials database.
CONFIG_CREDENTIALS_LOCATION - Static variable in class org.apache.tinkerpop.gremlin.server.auth.SimpleAuthenticator
Deprecated.
As of release 3.1.1-incubating, if using TinkerGraph, simply rely on it's "persistence" features.
CONFIG_DEFAULT_VERTEX_PROPERTY_CARDINALITY - Static variable in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
Deprecated.
CONFIG_DIRECTORY - Static variable in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
 
CONFIG_EDGE_ID - Static variable in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
Deprecated.
As of release 3.1.0, replaced by TinkerGraph.GREMLIN_TINKERGRAPH_EDGE_ID_MANAGER
CONFIG_GRAPH_FORMAT - Static variable in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
Deprecated.
As of release 3.1.0, replaced by TinkerGraph.GREMLIN_TINKERGRAPH_GRAPH_FORMAT
CONFIG_GRAPH_LOCATION - Static variable in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
Deprecated.
As of release 3.1.0, replaced by TinkerGraph.GREMLIN_TINKERGRAPH_GRAPH_LOCATION
CONFIG_IO_GRYO_POOL_SIZE - Static variable in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoPool
 
CONFIG_IO_GRYO_POOL_SIZE_DEFAULT - Static variable in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoPool
 
CONFIG_IO_REGISTRY - Static variable in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoPool
 
CONFIG_META_PROPERTIES - Static variable in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
 
CONFIG_MULTI_PROPERTIES - Static variable in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
 
CONFIG_PER_GRAPH_CLOSE_TIMEOUT - Static variable in class org.apache.tinkerpop.gremlin.server.op.session.SessionOpProcessor
Configuration setting for how long to wait in milliseconds for each configured graph to close any open transactions when the session is killed.
CONFIG_SESSION_TIMEOUT - Static variable in class org.apache.tinkerpop.gremlin.server.op.session.SessionOpProcessor
Configuration setting for how long a session will be available before it times out.
CONFIG_VERTEX_ID - Static variable in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
Deprecated.
As of release 3.1.0, replaced by TinkerGraph.GREMLIN_TINKERGRAPH_VERTEX_ID_MANAGER
CONFIG_VERTEX_PROPERTY_ID - Static variable in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
Deprecated.
configuration - Variable in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph
 
configuration() - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph
 
configuration - Variable in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
 
configuration() - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
 
configuration - Variable in class org.apache.tinkerpop.gremlin.process.computer.util.AbstractVertexProgramBuilder
 
configuration() - Method in class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph
 
configuration() - Method in class org.apache.tinkerpop.gremlin.process.remote.RemoteGraph
Deprecated.
 
configuration() - Method in interface org.apache.tinkerpop.gremlin.structure.Graph
Get the org.apache.commons.configuration.Configuration associated with the construction of this graph.
configuration() - Method in class org.apache.tinkerpop.gremlin.structure.util.empty.EmptyGraph
 
configuration() - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph
 
configuration() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
 
ConfigurationCustomizerProvider - Class in org.apache.tinkerpop.gremlin.groovy.jsr223.customizer
Deprecated.
As of release 3.2.4, not replaced by a public class.
ConfigurationCustomizerProvider(Object...) - Constructor for class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.ConfigurationCustomizerProvider
Deprecated.
Creates a new instance using configuration values specified
ConfigurationCustomizerProvider(Map<String, Object>) - Constructor for class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.ConfigurationCustomizerProvider
Deprecated.
Creates a new instance using configuration values specified
ConfigurationEvaluator - Class in org.apache.tinkerpop.gremlin.driver.util
An internal application used to test out ranges of configuration parameters for Gremlin Driver.
ConfigurationEvaluator() - Constructor for class org.apache.tinkerpop.gremlin.driver.util.ConfigurationEvaluator
 
ConfigurationTraversal<S,E> - Class in org.apache.tinkerpop.gremlin.process.computer.util
Deprecated.
As of release 3.2.0, replaced by PureTraversal.
configure(ChannelPipeline) - Method in class org.apache.tinkerpop.gremlin.driver.Channelizer.AbstractChannelizer
 
configure(ChannelPipeline) - Method in class org.apache.tinkerpop.gremlin.driver.Channelizer.NioChannelizer
 
configure(ChannelPipeline) - Method in class org.apache.tinkerpop.gremlin.driver.Channelizer.WebSocketChannelizer
 
configure(Map<String, Object>, Map<String, Graph>) - Method in interface org.apache.tinkerpop.gremlin.driver.MessageSerializer
Configure the serializer with mapper settings as required.
configure(Map<String, Object>, Map<String, Graph>) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV1d0
 
configure(Map<String, Object>, Map<String, Graph>) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV2d0
 
configure(Map<String, Object>, Map<String, Graph>) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractGryoMessageSerializerV1d0
 
configure(String, Object) - Method in class org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphGraphComputer
 
configure(List<String>) - Method in interface org.apache.tinkerpop.gremlin.groovy.plugin.RemoteAcceptor
Deprecated.
Gets called when :remote is used in conjunction with the config option.
configure(List<String>) - Method in class org.apache.tinkerpop.gremlin.hadoop.groovy.plugin.HadoopRemoteAcceptor
Deprecated.
 
configure(List<String>) - Method in class org.apache.tinkerpop.gremlin.hadoop.jsr223.HadoopRemoteAcceptor
 
configure(List<String>) - Method in interface org.apache.tinkerpop.gremlin.jsr223.console.RemoteAcceptor
Gets called when :remote is used in conjunction with the config option.
configure(Configuration) - Method in interface org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoader
Configures the BulkLoader instance.
configure(Configuration) - Method in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.IncrementalBulkLoader
Configures the BulkLoader instance.
configure(Configuration) - Method in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.OneTimeBulkLoader
Configures the BulkLoader instance.
configure(String, Object) - Method in class org.apache.tinkerpop.gremlin.process.computer.Computer
 
configure(Map<String, Object>) - Method in class org.apache.tinkerpop.gremlin.process.computer.Computer
 
configure(String, Object) - Method in interface org.apache.tinkerpop.gremlin.process.computer.GraphComputer
Set an arbitrary configuration key/value for the underlying org.apache.commons.configuration.Configuration in the GraphComputer.
configure(String, Object) - Method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputerTest.BadGraphComputer
 
configure(String, Object) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.decoration.VertexProgramStrategy.Builder
 
configure(Map<String, Object>) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.decoration.VertexProgramStrategy.Builder
 
configure(Object...) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.AbstractVertexProgramBuilder
This method should only be used by the underlying compute engine.
configure(Object...) - Method in interface org.apache.tinkerpop.gremlin.process.computer.VertexProgram.Builder
This method should only be used by the underlying compute engine.
configure(ChannelPipeline) - Method in class org.apache.tinkerpop.gremlin.server.AbstractChannelizer
This method is called from within #initChannel(io.netty.channel.socket.SocketChannel) just after the SSL handler is put in the pipeline.
configure(ChannelPipeline) - Method in class org.apache.tinkerpop.gremlin.server.channel.HttpChannelizer
 
configure(ChannelPipeline) - Method in class org.apache.tinkerpop.gremlin.server.channel.NioChannelizer
 
configure(ChannelPipeline) - Method in class org.apache.tinkerpop.gremlin.server.channel.WebSocketChannelizer
 
configure(String, Object) - Method in class org.apache.tinkerpop.gremlin.spark.process.computer.SparkGraphComputer
 
ConfUtil - Class in org.apache.tinkerpop.gremlin.hadoop.structure.util
 
connect() - Method in class org.apache.tinkerpop.gremlin.driver.Cluster
Creates a Client.ClusteredClient instance to this Cluster, meaning requests will be routed to one or more servers (depending on the cluster configuration), where each request represents the entirety of a transaction.
connect(String) - Method in class org.apache.tinkerpop.gremlin.driver.Cluster
Creates a Client.SessionedClient instance to this Cluster, meaning requests will be routed to a single server (randomly selected from the cluster), where the same bindings will be available on each request.
connect(String, boolean) - Method in class org.apache.tinkerpop.gremlin.driver.Cluster
Creates a Client.SessionedClient instance to this Cluster, meaning requests will be routed to a single server (randomly selected from the cluster), where the same bindings will be available on each request.
connect(Client.Settings) - Method in class org.apache.tinkerpop.gremlin.driver.Cluster
Creates a new Client based on the settings provided.
connect(List<String>) - Method in interface org.apache.tinkerpop.gremlin.groovy.plugin.RemoteAcceptor
Deprecated.
Gets called when :remote is used in conjunction with the "connect" option.
connect(List<String>) - Method in class org.apache.tinkerpop.gremlin.hadoop.groovy.plugin.HadoopRemoteAcceptor
Deprecated.
 
connect(List<String>) - Method in class org.apache.tinkerpop.gremlin.hadoop.jsr223.HadoopRemoteAcceptor
 
connect(List<String>) - Method in interface org.apache.tinkerpop.gremlin.jsr223.console.RemoteAcceptor
Gets called when :remote is used in conjunction with the "connect" option.
connected() - Method in interface org.apache.tinkerpop.gremlin.driver.Channelizer
Called after the channel connects.
connected() - Method in class org.apache.tinkerpop.gremlin.driver.Channelizer.WebSocketChannelizer
 
connection - Variable in class org.apache.tinkerpop.gremlin.driver.Channelizer.AbstractChannelizer
 
connection - Variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource
 
ConnectionException - Exception in org.apache.tinkerpop.gremlin.driver.exception
 
ConnectionException(URI, InetSocketAddress, String) - Constructor for exception org.apache.tinkerpop.gremlin.driver.exception.ConnectionException
 
ConnectionException(URI, String, Throwable) - Constructor for exception org.apache.tinkerpop.gremlin.driver.exception.ConnectionException
 
ConnectionException(URI, InetSocketAddress, String, Throwable) - Constructor for exception org.apache.tinkerpop.gremlin.driver.exception.ConnectionException
 
ConnectiveP<V> - Class in org.apache.tinkerpop.gremlin.process.traversal.util
 
ConnectiveP(List<P<V>>) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.ConnectiveP
 
ConnectiveP(P<V>...) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.ConnectiveP
Deprecated.
ConnectiveStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
ConnectiveStep(Traversal.Admin, Traversal<S, ?>...) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.ConnectiveStep
 
ConnectiveStep.Connective - Enum in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
ConnectiveStrategy - Class in org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration
ConnectiveStrategy rewrites the binary conjunction form of a.and().b into a AndStep of and(a,b) (likewise for OrStep).
ConsoleCustomizer - Interface in org.apache.tinkerpop.gremlin.jsr223.console
 
ConsoleMutationListener - Class in org.apache.tinkerpop.gremlin.process.traversal.step.util.event
An example listener that writes a message to the console for each event that fires from the graph.
ConsoleMutationListener(Graph) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.util.event.ConsoleMutationListener
 
consoleReporter - Variable in class org.apache.tinkerpop.gremlin.server.Settings.ServerMetrics
 
ConsoleReporterMetrics() - Constructor for class org.apache.tinkerpop.gremlin.server.Settings.ConsoleReporterMetrics
 
constant(A) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
constant(E2) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Map any object to a fixed E value.
constant - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
Constants - Class in org.apache.tinkerpop.gremlin.hadoop
 
ConstantStep<S,E> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
ConstantStep(Traversal.Admin, E) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.ConstantStep
 
ConstantSupplier<A> - Class in org.apache.tinkerpop.gremlin.util.function
 
ConstantSupplier(A) - Constructor for class org.apache.tinkerpop.gremlin.util.function.ConstantSupplier
 
ConstantTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
ConstantTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.ConstantTest
 
ConstantTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
ConstantTraversal<S,E> - Class in org.apache.tinkerpop.gremlin.process.traversal.lambda
 
ConstantTraversal(E) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.lambda.ConstantTraversal
 
consume(Iterator<S>, Consumer<S>) - Static method in class org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils
 
consume(Iterable<S>, Consumer<S>) - Static method in class org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils
 
consumer(String, String) - Static method in interface org.apache.tinkerpop.gremlin.util.function.Lambda
 
consumer(String) - Static method in interface org.apache.tinkerpop.gremlin.util.function.Lambda
 
Contains - Enum in org.apache.tinkerpop.gremlin.process.traversal
Contains is a BiPredicate that evaluates whether the first object is contained within (or not within) the second collection object.
contains(Object) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.BulkSet
 
contains(Object) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.Parameters
Checks for existence of key in parameter set.
contains(Object) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.TraverserSet
 
containsEntry(Map<K, Set<V>>, K, V) - Static method in class org.apache.tinkerpop.gremlin.util.tools.MultiMap
 
containsKey(String) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopConfiguration
 
Context - Class in org.apache.tinkerpop.gremlin.server
The context of Gremlin Server within which a particular request is made.
Context(RequestMessage, ChannelHandlerContext, Settings, GraphManager, GremlinExecutor, ScheduledExecutorService) - Constructor for class org.apache.tinkerpop.gremlin.server.Context
 
Context(Logger) - Constructor for class org.apache.tinkerpop.gremlin.server.util.LifeCycleHook.Context
 
ControlOpProcessor - Class in org.apache.tinkerpop.gremlin.server.op.control
Deprecated.
As for release 3.2.2, not replaced as this feature was never really published as official.
ControlOpProcessor() - Constructor for class org.apache.tinkerpop.gremlin.server.op.control.ControlOpProcessor
Deprecated.
 
convert(Object) - Method in interface org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph.IdManager
Convert an identifier to the type required by the manager.
convertElementsToIds() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GraphStep
 
convertId(Object, Class<? extends Element>) - Method in class org.apache.tinkerpop.gremlin.GraphManager.ManagedGraphProvider
 
convertId(Object, Class<? extends Element>) - Method in interface org.apache.tinkerpop.gremlin.GraphProvider
Converts an identifier from a test to an identifier accepted by the Graph instance.
convertLabel(String) - Method in class org.apache.tinkerpop.gremlin.GraphManager.ManagedGraphProvider
 
convertLabel(String) - Method in interface org.apache.tinkerpop.gremlin.GraphProvider
Converts an label from a test to an label accepted by the Graph instance.
convertLambdaToString(Lambda) - Method in class org.apache.tinkerpop.gremlin.python.jsr223.JythonTranslator
 
convertLambdaToString(Lambda) - Method in class org.apache.tinkerpop.gremlin.python.jsr223.PythonTranslator
 
convertPackageToResourcePath(Class) - Static method in class org.apache.tinkerpop.gremlin.TestHelper
Takes a class and converts its package name to a path that can be used to access a resource in that package.
convertToEdgeId(String, String, String) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
 
convertToEdgeId(Graph, String, String, String) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
 
convertToRelative(Class, File) - Static method in class org.apache.tinkerpop.gremlin.TestHelper
 
convertToVertex(Graph, String) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
 
convertToVertexId(String) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
Looks up the identifier as generated by the current source graph being tested.
convertToVertexId(Graph, String) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
Looks up the identifier as generated by the current source graph being tested.
convertToVertexProperty(Graph, String, String) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
 
convertToVertexPropertyId(String, String) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
 
convertToVertexPropertyId(Graph, String, String) - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinTest
 
convertValueTraversal(Traversal.Admin<S, E>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GroupStep
 
copyDirectoryIfNonExistent(FileSystem, String) - Static method in class org.apache.tinkerpop.gremlin.hadoop.process.computer.AbstractHadoopGraphComputer
 
CopyDistribution - Class in org.apache.tinkerpop.gremlin.algorithm.generator
CopyDistribution returns the conditional value.
CopyDistribution() - Constructor for class org.apache.tinkerpop.gremlin.algorithm.generator.CopyDistribution
 
copyFromLocal(String, String) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.FileSystemStorage
 
copyLabels(Step<?, ?>, Step<?, ?>, boolean) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalHelper
 
copyMembers(ImmutableMetrics) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.MutableMetrics
 
copyToLocal(String, String) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.FileSystemStorage
 
CORE_IMPLEMENTATIONS - Static variable in interface org.apache.tinkerpop.gremlin.GraphProvider
Implementations from gremlin-core that need to be part of the clear process.
CoreGremlinModule - Class in org.apache.tinkerpop.gremlin.jsr223
Deprecated.
As of release 3.2.4, replaced by CoreGremlinPlugin.
CoreGremlinPlugin - Class in org.apache.tinkerpop.gremlin.jsr223
This module is required for a ScriptEngine to be Gremlin-enabled.
CoreImports - Class in org.apache.tinkerpop.gremlin.jsr223
 
CoreImports - Class in org.apache.tinkerpop.gremlin.util
Deprecated.
As of release 3.2.4, replaced by CoreImports.
CoreTraversalTest - Class in org.apache.tinkerpop.gremlin.process.traversal
 
CoreTraversalTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.CoreTraversalTest
 
count() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
count(Scope) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
count() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Map the traversal stream to its reduction as a sum of the Traverser.bulk() values (i.e.
count(Scope) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
count - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
count(Iterator) - Static method in class org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils
 
count(Iterable) - Static method in class org.apache.tinkerpop.gremlin.util.iterator.IteratorUtils
 
counter - Variable in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchStep.CountMatchAlgorithm
 
CountGlobalStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
CountGlobalStep(Traversal.Admin) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.CountGlobalStep
 
CountLocalStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
CountLocalStep(Traversal.Admin) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.CountLocalStep
 
CountMatchAlgorithm() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchStep.CountMatchAlgorithm
 
CountMatchTraversals() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.MatchTest.CountMatchTraversals
 
counts - Variable in class org.apache.tinkerpop.gremlin.process.traversal.util.ImmutableMetrics
 
COUNTS - Static variable in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTokens
 
CountTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
CountTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.CountTest
 
CountTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
countUsers() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.dsl.credential.CredentialGraph
Get a count of the number of users in the database.
countUsers() - Method in class org.apache.tinkerpop.gremlin.groovy.plugin.dsl.credential.CredentialGraph
Deprecated.
Get a count of the number of users in the database.
coworkerSummary() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.ComplexTest
 
coworkerSummaryOLTP() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.ComplexTest
 
cp(String, String) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.FileSystemStorage
 
cp(String, String) - Method in class org.apache.tinkerpop.gremlin.spark.structure.io.SparkContextStorage
 
cp(String, String) - Method in interface org.apache.tinkerpop.gremlin.structure.io.Storage
Recursively copy all the data sources from the source location to the target location.
create() - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGenerator.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.DistributionGenerator.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.driver.Client.SessionSettings.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.driver.Client.Settings.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.driver.Cluster.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.driver.message.RequestMessage.Builder
Create the request message given the settings provided to the RequestMessage.Builder.
create() - Method in class org.apache.tinkerpop.gremlin.driver.message.ResponseMessage.Builder
 
create(String, Class<? extends Graph.Features.FeatureSet>) - Static method in class org.apache.tinkerpop.gremlin.FeatureRequirement.Factory
 
create(String, Class<? extends Graph.Features.FeatureSet>, boolean) - Static method in class org.apache.tinkerpop.gremlin.FeatureRequirement.Factory
 
create() - Method in class org.apache.tinkerpop.gremlin.groovy.AbstractImportCustomizerProvider
 
create() - Method in interface org.apache.tinkerpop.gremlin.groovy.CompilerCustomizerProvider
Create a new instance of a CompilationCustomizer to add to the GremlinGroovyScriptEngine.
create() - Method in class org.apache.tinkerpop.gremlin.groovy.EmptyImportCustomizerProvider
 
create() - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutor.LifeCycle.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.CompileStaticCustomizerProvider
Deprecated.
 
create() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.ConfigurationCustomizerProvider
Deprecated.
 
create() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.InterpreterModeCustomizerProvider
Deprecated.
 
create() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.ThreadInterruptCustomizerProvider
Deprecated.
 
create() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.TimedInterruptCustomizerProvider
Deprecated.
 
create() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.TypeCheckedCustomizerProvider
Deprecated.
 
create() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GroovyCompilerGremlinPlugin.Builder
 
create() - Method in interface org.apache.tinkerpop.gremlin.groovy.jsr223.GroovyCustomizer
Create a new instance of a CompilationCustomizer to add to the GremlinGroovyScriptEngine.
create() - Method in class org.apache.tinkerpop.gremlin.groovy.NoImportCustomizerProvider
 
create() - Method in class org.apache.tinkerpop.gremlin.jsr223.BindingsGremlinPlugin.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.jsr223.DefaultImportCustomizer.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.jsr223.ImportGremlinPlugin.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.jsr223.ScriptFileGremlinPlugin.Builder
 
create(Graph) - Method in class org.apache.tinkerpop.gremlin.process.computer.bulkdumping.BulkDumperVertexProgram.Builder
 
create(Graph) - Method in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoaderVertexProgram.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.ClusterCountMapReduce.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.ClusterPopulationMapReduce.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.process.computer.ranking.pagerank.PageRankMapReduce.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.decoration.VertexProgramStrategy.Builder
 
create(Configuration) - Static method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.decoration.VertexProgramStrategy
 
create(Graph) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.AbstractVertexProgramBuilder
 
create(Graph) - Method in interface org.apache.tinkerpop.gremlin.process.computer.VertexProgram.Builder
 
create(Graph) - Method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource.Builder
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
create(Graph) - Method in class org.apache.tinkerpop.gremlin.process.traversal.engine.ComputerTraversalEngine.Builder
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
create(GraphTraversalSource) - Method in class org.apache.tinkerpop.gremlin.process.traversal.engine.ComputerTraversalEngine.Builder
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
create(Graph) - Method in class org.apache.tinkerpop.gremlin.process.traversal.engine.StandardTraversalEngine.Builder
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
create() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.ElementIdStrategy.Builder
 
create(Configuration) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.ElementIdStrategy
 
create() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategy.Builder
 
create(Configuration) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.HaltedTraverserStrategy
 
create() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.PartitionStrategy.Builder
Creates the PartitionStrategy.
create(Configuration) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.PartitionStrategy
 
create() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SackStrategy.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SubgraphStrategy.Builder
 
create(Configuration) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SubgraphStrategy
 
create() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.finalization.MatchAlgorithmStrategy.Builder
 
create(Configuration) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.finalization.MatchAlgorithmStrategy
 
create(Graph) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalEngine.Builder
Deprecated.
Create the TraversalEngine.
create(Graph) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.TraversalSource.Builder
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
create(String) - Static method in class org.apache.tinkerpop.gremlin.server.util.ThreadFactoryUtil
 
create(Configuration) - Static method in class org.apache.tinkerpop.gremlin.spark.structure.Spark
 
create(SparkContext) - Static method in class org.apache.tinkerpop.gremlin.spark.structure.Spark
 
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLIo.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLMapper.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLReader.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLWriter.Builder
 
create() - Method in interface org.apache.tinkerpop.gremlin.structure.io.GraphReader.ReaderBuilder
Creates the GraphReader implementation given options provided to the GraphReader.ReaderBuilder implementation.
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONIo.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONMapper.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONReader.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONWriter.Builder
 
create(boolean) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONXModuleV2d0.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.LegacyGraphSONReader.Builder
 
create() - Method in interface org.apache.tinkerpop.gremlin.structure.io.GraphWriter.WriterBuilder
Creates the GraphWriter implementation given options provided to the GraphWriter.WriterBuilder implementation.
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoIo.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoMapper.Builder
Creates a GryoMapper.
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoPool.Builder
Create the GryoPool from this builder.
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoReader.Builder
 
create() - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoWriter.Builder
Create the GryoWriter.
create() - Method in interface org.apache.tinkerpop.gremlin.structure.io.Io.Builder
Providers call this method in the Graph.io(Io.Builder) method to construct the Io instance and return the value.
create(Host) - Static method in class org.apache.tinkerpop.gremlin.structure.util.Attachable.Method
 
createBindings() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GremlinGroovyScriptEngine
Create bindings to be used by this ScriptEngine.
createBindings() - Method in class org.apache.tinkerpop.gremlin.python.jsr223.GremlinJythonScriptEngine
 
createClassic() - Static method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerFactory
 
createEdge(Edge, Vertex, Vertex, Graph, GraphTraversalSource) - Method in interface org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoader
Creates a clone of the given edge between the given in- and out-vertices.
createEdge(Attachable<Edge>, Graph) - Static method in class org.apache.tinkerpop.gremlin.structure.util.Attachable.Method
 
createEdge(Attachable<Edge>, Vertex) - Static method in class org.apache.tinkerpop.gremlin.structure.util.Attachable.Method
 
createFlattened(JsonParser, JsonParser) - Static method in class org.apache.tinkerpop.gremlin.structure.io.graphson.JsonParserConcat
 
createGraphComputerView(TinkerGraph, GraphFilter, Set<VertexComputeKey>) - Static method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerHelper
 
createIndex(String, Class<E>) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
Create an index for said element class (Vertex or Edge) and said property key.
createInitialMessage() - Method in class org.apache.tinkerpop.gremlin.giraph.process.computer.GiraphMessageCombiner
 
createInitialValue() - Method in class org.apache.tinkerpop.gremlin.giraph.process.computer.MemoryAggregator
 
createIoBuilder(String) - Static method in class org.apache.tinkerpop.gremlin.structure.io.IoCore
 
createKeepAliveMessage() - Method in interface org.apache.tinkerpop.gremlin.driver.Channelizer
Create a message for the driver to use as a "keep-alive" for the connection.
createKeepAliveMessage() - Method in class org.apache.tinkerpop.gremlin.driver.Channelizer.WebSocketChannelizer
 
createMapper() - Method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLMapper
 
createMapper() - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONMapper
 
createMapper() - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoMapper
 
createMapper() - Method in interface org.apache.tinkerpop.gremlin.structure.io.Mapper
Create a new instance of the internal object mapper that an implementation represents.
createMapReduce(Graph, Configuration) - Static method in interface org.apache.tinkerpop.gremlin.process.computer.MapReduce
A helper method to construct a MapReduce given the content of the supplied configuration.
createModern() - Static method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerFactory
 
createObject(Map<String, Object>) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV2d0.RequestMessageDeserializer
 
createObject(Map<String, Object>) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV2d0.ResponseMessageDeserializer
 
createObject(Map<String, Object>) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.AbstractObjectDeserializer
 
createObject(Map) - Method in class org.apache.tinkerpop.gremlin.structure.io.util.CustomId.CustomIdJacksonDeserializerV2d0
 
createProperty(Attachable<Property>, Graph) - Static method in class org.apache.tinkerpop.gremlin.structure.util.Attachable.Method
 
createProperty(Attachable<Property>, Vertex) - Static method in class org.apache.tinkerpop.gremlin.structure.util.Attachable.Method
 
createRandomGraph(Graph, int, int) - Static method in class org.apache.tinkerpop.gremlin.TestHelper
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.tinkerpop.gremlin.hadoop.process.computer.GraphFilterInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.graphson.GraphSONInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.gryo.GryoInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.script.ScriptInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.tinkerpop.gremlin.spark.structure.io.InputRDDFormat
 
createTheCrew() - Static method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerFactory
 
createThreadedTx() - Method in interface org.apache.tinkerpop.gremlin.structure.Transaction
Creates a transaction that can be executed across multiple threads.
createThreadedTx() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractTransaction
Creates a transaction that can be executed across multiple threads.
createTraversalSource(Graph) - Method in class org.apache.tinkerpop.gremlin.process.traversal.util.TraversalSourceFactory
 
createUser(String, String) - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.dsl.credential.CredentialGraph
Creates a new user.
createUser(String, String) - Method in class org.apache.tinkerpop.gremlin.groovy.plugin.dsl.credential.CredentialGraph
Deprecated.
Creates a new user.
createVertex(Attachable<Vertex>, Graph) - Static method in class org.apache.tinkerpop.gremlin.structure.util.Attachable.Method
 
createVertex(Attachable<Vertex>, Vertex) - Static method in class org.apache.tinkerpop.gremlin.structure.util.Attachable.Method
 
createVertexProgram(Graph, Configuration) - Static method in interface org.apache.tinkerpop.gremlin.process.computer.VertexProgram
A helper method to construct a VertexProgram given the content of the supplied configuration.
createVertexProperty(VertexProperty<?>, Vertex, Graph, GraphTraversalSource) - Method in interface org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoader
Creates a clone of the given property for the given vertex.
createVertexProperty(Attachable<VertexProperty>, Graph) - Static method in class org.apache.tinkerpop.gremlin.structure.util.Attachable.Method
 
createVertexProperty(Attachable<VertexProperty>, Vertex) - Static method in class org.apache.tinkerpop.gremlin.structure.util.Attachable.Method
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.tinkerpop.gremlin.giraph.structure.io.GiraphVertexInputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.tinkerpop.gremlin.giraph.structure.io.GiraphVertexOutputFormat
 
CredentialGraph - Class in org.apache.tinkerpop.gremlin.groovy.jsr223.dsl.credential
A DSL for managing a "credentials graph" used by Gremlin Server for simple authentication functions.
CredentialGraph(Graph) - Constructor for class org.apache.tinkerpop.gremlin.groovy.jsr223.dsl.credential.CredentialGraph
 
CredentialGraph - Class in org.apache.tinkerpop.gremlin.groovy.plugin.dsl.credential
Deprecated.
As of release 3.2.4, replaced by CredentialGraph.
CredentialGraph(Graph) - Constructor for class org.apache.tinkerpop.gremlin.groovy.plugin.dsl.credential.CredentialGraph
Deprecated.
 
CredentialGraphGremlinPlugin - Class in org.apache.tinkerpop.gremlin.groovy.jsr223.dsl.credential
Plugin for the "credentials graph".
CredentialGraphGremlinPlugin() - Constructor for class org.apache.tinkerpop.gremlin.groovy.jsr223.dsl.credential.CredentialGraphGremlinPlugin
 
CredentialGraphGremlinPlugin - Class in org.apache.tinkerpop.gremlin.groovy.plugin.dsl.credential
Deprecated.
As of release 3.2.4, replaced by CredentialGraphGremlinPlugin.
CredentialGraphGremlinPlugin() - Constructor for class org.apache.tinkerpop.gremlin.groovy.plugin.dsl.credential.CredentialGraphGremlinPlugin
Deprecated.
 
CredentialGraphTest - Class in org.apache.tinkerpop.gremlin.groovy.jsr223.dsl.credential
 
CredentialGraphTest() - Constructor for class org.apache.tinkerpop.gremlin.groovy.jsr223.dsl.credential.CredentialGraphTest
 
CredentialGraphTest - Class in org.apache.tinkerpop.gremlin.groovy.plugin.dsl.credential
 
CredentialGraphTest() - Constructor for class org.apache.tinkerpop.gremlin.groovy.plugin.dsl.credential.CredentialGraphTest
 
CredentialGraphTokens - Class in org.apache.tinkerpop.gremlin.groovy.jsr223.dsl.credential
 
CredentialGraphTokens - Class in org.apache.tinkerpop.gremlin.groovy.plugin.dsl.credential
Deprecated.
As of release 3.2.4, replaced by CredentialGraphTokens.
credentials(String, String) - Method in class org.apache.tinkerpop.gremlin.driver.Cluster.Builder
Sets the AuthProperties.Property.USERNAME and AuthProperties.Property.PASSWORD properties for authentication to Gremlin Server.
credentials(Graph) - Static method in class org.apache.tinkerpop.gremlin.groovy.jsr223.dsl.credential.CredentialGraph
Wrap up any Graph instance in the CredentialGraph DSL.
credentials(Graph) - Static method in class org.apache.tinkerpop.gremlin.groovy.plugin.dsl.credential.CredentialGraph
Deprecated.
Wrap up any Graph instance in the CredentialGraph DSL.
crossCommunityPercentage(double) - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGenerator.Builder
Sets the percentage of edges that cross a community, i.e.
crossPcent - Variable in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGeneratorTest.DifferentDistributionsTest
 
csvReporter - Variable in class org.apache.tinkerpop.gremlin.server.Settings.ServerMetrics
 
CsvReporterMetrics() - Constructor for class org.apache.tinkerpop.gremlin.server.Settings.CsvReporterMetrics
 
currentId - Variable in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
 
currentMap - Variable in class org.apache.tinkerpop.gremlin.tinkergraph.process.computer.TinkerMemory
 
CustomId - Class in org.apache.tinkerpop.gremlin.structure.io.util
A mock identifier for use in ensuring that custom serializers work around element identifiers.
CustomId(String, UUID) - Constructor for class org.apache.tinkerpop.gremlin.structure.io.util.CustomId
 
CustomId.CustomIdJacksonDeserializerV2d0 - Class in org.apache.tinkerpop.gremlin.structure.io.util
 
CustomId.CustomIdJacksonSerializerV1d0 - Class in org.apache.tinkerpop.gremlin.structure.io.util
 
CustomId.CustomIdJacksonSerializerV2d0 - Class in org.apache.tinkerpop.gremlin.structure.io.util
 
CustomId.CustomIdTinkerPopJacksonModule - Class in org.apache.tinkerpop.gremlin.structure.io.util
 
CustomIdJacksonDeserializerV2d0() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.util.CustomId.CustomIdJacksonDeserializerV2d0
 
CustomIdJacksonSerializerV1d0() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.util.CustomId.CustomIdJacksonSerializerV1d0
 
CustomIdJacksonSerializerV2d0() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.util.CustomId.CustomIdJacksonSerializerV2d0
 
CustomIdTinkerPopJacksonModule() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.util.CustomId.CustomIdTinkerPopJacksonModule
 
Customizer - Interface in org.apache.tinkerpop.gremlin.jsr223
The Customizer provides a general way to provide configurations to a GremlinScriptEngine.
customizers - Variable in class org.apache.tinkerpop.gremlin.jsr223.AbstractGremlinPlugin
 
cyclicPath() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
cyclicPath() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Filter the E object if its Traverser.path() is Path.isSimple().
cyclicPath - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
CyclicPathStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
CyclicPathStep(Traversal.Admin) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.CyclicPathStep
 
CyclicPathTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
CyclicPathTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.CyclicPathTest
 
CyclicPathTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
cypher(String) - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
Execute the Cypher query and get the result set as a GraphTraversal.
cypher(String, Map<String, Object>) - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
Execute the Cypher query with provided parameters and get the result set as a GraphTraversal.
CypherStartStep - Class in org.apache.tinkerpop.gremlin.neo4j.process.traversal.step.sideEffect
 
CypherStartStep(Traversal.Admin, String, Neo4jCypherIterator<?>) - Constructor for class org.apache.tinkerpop.gremlin.neo4j.process.traversal.step.sideEffect.CypherStartStep
 

D

data() - Static method in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGeneratorTest.DifferentDistributionsTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.algorithm.generator.DistributionGeneratorTest.DifferentDistributionsTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GremlinGroovyScriptEngineSandboxedStandardTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.TraversalInterruptionComputerTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.TraversalInterruptionTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.FeatureSupportTest.ElementPropertyDataTypeFunctionalityTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.FeatureSupportTest.GraphVariablesFunctionalityTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.io.IoCustomTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.io.IoEdgeTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.io.IoGraphTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.io.IoPropertyTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.io.IoVertexTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.PropertyTest.PropertyFeatureSupportTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.PropertyTest.PropertyValidationOnAddExceptionConsistencyTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.PropertyTest.PropertyValidationOnSetExceptionConsistencyTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.VariablesTest.GraphVariablesFeatureSupportTest
 
data() - Static method in class org.apache.tinkerpop.gremlin.structure.VariablesTest.VariableExceptionConsistencyTest
 
dataTypeOfPropertyValueNotSupported(Object) - Static method in class org.apache.tinkerpop.gremlin.structure.Property.Exceptions
 
dataTypeOfPropertyValueNotSupported(Object, Exception) - Static method in class org.apache.tinkerpop.gremlin.structure.Property.Exceptions
 
dataTypeOfVariableValueNotSupported(Object) - Static method in class org.apache.tinkerpop.gremlin.structure.Graph.Variables.Exceptions
 
dataTypeOfVariableValueNotSupported(Object, Exception) - Static method in class org.apache.tinkerpop.gremlin.structure.Graph.Variables.Exceptions
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.tinkerpop.gremlin.driver.handler.NioGremlinResponseDecoder
 
decode(ChannelHandlerContext, WebSocketFrame, List<Object>) - Method in class org.apache.tinkerpop.gremlin.driver.handler.WebSocketGremlinResponseDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.tinkerpop.gremlin.server.handler.NioGremlinBinaryRequestDecoder
 
decode(ChannelHandlerContext, RequestMessage, List<Object>) - Method in class org.apache.tinkerpop.gremlin.server.handler.OpSelectorHandler
 
decode(ChannelHandlerContext, BinaryWebSocketFrame, List<Object>) - Method in class org.apache.tinkerpop.gremlin.server.handler.WsGremlinBinaryRequestDecoder
 
decode(ChannelHandlerContext, CloseWebSocketFrame, List<Object>) - Method in class org.apache.tinkerpop.gremlin.server.handler.WsGremlinCloseRequestDecoder
 
decode(ChannelHandlerContext, TextWebSocketFrame, List<Object>) - Method in class org.apache.tinkerpop.gremlin.server.handler.WsGremlinTextRequestDecoder
 
dedup(String...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
dedup(Scope, String...) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
dedup(Scope, String...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Remove all duplicates in the traversal stream up to this point.
dedup(String...) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
Remove all duplicates in the traversal stream up to this point.
dedup - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
DedupGlobalStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
DedupGlobalStep(Traversal.Admin, String...) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.DedupGlobalStep
 
DedupLocalStep<E,S extends Iterable<E>> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
DedupLocalStep(Traversal.Admin) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.DedupLocalStep
 
DedupTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
DedupTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.DedupTest
 
DedupTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
DEFAULT_BENCHMARK_ROUNDS - Static variable in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutorPerformanceTest
Deprecated.
 
DEFAULT_BENCHMARK_ROUNDS - Static variable in class org.apache.tinkerpop.gremlin.process.TraversalPerformanceTest
Deprecated.
 
DEFAULT_BULK_LOADER_VERTEX_ID - Static variable in class org.apache.tinkerpop.gremlin.process.computer.bulkloading.BulkLoaderVertexProgram
 
DEFAULT_CACHE_EXPIRATION_TIME - Static variable in class org.apache.tinkerpop.gremlin.server.op.traversal.TraversalOpProcessor
Default timeout for a cached side-effect is ten minutes.
DEFAULT_CACHE_MAX_SIZE - Static variable in class org.apache.tinkerpop.gremlin.server.op.traversal.TraversalOpProcessor
Default size of the max size of the cache.
DEFAULT_CROSS_COMMUNITY_PERCENTAGE - Static variable in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGenerator
 
DEFAULT_DELAY_MS - Static variable in class org.apache.tinkerpop.gremlin.structure.Transaction.Workload
 
DEFAULT_IDENT - Static variable in class org.apache.tinkerpop.gremlin.util.config.YamlConfiguration
 
DEFAULT_INTERRUPTION_TIMEOUT - Static variable in class org.apache.tinkerpop.gremlin.groovy.jsr223.customizer.TimedInterruptCustomizerProvider
Deprecated.
 
DEFAULT_LABEL - Static variable in interface org.apache.tinkerpop.gremlin.structure.Edge
The default label to use for an edge.
DEFAULT_LABEL - Static variable in interface org.apache.tinkerpop.gremlin.structure.Vertex
The default label to use for a vertex.
DEFAULT_LABEL - Static variable in interface org.apache.tinkerpop.gremlin.structure.VertexProperty
 
DEFAULT_LAMBDA_LANGUAGE - Static variable in interface org.apache.tinkerpop.gremlin.util.function.Lambda
 
DEFAULT_MEMORY_KEY - Static variable in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.ClusterCountMapReduce
 
DEFAULT_MEMORY_KEY - Static variable in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.ClusterPopulationMapReduce
 
DEFAULT_MEMORY_KEY - Static variable in class org.apache.tinkerpop.gremlin.process.computer.ranking.pagerank.PageRankMapReduce
 
DEFAULT_METRICS_KEY - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.step.sideEffect.ProfileSideEffectStep
 
DEFAULT_NUMBER_OF_COMMUNITIES - Static variable in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGenerator
 
DEFAULT_PER_GRAPH_CLOSE_TIMEOUT - Static variable in class org.apache.tinkerpop.gremlin.server.op.session.SessionOpProcessor
Default amount of time to wait in milliseconds for each configured graph to close any open transactions when the session is killed.
DEFAULT_REQUEST_SERIALIZER - Static variable in enum org.apache.tinkerpop.gremlin.driver.ser.Serializers
Default serializer for requests received by Gremlin Server.
DEFAULT_RESULT_SERIALIZER - Static variable in enum org.apache.tinkerpop.gremlin.driver.ser.Serializers
Default serializer for results returned from Gremlin Server.
DEFAULT_SCRIPT_ENGINE - Static variable in class org.apache.tinkerpop.gremlin.jsr223.ScriptEngineCache
 
DEFAULT_SCRIPT_ENGINE - Static variable in class org.apache.tinkerpop.gremlin.util.ScriptEngineCache
Deprecated.
 
DEFAULT_SERIALIZERS - Static variable in class org.apache.tinkerpop.gremlin.server.AbstractChannelizer
 
DEFAULT_SESSION_TIMEOUT - Static variable in class org.apache.tinkerpop.gremlin.server.op.session.SessionOpProcessor
Default timeout for a session is eight hours.
DEFAULT_SETTINGS - Static variable in class org.apache.tinkerpop.gremlin.server.op.traversal.TraversalOpProcessor
 
DEFAULT_TRIES - Static variable in class org.apache.tinkerpop.gremlin.structure.Transaction.Workload
 
DEFAULT_WARMUP_ROUNDS - Static variable in class org.apache.tinkerpop.gremlin.groovy.engine.GremlinExecutorPerformanceTest
Deprecated.
 
DEFAULT_WARMUP_ROUNDS - Static variable in class org.apache.tinkerpop.gremlin.process.TraversalPerformanceTest
Deprecated.
 
DefaultBindingsCustomizer - Class in org.apache.tinkerpop.gremlin.jsr223
Default implementation of the BindingsCustomizer.
DefaultBindingsCustomizer(Bindings) - Constructor for class org.apache.tinkerpop.gremlin.jsr223.DefaultBindingsCustomizer
Creates a new object with ScriptContext.ENGINE_SCOPE.
DefaultBindingsCustomizer(Bindings, int) - Constructor for class org.apache.tinkerpop.gremlin.jsr223.DefaultBindingsCustomizer
 
DefaultCloseableIterator<T> - Class in org.apache.tinkerpop.gremlin.structure.util
A default implementation of CloseableIterator that simply wraps an existing Iterator.
DefaultCloseableIterator(Iterator<T>) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.DefaultCloseableIterator
 
DefaultComputerResult - Class in org.apache.tinkerpop.gremlin.process.computer.util
The result of the GraphComputer's computation.
DefaultComputerResult(Graph, Memory) - Constructor for class org.apache.tinkerpop.gremlin.process.computer.util.DefaultComputerResult
 
DefaultEventQueue() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategy.DefaultEventQueue
 
DefaultGraphTraversal<S,E> - Class in org.apache.tinkerpop.gremlin.process.traversal.dsl.graph
 
DefaultGraphTraversal() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.DefaultGraphTraversal
 
DefaultGraphTraversal(GraphTraversalSource) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.DefaultGraphTraversal
 
DefaultGraphTraversal(Graph) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.DefaultGraphTraversal
 
DefaultGremlinScriptEngineManager - Class in org.apache.tinkerpop.gremlin.jsr223
The ScriptEngineManager implements a discovery, instantiation and configuration mechanism for GremlinScriptEngine classes and also maintains a collection of key/value pairs storing state shared by all engines created by it.
DefaultGremlinScriptEngineManager() - Constructor for class org.apache.tinkerpop.gremlin.jsr223.DefaultGremlinScriptEngineManager
The effect of calling this constructor is the same as calling DefaultGremlinScriptEngineManager(Thread.currentThread().getContextClassLoader()).
DefaultGremlinScriptEngineManager(ClassLoader) - Constructor for class org.apache.tinkerpop.gremlin.jsr223.DefaultGremlinScriptEngineManager
This constructor loads the implementations of GremlinScriptEngineFactory visible to the given ClassLoader using the ServiceLoader mechanism.
DefaultImportCustomizer - Class in org.apache.tinkerpop.gremlin.jsr223
Simple implementation of the ImportCustomizer which allows direct setting of all the different import types.
DefaultImportCustomizer.Builder - Class in org.apache.tinkerpop.gremlin.jsr223
 
DefaultImportCustomizerProvider - Class in org.apache.tinkerpop.gremlin.groovy
Grabs the standard Gremlin core classes and allows additional imports to be added.
DefaultImportCustomizerProvider() - Constructor for class org.apache.tinkerpop.gremlin.groovy.DefaultImportCustomizerProvider
Utilizes imports defined statically by initializeStatically().
DefaultImportCustomizerProvider(Set<String>, Set<String>) - Constructor for class org.apache.tinkerpop.gremlin.groovy.DefaultImportCustomizerProvider
Utilizes imports defined by the supplied arguments.
DefaultImportCustomizerProvider(ImportCustomizerProvider, Set<String>, Set<String>) - Constructor for class org.apache.tinkerpop.gremlin.groovy.DefaultImportCustomizerProvider
Utilizes imports defined by the supplied arguments.
DefaultRemoteTraverser<T> - Class in org.apache.tinkerpop.gremlin.process.remote.traversal
 
DefaultRemoteTraverser(T, long) - Constructor for class org.apache.tinkerpop.gremlin.process.remote.traversal.DefaultRemoteTraverser
 
DefaultRemoteTraverserSerializer() - Constructor for class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoSerializers.DefaultRemoteTraverserSerializer
 
DefaultScriptCustomizer - Class in org.apache.tinkerpop.gremlin.jsr223
Default implementation of the ScriptCustomizer that can create the script list from a list of files or from lines of script.
DefaultScriptCustomizer(List<File>) - Constructor for class org.apache.tinkerpop.gremlin.jsr223.DefaultScriptCustomizer
 
DefaultScriptCustomizer(Collection<List<String>>) - Constructor for class org.apache.tinkerpop.gremlin.jsr223.DefaultScriptCustomizer
 
DefaultTraversal<S,E> - Class in org.apache.tinkerpop.gremlin.process.traversal.util
 
DefaultTraversal(Graph) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversal
 
DefaultTraversal(TraversalSource) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversal
 
DefaultTraversal() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversal
 
DefaultTraversal(Bytecode) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversal
 
DefaultTraversalMetrics - Class in org.apache.tinkerpop.gremlin.process.traversal.util
 
DefaultTraversalMetrics() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversalMetrics
 
DefaultTraversalMetrics(long, List<MutableMetrics>) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversalMetrics
This is only a convenient constructor needed for GraphSON deserialization.
DefaultTraversalMetricsSupplier - Class in org.apache.tinkerpop.gremlin.util.function
 
DefaultTraversalSideEffects - Class in org.apache.tinkerpop.gremlin.process.traversal.util
 
DefaultTraversalSideEffects() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversalSideEffects
 
DefaultTraversalStrategies - Class in org.apache.tinkerpop.gremlin.process.traversal.util
 
DefaultTraversalStrategies() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.util.DefaultTraversalStrategies
 
DefaultTraverserGeneratorFactory - Class in org.apache.tinkerpop.gremlin.process.traversal.traverser.util
 
defaultVertexPropertyCardinality - Variable in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
 
degreeDistribution(Distribution) - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGenerator.Builder
Sets the distribution to be used to generate the out-degrees of vertices.
degreeDistribution - Variable in class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGeneratorTest.DifferentDistributionsTest
 
deleteDirectory(File) - Static method in class org.apache.tinkerpop.gremlin.AbstractGraphProvider
Helper method for those building GraphProvider implementations that need to clean directories between test runs.
dependencies() - Method in class org.apache.tinkerpop.gremlin.groovy.engine.ScriptEngines
Deprecated.
List dependencies for those ScriptEngine objects that implement the DependencyManager interface.
dependencies() - Method in interface org.apache.tinkerpop.gremlin.groovy.jsr223.DependencyManager
Deprecated.
List the dependencies in the ScriptEngine classloader.
dependencies() - Method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GremlinGroovyScriptEngine
List the dependencies in the ScriptEngine classloader.
DependencyManager - Interface in org.apache.tinkerpop.gremlin.groovy.jsr223
Deprecated.
As of release 3.2.4, not replaced - no longer needed under the new GremlinScriptEngine model.
describe() - Method in class org.apache.tinkerpop.gremlin.AbstractGremlinSuite.OptOutTestFilter
 
describe(String) - Method in class org.apache.tinkerpop.gremlin.spark.structure.io.SparkContextStorage
 
deserialize(Configuration, String) - Static method in class org.apache.tinkerpop.gremlin.process.computer.util.VertexProgramHelper
 
deserialize(ByteBuffer, <any>) - Method in class org.apache.tinkerpop.gremlin.spark.structure.io.gryo.GryoSerializerInstance
 
deserialize(ByteBuffer, ClassLoader, <any>) - Method in class org.apache.tinkerpop.gremlin.spark.structure.io.gryo.GryoSerializerInstance
 
deserialize(JsonParser, DeserializationContext) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.AbstractObjectDeserializer
 
deserializeObject(byte[]) - Static method in class org.apache.tinkerpop.gremlin.util.Serializer
 
deserializeRequest(ByteBuf) - Method in interface org.apache.tinkerpop.gremlin.driver.MessageSerializer
Deserialize a Netty ByteBuf into a RequestMessage.
deserializeRequest(ByteBuf) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV1d0
 
deserializeRequest(ByteBuf) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV2d0
 
deserializeRequest(ByteBuf) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractGryoMessageSerializerV1d0
 
deserializeRequest(String) - Method in class org.apache.tinkerpop.gremlin.driver.ser.GraphSONMessageSerializerV1d0
 
deserializeRequest(String) - Method in class org.apache.tinkerpop.gremlin.driver.ser.GraphSONMessageSerializerV2d0
 
deserializeRequest(String) - Method in interface org.apache.tinkerpop.gremlin.driver.ser.MessageTextSerializer
 
deserializeResponse(ByteBuf) - Method in interface org.apache.tinkerpop.gremlin.driver.MessageSerializer
Deserialize a Netty ByteBuf into a ResponseMessage.
deserializeResponse(ByteBuf) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV1d0
 
deserializeResponse(ByteBuf) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractGraphSONMessageSerializerV2d0
 
deserializeResponse(ByteBuf) - Method in class org.apache.tinkerpop.gremlin.driver.ser.AbstractGryoMessageSerializerV1d0
 
deserializeResponse(String) - Method in class org.apache.tinkerpop.gremlin.driver.ser.GraphSONMessageSerializerV1d0
 
deserializeResponse(String) - Method in class org.apache.tinkerpop.gremlin.driver.ser.GraphSONMessageSerializerV2d0
 
deserializeResponse(String) - Method in interface org.apache.tinkerpop.gremlin.driver.ser.MessageTextSerializer
 
deserializeStream(InputStream) - Method in class org.apache.tinkerpop.gremlin.spark.structure.io.gryo.GryoSerializerInstance
 
deserializeTypedFromAny(JsonParser, DeserializationContext) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTypeDeserializer
 
deserializeTypedFromArray(JsonParser, DeserializationContext) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTypeDeserializer
 
deserializeTypedFromObject(JsonParser, DeserializationContext) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTypeDeserializer
 
deserializeTypedFromScalar(JsonParser, DeserializationContext) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTypeDeserializer
 
destroy() - Static method in class org.apache.tinkerpop.gremlin.groovy.jsr223.GremlinGroovyScriptEngineFileSandboxTest
 
detach() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traverser.Admin
Prepare the traverser for migration across a JVM boundary.
detach() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_LP_O_P_S_SE_SL_Traverser
 
detach() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_LP_O_S_SE_SL_Traverser
 
detach() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.LP_O_OB_P_S_SE_SL_Traverser
 
detach() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.LP_O_OB_S_SE_SL_Traverser
 
detach() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.ProjectedTraverser
 
detach() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.AbstractTraverser
 
detach() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.EmptyTraverser
 
detach(Vertex, boolean) - Static method in class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedFactory
 
detach(Edge, boolean) - Static method in class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedFactory
 
detach(VertexProperty<V>, boolean) - Static method in class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedFactory
 
detach(Property<V>) - Static method in class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedFactory
 
detach(Path, boolean) - Static method in class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedFactory
 
detach(Element, boolean) - Static method in class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedFactory
 
detach(Object, boolean) - Static method in class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedFactory
 
detach(Vertex) - Static method in class org.apache.tinkerpop.gremlin.structure.util.reference.ReferenceFactory
 
detach(Edge) - Static method in class org.apache.tinkerpop.gremlin.structure.util.reference.ReferenceFactory
 
detach(VertexProperty<V>) - Static method in class org.apache.tinkerpop.gremlin.structure.util.reference.ReferenceFactory
 
detach(Property<V>) - Static method in class org.apache.tinkerpop.gremlin.structure.util.reference.ReferenceFactory
 
detach(Path) - Static method in class org.apache.tinkerpop.gremlin.structure.util.reference.ReferenceFactory
 
detach(Element) - Static method in class org.apache.tinkerpop.gremlin.structure.util.reference.ReferenceFactory
 
detach(Object) - Static method in class org.apache.tinkerpop.gremlin.structure.util.reference.ReferenceFactory
 
detached() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.HaltedTraverserStrategy
 
DetachedEdge - Class in org.apache.tinkerpop.gremlin.structure.util.detached
Represents an Edge that is disconnected from a Graph.
DetachedEdge(Edge, boolean) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedEdge
 
DetachedEdge(Object, String, Map<String, Object>, <any>, <any>) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedEdge
 
DetachedEdgeTest - Class in org.apache.tinkerpop.gremlin.structure.util.detached
 
DetachedEdgeTest() - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedEdgeTest
 
DetachedElement<E> - Class in org.apache.tinkerpop.gremlin.structure.util.detached
 
DetachedElement() - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedElement
 
DetachedElement(Element) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedElement
 
DetachedElement(Object, String) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedElement
 
DetachedFactory - Class in org.apache.tinkerpop.gremlin.structure.util.detached
 
DetachedGraphTest - Class in org.apache.tinkerpop.gremlin.structure.util.detached
 
DetachedGraphTest() - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedGraphTest
 
DetachedPath - Class in org.apache.tinkerpop.gremlin.structure.util.detached
 
DetachedPath(Path, boolean) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedPath
 
DetachedProperty<V> - Class in org.apache.tinkerpop.gremlin.structure.util.detached
 
DetachedProperty(Property<V>) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedProperty
 
DetachedProperty(String, V) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedProperty
 
DetachedProperty(String, V, Element) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedProperty
 
DetachedPropertyTest - Class in org.apache.tinkerpop.gremlin.structure.util.detached
 
DetachedPropertyTest() - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedPropertyTest
 
DetachedVertex - Class in org.apache.tinkerpop.gremlin.structure.util.detached
Represents a Vertex that is disconnected from a Graph.
DetachedVertex(Vertex, boolean) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedVertex
 
DetachedVertex(Object, String, Map<String, Object>) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedVertex
 
DetachedVertexProperty<V> - Class in org.apache.tinkerpop.gremlin.structure.util.detached
 
DetachedVertexProperty(VertexProperty<V>, boolean) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedVertexProperty
 
DetachedVertexProperty(Object, String, V, Map<String, Object>, Vertex) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedVertexProperty
 
DetachedVertexProperty(Object, String, V, Map<String, Object>) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedVertexProperty
This constructor is used by GraphSON when deserializing and the Host is not known.
DetachedVertexPropertyTest - Class in org.apache.tinkerpop.gremlin.structure.util.detached
 
DetachedVertexPropertyTest() - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedVertexPropertyTest
 
DetachedVertexTest - Class in org.apache.tinkerpop.gremlin.structure.util.detached
 
DetachedVertexTest() - Constructor for class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedVertexTest
 
DifferentDistributionsTest() - Constructor for class org.apache.tinkerpop.gremlin.algorithm.generator.CommunityGeneratorTest.DifferentDistributionsTest
 
DifferentDistributionsTest() - Constructor for class org.apache.tinkerpop.gremlin.algorithm.generator.DistributionGeneratorTest.DifferentDistributionsTest
 
Direction - Enum in org.apache.tinkerpop.gremlin.structure
Direction is used to denote the direction of an Edge or location of a Vertex on an Edge.
DirectionalStarGraph - Class in org.apache.tinkerpop.gremlin.structure.util.star
 
DirectionalStarGraph(StarGraph, Direction) - Constructor for class org.apache.tinkerpop.gremlin.structure.util.star.DirectionalStarGraph
 
distributeVote(boolean) - Method in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.PeerPressureVertexProgram.Builder
 
Distribution - Interface in org.apache.tinkerpop.gremlin.algorithm.generator
Interface for a distribution over discrete values.
DistributionGenerator - Class in org.apache.tinkerpop.gremlin.algorithm.generator
Generates a synthetic network for a given out- and (optionally) in-degree distribution.
DistributionGenerator.Builder - Class in org.apache.tinkerpop.gremlin.algorithm.generator
 
DistributionGeneratorTest - Class in org.apache.tinkerpop.gremlin.algorithm.generator
 
DistributionGeneratorTest() - Constructor for class org.apache.tinkerpop.gremlin.algorithm.generator.DistributionGeneratorTest
 
DistributionGeneratorTest.DifferentDistributionsTest - Class in org.apache.tinkerpop.gremlin.algorithm.generator
 
DistributionGeneratorTest.ProcessorTest - Class in org.apache.tinkerpop.gremlin.algorithm.generator
 
div - Variable in class org.apache.tinkerpop.gremlin.process.traversal.NumberHelper
 
div(Number, Number) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.NumberHelper
 
div(Number, Number, boolean) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.NumberHelper
 
doClose() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractThreadedTransaction
Clears transaction listeners
doClose() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractThreadLocalTransaction
 
doClose() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractTransaction
doCommit() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractTransaction
Called with AbstractTransaction.commit() after the Transaction.onReadWrite(Consumer) has been notified.
doEmit(Traverser.Admin<S>, boolean) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.RepeatStep
 
doFinalReduction(Map<K, Object>, Traversal.Admin<?, V>) - Static method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GroupStep
 
domain - Variable in class org.apache.tinkerpop.gremlin.server.Settings.JmxReporterMetrics
 
done() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.Barrier
A way to hard set that the barrier is complete.
done - Variable in class org.apache.tinkerpop.gremlin.process.traversal.step.map.GraphStep
 
done() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.ReducingBarrierStep
 
done() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.SupplyingBarrierStep
 
doOpen() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractTransaction
Called within AbstractTransaction.open() if it is determined that the transaction is not yet open given Transaction.isOpen().
doReadWrite() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractThreadedTransaction
Threaded transactions should be open immediately upon creation so most implementations should do nothing with this method.
doReadWrite() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractThreadLocalTransaction
 
doReadWrite() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractTransaction
doRollback() - Method in class org.apache.tinkerpop.gremlin.structure.util.AbstractTransaction
Called with AbstractTransaction.rollback() after the Transaction.onReadWrite(Consumer) has been notified.
doStage(MapReduce.Stage) - Method in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.ClusterCountMapReduce
 
doStage(MapReduce.Stage) - Method in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.ClusterPopulationMapReduce
 
doStage(MapReduce.Stage) - Method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputerTest.MapReduceB
 
doStage(MapReduce.Stage) - Method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputerTest.MapReduceBB
 
doStage(MapReduce.Stage) - Method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputerTest.MapReduceC
 
doStage(MapReduce.Stage) - Method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputerTest.MapReduceK
 
doStage(MapReduce.Stage) - Method in interface org.apache.tinkerpop.gremlin.process.computer.MapReduce
A MapReduce job can be map-only, map-reduce-only, or map-combine-reduce.
doStage(MapReduce.Stage) - Method in class org.apache.tinkerpop.gremlin.process.computer.ranking.pagerank.PageRankMapReduce
 
DOT_JAR - Static variable in class org.apache.tinkerpop.gremlin.hadoop.Constants
 
DOT_STAR - Static variable in class org.apache.tinkerpop.gremlin.groovy.AbstractImportCustomizerProvider
 
DOT_STAR - Static variable in class org.apache.tinkerpop.gremlin.groovy.plugin.AbstractGremlinPlugin
Deprecated.
 
doubleValue() - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.map.MeanGlobalStep.MeanNumber
 
doUntil(Traverser.Admin<S>, boolean) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.branch.RepeatStep
 
doWithReader(Function<GryoReader, A>) - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoPool
 
doWithWriter(Consumer<GryoWriter>) - Method in class org.apache.tinkerpop.gremlin.structure.io.gryo.GryoPool
 
DriverRemoteConnection - Class in org.apache.tinkerpop.gremlin.driver.remote
A RemoteConnection implementation for Gremlin Server.
DriverRemoteConnection(Configuration) - Constructor for class org.apache.tinkerpop.gremlin.driver.remote.DriverRemoteConnection
 
DriverRemoteTraversal<S,E> - Class in org.apache.tinkerpop.gremlin.driver.remote
A AbstractRemoteTraversal implementation for the Gremlin Driver.
DriverRemoteTraversal(ResultSet, Client, boolean, Optional<Configuration>) - Constructor for class org.apache.tinkerpop.gremlin.driver.remote.DriverRemoteTraversal
 
DriverRemoteTraversalSideEffects - Class in org.apache.tinkerpop.gremlin.driver.remote
Java driver implementation of TraversalSideEffects.
DriverRemoteTraversalSideEffects(Client, UUID, Host, CompletableFuture<Void>) - Constructor for class org.apache.tinkerpop.gremlin.driver.remote.DriverRemoteTraversalSideEffects
 
drop() - Static method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.__
 
drop() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal
 
drop - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
dropEdges(Direction) - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph.StarVertex
 
dropEdges(Direction, String) - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph.StarVertex
 
dropGraphComputerView(TinkerGraph) - Static method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerHelper
 
dropIndex(String, Class<E>) - Method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
Drop the index for the specified element class (Vertex or Edge) and key.
dropLabels(Set<String>) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traverser.Admin
Drop all path information associated with specified labels.
dropLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_LP_O_S_SE_SL_Traverser
 
dropLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.LP_O_OB_P_S_SE_SL_Traverser
 
dropLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.ProjectedTraverser
 
dropLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.AbstractTraverser
 
dropLabels(Set<String>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.EmptyTraverser
 
dropPath() - Method in interface org.apache.tinkerpop.gremlin.process.traversal.Traverser.Admin
Drop the path of the traverser.
dropPath() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.B_LP_O_S_SE_SL_Traverser
 
dropPath() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.LP_O_OB_P_S_SE_SL_Traverser
 
dropPath() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.ProjectedTraverser
 
dropPath() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.AbstractTraverser
 
dropPath() - Method in class org.apache.tinkerpop.gremlin.process.traversal.traverser.util.EmptyTraverser
 
DropStep<S> - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
DropStep(Traversal.Admin) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.DropStep
 
DropTest - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
DropTest() - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.filter.DropTest
 
DropTest.Traversals - Class in org.apache.tinkerpop.gremlin.process.traversal.step.filter
 
dropVertexProperties(String...) - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph.StarVertex
 
DURATION - Static variable in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTokens
 
durationNs - Variable in class org.apache.tinkerpop.gremlin.process.traversal.util.ImmutableMetrics
 

E

E - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversal.Symbols
 
E(Object...) - Method in class org.apache.tinkerpop.gremlin.process.traversal.dsl.graph.GraphTraversalSource
 
edge() - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph.HadoopGraphFeatures
 
edge(Vertex, Vertex) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.script.ScriptRecordReader.ScriptElementFactory
Deprecated.
 
edge(Vertex, Vertex, String) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.io.script.ScriptRecordReader.ScriptElementFactory
Deprecated.
 
edge() - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph.Neo4jGraphFeatures
 
Edge - Interface in org.apache.tinkerpop.gremlin.structure
An Edge links two Vertex objects.
edge() - Method in interface org.apache.tinkerpop.gremlin.structure.Graph.Features
Gets the features related to "edge" operation.
EDGE - Static variable in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTokens
 
edge() - Method in class org.apache.tinkerpop.gremlin.structure.util.empty.EmptyGraph.EmptyGraphFeatures
 
edge() - Method in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph.StarGraphFeatures
 
edge() - Method in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph.TinkerGraphFeatures
 
Edge.Exceptions - Class in org.apache.tinkerpop.gremlin.structure
Common exceptions to use with an edge.
EDGE_COMPARATOR - Static variable in class org.apache.tinkerpop.gremlin.structure.util.Comparators
Sorts Edge objects by the toString() value of Element.id() using String.CASE_INSENSITIVE_ORDER.
edgeAdded(Edge) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.event.ConsoleMutationListener
 
edgeAdded(Edge) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.util.event.MutationListener
Raised after a new Edge is added.
edgeAdded(Edge) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategyProcessTest.StubMutationListener
 
EdgeAddedEvent(Edge) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.util.event.Event.EdgeAddedEvent
 
edgeAdditionsNotSupported() - Static method in class org.apache.tinkerpop.gremlin.structure.Vertex.Exceptions
 
edgeCriterion(Traversal<Edge, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SubgraphStrategy.Builder
Deprecated.
As of release 3.2.2, replaced by Builder#edges.
edgeFeatures - Variable in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph.Neo4jGraphFeatures
 
edgeFilterAccessesAdjacentVertices(Traversal<Vertex, Edge>) - Static method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputer.Exceptions
 
edgeFunction - Variable in class org.apache.tinkerpop.gremlin.process.computer.MessageScope.Local
 
EdgeFunctionalityTest() - Constructor for class org.apache.tinkerpop.gremlin.structure.FeatureSupportTest.EdgeFunctionalityTest
 
edgeIdManager - Variable in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
 
edgeIndex - Variable in class org.apache.tinkerpop.gremlin.tinkergraph.structure.TinkerGraph
 
edgeKeyTypes(Map<String, String>) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLWriter.Builder
Map of the data types of the edge keys.
edgeLabelKey(String) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLReader.Builder
The key to use as the edge label.
edgeLabelKey(String) - Method in class org.apache.tinkerpop.gremlin.structure.io.graphml.GraphMLWriter.Builder
Set the name of the edge label in the GraphML.
EdgeOtherVertexStep - Class in org.apache.tinkerpop.gremlin.process.traversal.step.map
 
EdgeOtherVertexStep(Traversal.Admin) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.map.EdgeOtherVertexStep
 
edgeProcessor - Variable in class org.apache.tinkerpop.gremlin.algorithm.generator.AbstractGenerator.AbstractGeneratorBuilder
 
edgeProcessor(Consumer<Edge>) - Method in class org.apache.tinkerpop.gremlin.algorithm.generator.AbstractGenerator.AbstractGeneratorBuilder
 
edgeProperties - Variable in class org.apache.tinkerpop.gremlin.structure.util.star.StarGraph
 
edgePropertyChanged(Edge, Property, Object) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.event.ConsoleMutationListener
 
edgePropertyChanged(Edge, Property, Object) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.util.event.MutationListener
Raised after the property of a Edge changed.
edgePropertyChanged(Edge, Property, Object) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategyProcessTest.StubMutationListener
 
EdgePropertyChangedEvent(Edge, Property, Object) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.util.event.Event.EdgePropertyChangedEvent
 
edgePropertyChangedEventRecorded() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategyProcessTest.StubMutationListener
 
edgePropertyRemoved(Edge, Property) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.event.ConsoleMutationListener
 
edgePropertyRemoved(Edge, Property) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.util.event.MutationListener
Raised after an Property property was removed from an Edge.
edgePropertyRemoved(Edge, Property) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategyProcessTest.StubMutationListener
 
EdgePropertyRemovedEvent(Edge, Property) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.util.event.Event.EdgePropertyRemovedEvent
 
edgePropertyRemovedEventRecorded() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategyProcessTest.StubMutationListener
 
edgeRemovalNotSupported() - Static method in class org.apache.tinkerpop.gremlin.structure.Edge.Exceptions
 
edgeRemoved(Edge) - Method in class org.apache.tinkerpop.gremlin.process.traversal.step.util.event.ConsoleMutationListener
 
edgeRemoved(Edge) - Method in interface org.apache.tinkerpop.gremlin.process.traversal.step.util.event.MutationListener
Raised after an Edge was removed from the graph.
edgeRemoved(Edge) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategyProcessTest.StubMutationListener
 
EdgeRemovedEvent(Edge) - Constructor for class org.apache.tinkerpop.gremlin.process.traversal.step.util.event.Event.EdgeRemovedEvent
 
edgeRemovedEventRecorded() - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.EventStrategyProcessTest.StubMutationListener
 
edges(Traversal<Vertex, Edge>) - Method in class org.apache.tinkerpop.gremlin.hadoop.process.computer.AbstractHadoopGraphComputer
 
edges(Object...) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopGraph
 
edges(Direction, String...) - Method in class org.apache.tinkerpop.gremlin.hadoop.structure.HadoopVertex
 
edges(Object...) - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jGraph
 
edges(Direction, String...) - Method in class org.apache.tinkerpop.gremlin.neo4j.structure.Neo4jVertex
 
edges(Traversal.Admin<Vertex, Edge>) - Method in class org.apache.tinkerpop.gremlin.process.computer.clustering.peerpressure.PeerPressureVertexProgram.Builder
 
edges(Traversal<Vertex, Edge>) - Method in class org.apache.tinkerpop.gremlin.process.computer.Computer
 
edges(Traversal<Vertex, Edge>) - Method in interface org.apache.tinkerpop.gremlin.process.computer.GraphComputer
Add a filter that will limit which edges of the vertices are loaded from the graph source.
edges(Traversal<Vertex, Edge>) - Method in class org.apache.tinkerpop.gremlin.process.computer.GraphComputerTest.BadGraphComputer
 
edges(Traversal.Admin<Vertex, Edge>) - Method in class org.apache.tinkerpop.gremlin.process.computer.ranking.pagerank.PageRankVertexProgram.Builder
 
edges(Traversal<Vertex, Edge>) - Method in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.decoration.VertexProgramStrategy.Builder
 
EDGES - Static variable in class org.apache.tinkerpop.gremlin.process.computer.traversal.strategy.decoration.VertexProgramStrategy
 
edges(Direction, String...) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph.ComputerAdjacentVertex
 
edges(Direction, String...) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph.ComputerVertex
 
edges(Object...) - Method in class org.apache.tinkerpop.gremlin.process.computer.util.ComputerGraph
 
edges(Object...) - Method in class org.apache.tinkerpop.gremlin.process.remote.RemoteGraph
Deprecated.
This method returns an empty Iterator - it is not meant to be called directly.
edges(Traversal<Vertex, Edge>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.engine.ComputerTraversalEngine.Builder
Deprecated.
As of release 3.2.0. Please use Graph.traversal(Class).
edges(Traversal<Edge, ?>) - Method in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SubgraphStrategy.Builder
 
EDGES - Static variable in class org.apache.tinkerpop.gremlin.process.traversal.strategy.decoration.SubgraphStrategy
 
edges(Object...) - Method in interface org.apache.tinkerpop.gremlin.structure.Graph
Get the Edge objects in this graph with the provided edge ids or Edge objects.
EDGES - Static variable in class org.apache.tinkerpop.gremlin.structure.io.graphson.GraphSONTokens
 
EDGES - Static variable in class org.apache.tinkerpop.gremlin.structure.io.graphson.LegacyGraphSONReader.GraphSONTokensTP2
 
edges(Direction, String...) - Method in class org.apache.tinkerpop.gremlin.structure.util.detached.DetachedVertex
 
edges(Object...) - Method in class org.apache.tinkerpop.gremlin.structure.util.empty.EmptyGraph
 
edges(Direction, String...) - Method in clas