A B C D E F G H I J K L M N O P R S T U V W Y Z 
All Classes All Packages

A

AbstractNodeProjection - Class in org.neo4j.graphalgo
 
AbstractNodeProjection() - Constructor for class org.neo4j.graphalgo.AbstractNodeProjection
 
AbstractNodeProjection.Builder - Class in org.neo4j.graphalgo
 
AbstractNodeProjections - Class in org.neo4j.graphalgo
 
AbstractNodeProjections() - Constructor for class org.neo4j.graphalgo.AbstractNodeProjections
 
AbstractProjections<I extends ElementIdentifier,​P extends ElementProjection> - Class in org.neo4j.graphalgo
 
AbstractProjections() - Constructor for class org.neo4j.graphalgo.AbstractProjections
 
AbstractPropertyMappings - Class in org.neo4j.graphalgo
 
AbstractPropertyMappings() - Constructor for class org.neo4j.graphalgo.AbstractPropertyMappings
 
AbstractPropertyMappings.Builder - Class in org.neo4j.graphalgo
 
AbstractRelationshipProjection - Class in org.neo4j.graphalgo
 
AbstractRelationshipProjection() - Constructor for class org.neo4j.graphalgo.AbstractRelationshipProjection
 
AbstractRelationshipProjection.Builder - Class in org.neo4j.graphalgo
 
AbstractRelationshipProjections - Class in org.neo4j.graphalgo
 
AbstractRelationshipProjections() - Constructor for class org.neo4j.graphalgo.AbstractRelationshipProjections
 
accept(long, double) - Method in interface org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue.Consumer
 
accept(long, long) - Method in interface org.neo4j.graphalgo.api.RelationshipConsumer
Called for every edge that matches a given relation-constraint
accept(long, long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph.ExistsConsumer
 
accept(long, long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph.GetTargetConsumer
 
accept(long, long, double) - Method in interface org.neo4j.graphalgo.api.RelationshipWithPropertyConsumer
Called for every relationship that matches a given relation-constraint
accept(long, long, double) - Method in interface org.neo4j.graphalgo.core.utils.queue.BoundedLongLongPriorityQueue.Consumer
 
accept(long, long, long) - Method in interface org.neo4j.graphalgo.api.IntersectionConsumer
 
accept(GraphCreateConfig.Cases<R>) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
accept(GraphCreateConfig.Cases<R>) - Method in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
accept(GraphCreateConfig.Cases<R>) - Method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
accept(GraphCreateConfig.Cases<R>) - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
accept(SecureTransaction.TxConsumer<E>) - Method in class org.neo4j.graphalgo.core.SecureTransaction
Run some code within a new Transaction under the managed SecurityContext.
accept(Transaction, KernelTransaction) - Method in interface org.neo4j.graphalgo.core.SecureTransaction.TxConsumer
Run some code within a transaction.
accept(Write, long) - Method in interface org.neo4j.graphalgo.core.write.NodePropertyExporter.WriteConsumer
 
accept(KernelTransaction) - Method in class org.neo4j.graphalgo.core.loading.IndexedNodePropertyImporter
 
accept(KernelTransaction) - Method in class org.neo4j.graphalgo.core.loading.NodesScanner
 
accept(KernelTransaction) - Method in class org.neo4j.graphalgo.core.loading.RelationshipsScanner
 
accept(KernelTransaction) - Method in interface org.neo4j.graphalgo.utils.StatementApi.TxConsumer
 
accept(T) - Method in interface org.neo4j.graphalgo.utils.CheckedConsumer
 
acceptInTransaction(StatementApi.TxConsumer) - Method in class org.neo4j.graphalgo.utils.StatementApi
 
add(int) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntSet
 
add(int, double) - Method in class org.neo4j.graphalgo.core.utils.AtomicDoubleArray
add argument to value at index.
add(int, int, double) - Method in class org.neo4j.graphalgo.core.loading.RelationshipPropertiesBatchBuffer
 
add(long) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongSet
 
add(long) - Method in interface org.neo4j.graphalgo.core.utils.mem.AllocationTracker
Add the given number of bytes to the total tracked amount.
add(long) - Method in class org.neo4j.graphalgo.core.utils.mem.InMemoryAllocationTracker
 
add(long) - Method in class org.neo4j.graphalgo.core.utils.mem.KernelAllocationTracker
 
add(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArrayQueue
 
add(long[], int, int, int) - Method in class org.neo4j.graphalgo.core.loading.CompressedLongArray
For memory efficiency, we reuse the values.
add(long[], long[][], int, int, int) - Method in class org.neo4j.graphalgo.core.loading.CompressedLongArray
For memory efficiency, we reuse the values.
add(long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.PagedAtomicDoubleArray
 
add(long, double) - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
add(long, int) - Method in class org.neo4j.graphalgo.core.utils.paged.PagedAtomicIntegerArray
 
add(long, long) - Method in class org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder
 
add(long, long, double) - Method in class org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder
 
add(long, long, double) - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongLongPriorityQueue
 
add(long, long, long) - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
add(long, long, long[]) - Method in class org.neo4j.graphalgo.core.loading.NodesBatchBuffer
 
add(long, long, long, long) - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
add(String, ValueType) - Method in class org.neo4j.graphalgo.beta.pregel.PregelSchema.Builder
 
add(String, ValueType, PregelSchema.Visibility) - Method in class org.neo4j.graphalgo.beta.pregel.PregelSchema.Builder
 
add(String, MemoryEstimation) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a MemoryEstimation as a sub-component to the builder.
add(Stream<T>) - Method in class org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder
 
add(MemoryEstimation) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a MemoryEstimation as a sub-component to the builder.
add(MemoryRange) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
add(HugeLongArray) - Static method in class org.neo4j.graphalgo.core.loading.IdMapBuilder
 
add(T) - Method in class org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder
 
addAll(PrimitiveIntIterator) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntSet
 
addAll(PrimitiveLongIterator) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongSet
 
addComponentsOf(MemoryEstimation) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
 
addFromInternal(long, long) - Method in class org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder
 
addFromInternal(long, long, double) - Method in class org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder
 
addFromInternal(Stream<T>) - Method in class org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder
 
addFromInternal(T) - Method in class org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder
 
additionalJvm() - Static method in class org.neo4j.graphalgo.core.Settings
 
addLabel(NodeLabel) - Method in class org.neo4j.graphalgo.api.schema.NodeSchema.Builder
 
addNode(long, NodeLabel...) - Method in class org.neo4j.graphalgo.core.loading.construction.NodesBuilder
 
addNodeProperty(NodeLabel, String, NodeProperties) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
addNodeProperty(NodeLabel, String, NodeProperties) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
addOptionalMappings(Stream<? extends PropertyMapping>) - Method in class org.neo4j.graphalgo.AbstractPropertyMappings.Builder
 
addOptionalMappings(PropertyMapping...) - Method in class org.neo4j.graphalgo.AbstractPropertyMappings.Builder
 
addProperty(NodeLabel, String, ValueType) - Method in class org.neo4j.graphalgo.api.schema.NodeSchema.Builder
 
addProperty(RelationshipType, String, ValueType) - Method in class org.neo4j.graphalgo.api.schema.RelationshipSchema.Builder
 
addPropertyMappings(PropertyMappings) - Method in class org.neo4j.graphalgo.AbstractNodeProjections
 
addPropertyMappings(PropertyMappings) - Method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
addRelationshipType(RelationshipType) - Method in class org.neo4j.graphalgo.api.schema.RelationshipSchema.Builder
 
addRelationshipType(RelationshipType, Optional<String>, Optional<NumberType>, Relationships) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
addRelationshipType(RelationshipType, Optional<String>, Optional<NumberType>, Relationships) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
address() - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListPageSlice
addTo(long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
Adds (+) the existing value and the provided value at the given index and stored the result into the given index.
addTo(long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
 
addTo(long, int) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Adds (+) the existing value and the provided value at the given index and stored the result into the given index.
addTo(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Adds (+) the existing value and the provided value at the given index and stored the result into the given index.
addTo(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
 
addTo(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray.GrowingBuilder
 
addTo(long, long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongDoubleMap
 
AdjacencyBuilder - Class in org.neo4j.graphalgo.core.loading
 
AdjacencyCompression - Class in org.neo4j.graphalgo.core.loading
 
AdjacencyCursor - Interface in org.neo4j.graphalgo.api
 
adjacencyList() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBuilder
 
AdjacencyList - Interface in org.neo4j.graphalgo.api
 
AdjacencyListAllocator - Interface in org.neo4j.graphalgo.core.loading
 
AdjacencyListBuilder - Interface in org.neo4j.graphalgo.core.loading
 
AdjacencyListBuilderFactory - Interface in org.neo4j.graphalgo.core.loading
 
AdjacencyListPageSlice - Interface in org.neo4j.graphalgo.core.loading
 
adjacencyOffsets() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyOffsets
 
AdjacencyOffsets - Interface in org.neo4j.graphalgo.api
 
AdjacencyOffsetsFactory - Interface in org.neo4j.graphalgo.core.loading
 
adjustedBatchSize(int, int) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
adjustedBatchSize(int, int, int) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
adjustedBatchSize(long, int, long) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
adjustedBatchSize(long, int, long, long) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
adjustedBatchSize(long, long) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
advance(CURSOR, long) - Method in class org.neo4j.graphalgo.core.huge.GraphIntersect
Get the node id greater than or equal (>=) to the provided target.
advance(TransientAdjacencyList.DecompressingCursor, long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraphIntersect
 
aggregation() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
aggregation() - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
aggregation() - Method in class org.neo4j.graphalgo.PropertyMapping
 
Aggregation - Enum in org.neo4j.graphalgo.core
 
AGGREGATION_KEY - Static variable in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
AlgoBaseConfig - Interface in org.neo4j.graphalgo.config
 
algoType() - Method in interface org.neo4j.graphalgo.core.model.Model
 
align(long, int) - Static method in class org.neo4j.graphalgo.core.utils.BitUtil
 
all() - Static method in class org.neo4j.graphalgo.AbstractNodeProjection
 
all() - Static method in class org.neo4j.graphalgo.AbstractNodeProjections
 
all() - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
all() - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
all(String, String) - Static method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
ALL - Static variable in class org.neo4j.graphalgo.AbstractNodeProjections
 
ALL - Static variable in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
ALL - Static variable in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
ALL_NODES - Static variable in class org.neo4j.graphalgo.NodeLabel
 
ALL_NODES_QUERY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
ALL_RELATIONSHIPS - Static variable in class org.neo4j.graphalgo.RelationshipType
 
ALL_RELATIONSHIPS_QUERY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
ALL_RELATIONSHIPS_UNDIRECTED_QUERY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
ALL_UNDIRECTED - Static variable in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
ALL_UNDIRECTED - Static variable in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
allocate(int) - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListAllocator
 
allocateBuffers(int) - Method in class org.neo4j.graphalgo.core.utils.paged.TrackingLongDoubleHashMap
 
AllocationTracker - Interface in org.neo4j.graphalgo.core.utils.mem
 
AllocationTrackerExtensionFactory - Class in org.neo4j.graphalgo.core.utils.mem
 
AllocationTrackerExtensionFactory() - Constructor for class org.neo4j.graphalgo.core.utils.mem.AllocationTrackerExtensionFactory
 
AllocationTrackerExtensionFactory.Dependencies - Interface in org.neo4j.graphalgo.core.utils.mem
 
AllocationTrackerLifecycleAdapter - Class in org.neo4j.graphalgo.core.utils.mem
 
allowSelfLoops() - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
allowUpgrade() - Static method in class org.neo4j.graphalgo.core.Settings
 
allProjections() - Method in class org.neo4j.graphalgo.AbstractProjections
 
allProperties() - Method in class org.neo4j.graphalgo.AbstractProjections
 
allSet() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Returns true iff all bits are set.
and(long, int) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Computes the bit-wise AND (&) of the existing value and the provided value at the given index.
and(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Computes the bit-wise AND (&) of the existing value and the provided value at the given index.
andThen(String, MemoryEstimation, MemoryEstimations.MemoryRangeModifier) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
andThen(RelationshipConsumer) - Method in interface org.neo4j.graphalgo.api.RelationshipConsumer
 
andThen(RelationshipWithPropertyConsumer) - Method in interface org.neo4j.graphalgo.api.RelationshipWithPropertyConsumer
 
andThen(MemoryEstimation, UnaryOperator<MemoryRange>) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
Updates the memory range of given MemoryEstimation by applying a given function.
andThen(MemoryEstimation, MemoryEstimations.MemoryRangeModifier) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
ANY_LABEL - Static variable in interface org.neo4j.graphalgo.core.GraphDimensions
 
ANY_RELATIONSHIP_TYPE - Static variable in interface org.neo4j.graphalgo.core.GraphDimensions
 
api() - Method in interface org.neo4j.graphalgo.api.GraphLoaderContext
 
api() - Method in class org.neo4j.graphalgo.utils.StatementApi
 
apply(long, long) - Method in interface org.neo4j.graphalgo.core.utils.BiLongConsumer
 
apply(GraphCreateConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Rewriter
 
apply(SecureTransaction.TxFunction<T, E>) - Method in class org.neo4j.graphalgo.core.SecureTransaction
Run some code within a new Transaction under the managed SecurityContext.
apply(CheckedFunction<? super T, ? extends R, E>, T) - Static method in class org.neo4j.graphalgo.utils.ExceptionUtil
 
apply(Transaction, KernelTransaction) - Method in interface org.neo4j.graphalgo.core.SecureTransaction.TxFunction
Calculate some result within a new transaction.
apply(KernelTransaction) - Method in class org.neo4j.graphalgo.core.GraphDimensionsReader
 
apply(KernelTransaction) - Method in interface org.neo4j.graphalgo.utils.StatementApi.TxFunction
 
apply(T) - Method in interface org.neo4j.graphalgo.utils.CheckedFunction
 
applyAsBoolean(boolean) - Method in interface org.neo4j.graphalgo.core.utils.Pointer.BooleanUnaryOperator
 
applyDeltaEncoding(LongsRef, Aggregation) - Static method in class org.neo4j.graphalgo.core.loading.AdjacencyCompression
 
applyInTransaction(StatementApi.TxFunction<T>) - Method in class org.neo4j.graphalgo.utils.StatementApi
 
applyRelationshipWeight(double, double) - Method in interface org.neo4j.graphalgo.beta.pregel.PregelComputation
If the input graph is weighted, i.e.
array - Variable in class org.neo4j.graphalgo.core.utils.paged.HugeCursor
a slice of values currently being traversed
ArrayUtil - Class in org.neo4j.graphalgo.core.utils
 
asArray(Iterator<Long>) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
asArray(PrimitiveLongIterator) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
AscendingLongComparator - Class in org.neo4j.graphalgo.core.utils
 
AscendingLongComparator(long[]) - Constructor for class org.neo4j.graphalgo.core.utils.AscendingLongComparator
 
asList(PrimitiveLongIterator) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
Pulls all items from the iterator and puts them into a List, boxing each long.
asLongArray(PrimitiveIntCollection) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
 
asNodeProperties() - Method in interface org.neo4j.graphalgo.core.utils.paged.dss.DisjointSetStruct
Wraps the DisjointSetStruct in an LongNodeProperties interface
asNodeProperties() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
 
asNodeProperties() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
 
asNodeProperties() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
 
asNodeProperties() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
 
asNodeProperties() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
 
asNodeProperties() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
 
assertNoProjectionsOrExplicitProperties(CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
assertRunning() - Method in interface org.neo4j.graphalgo.core.utils.TerminationFlag
 
AtomicDoubleArray - Class in org.neo4j.graphalgo.core.utils
Atomic double Array implementation
AtomicDoubleArray(int) - Constructor for class org.neo4j.graphalgo.core.utils.AtomicDoubleArray
Create a new AtomicDoubleArray
authEnabled() - Static method in class org.neo4j.graphalgo.core.Settings
 
AutoCloseableThreadLocal<T extends java.lang.AutoCloseable> - Class in org.neo4j.graphalgo.utils
 
AutoCloseableThreadLocal(Supplier<T>, Optional<Consumer<? super T>>) - Constructor for class org.neo4j.graphalgo.utils.AutoCloseableThreadLocal
 
availableNodeLabels() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
availableNodeLabels() - Method in interface org.neo4j.graphalgo.api.Graph
 
availableNodeLabels() - Method in interface org.neo4j.graphalgo.api.NodeMapping
 
availableNodeLabels() - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
availableNodeLabels() - Method in class org.neo4j.graphalgo.core.loading.IdMap
 
availableNodeProperties() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
availableNodeProperties() - Method in interface org.neo4j.graphalgo.api.NodePropertyContainer
 
availableNodeProperties() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
availableNodeProperties() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
averageDegree() - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
averageDegree() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
awaitTermination(Collection<Future<?>>) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
awaitTerminations(Queue<Future<?>>) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 

B

base - Variable in class org.neo4j.graphalgo.core.utils.paged.HugeCursor
the base for the index to get the global index
BaseConfig - Interface in org.neo4j.graphalgo.config
 
batch() - Method in class org.neo4j.graphalgo.core.loading.RecordsBatchBuffer
 
BATCH_ENTRY_SHIFT_SIZE - Static variable in class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
BATCH_ENTRY_SIZE - Static variable in class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
BatchingProgressLogger - Class in org.neo4j.graphalgo.core.utils
 
BatchingProgressLogger(Log, long, long, String, int) - Constructor for class org.neo4j.graphalgo.core.utils.BatchingProgressLogger
 
BatchingProgressLogger(Log, long, String, int) - Constructor for class org.neo4j.graphalgo.core.utils.BatchingProgressLogger
 
batchIterables(int) - Method in interface org.neo4j.graphalgo.api.BatchNodeIterable
 
batchIterables(int) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
batchIterables(int) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
batchIterables(int) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
batchIterables(int) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
batchIterables(int) - Method in class org.neo4j.graphalgo.core.loading.IdMap
 
BatchNodeIterable - Interface in org.neo4j.graphalgo.api
Iterate over each graph-nodeId in batches.
BatchNodeIterable.IdIterable - Class in org.neo4j.graphalgo.api
 
BatchNodeIterable.IdIterator - Class in org.neo4j.graphalgo.api
 
batchSize() - Method in interface org.neo4j.graphalgo.config.BatchSizeConfig
 
batchSize() - Method in interface org.neo4j.graphalgo.core.utils.export.GraphStoreExportConfig
 
BatchSizeConfig - Interface in org.neo4j.graphalgo.config
 
BiLongConsumer - Interface in org.neo4j.graphalgo.core.utils
 
binaryLookup(long, long[]) - Static method in class org.neo4j.graphalgo.core.utils.ArrayUtil
Find the index where (ids[idx] <= id) && (ids[idx + 1] > id).
binarySearch(int[], int, int) - Static method in class org.neo4j.graphalgo.core.utils.ArrayUtil
 
binarySearch(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Find the index where (values[idx] <= searchValue) && (values[idx + 1] > searchValue).
binarySearchIndex(int[], int, int) - Static method in class org.neo4j.graphalgo.core.utils.ArrayUtil
 
BitUtil - Class in org.neo4j.graphalgo.core.utils
 
boltEnabled() - Static method in class org.neo4j.graphalgo.core.Settings
 
boltListenAddress() - Static method in class org.neo4j.graphalgo.core.Settings
 
BoolPointer(boolean) - Constructor for class org.neo4j.graphalgo.core.utils.Pointer.BoolPointer
 
BoundedLongLongPriorityQueue - Class in org.neo4j.graphalgo.core.utils.queue
 
BoundedLongLongPriorityQueue.Consumer - Interface in org.neo4j.graphalgo.core.utils.queue
 
BoundedLongPriorityQueue - Class in org.neo4j.graphalgo.core.utils.queue
 
BoundedLongPriorityQueue.Consumer - Interface in org.neo4j.graphalgo.core.utils.queue
 
bufferSize() - Method in interface org.neo4j.graphalgo.core.loading.StoreScanner.ScanCursor
 
build() - Method in class org.neo4j.graphalgo.AbstractNodeProjection.Builder
 
build() - Method in class org.neo4j.graphalgo.AbstractPropertyMappings.Builder
 
build() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjection.Builder
 
build() - Method in class org.neo4j.graphalgo.api.GraphStoreFactory
 
build() - Method in class org.neo4j.graphalgo.beta.pregel.PregelSchema.Builder
 
build() - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListBuilder
 
build() - Method in class org.neo4j.graphalgo.core.loading.construction.NodesBuilder
 
build() - Method in class org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder
 
build() - Method in class org.neo4j.graphalgo.core.loading.CypherFactory
 
build() - Method in class org.neo4j.graphalgo.core.loading.NativeFactory
 
build() - Method in class org.neo4j.graphalgo.core.loading.NativeNodePropertyImporter.Builder
 
build() - Method in class org.neo4j.graphalgo.core.loading.nodeproperties.NodePropertiesFromStoreBuilder
 
build() - Method in class org.neo4j.graphalgo.core.loading.ScanningRecordsImporter
 
build() - Method in class org.neo4j.graphalgo.core.loading.ScanningRelationshipsImporter
 
build() - Method in class org.neo4j.graphalgo.core.loading.TransientAdjacencyListBuilder
 
build() - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
 
build() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray.Builder
 
build() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray.GrowingBuilder
 
build() - Method in class org.neo4j.graphalgo.core.write.ExporterBuilder
 
build() - Method in class org.neo4j.graphalgo.core.write.NodePropertyExporter.Builder
 
build() - Method in class org.neo4j.graphalgo.core.write.RelationshipExporter.Builder
 
build(HugeLongArrayBuilder, Map<NodeLabel, HugeAtomicBitSet>, long, int, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.loading.IdMapBuilder
 
builder() - Static method in class org.neo4j.graphalgo.AbstractNodeProjection
 
builder() - Static method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
builder() - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
builder() - Static method in interface org.neo4j.graphalgo.api.NodePropertyStore
 
builder() - Static method in interface org.neo4j.graphalgo.api.RelationshipPropertyStore
 
builder() - Static method in interface org.neo4j.graphalgo.api.schema.NodeSchema
 
builder() - Static method in interface org.neo4j.graphalgo.api.schema.RelationshipSchema
 
builder() - Static method in class org.neo4j.graphalgo.core.loading.NativeNodePropertyImporter
 
builder() - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
Creates a new MemoryEstimations.Builder with an empty description.
builder(Class<?>) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
Creates a new MemoryEstimations.Builder from the given class type.
builder(String) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
Creates a new MemoryEstimations.Builder using the given description.
builder(String, Class<?>) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
Creates a new MemoryEstimations.Builder using the given description and class type.
builder(SecureTransaction, IdMapping, TerminationFlag) - Static method in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
builder(GraphDatabaseService, IdMapping, TerminationFlag) - Static method in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
Builder() - Constructor for class org.neo4j.graphalgo.api.NodePropertyStore.Builder
 
Builder() - Constructor for class org.neo4j.graphalgo.api.RelationshipPropertyStore.Builder
 
Builder() - Constructor for class org.neo4j.graphalgo.api.schema.NodeSchema.Builder
 
Builder() - Constructor for class org.neo4j.graphalgo.api.schema.RelationshipSchema.Builder
 
Builder() - Constructor for class org.neo4j.graphalgo.beta.pregel.PregelSchema.Builder
 
builderFactory(AllocationTracker) - Static method in class org.neo4j.graphalgo.core.loading.TransientAdjacencyListBuilder
 
builders() - Method in interface org.neo4j.graphalgo.api.GraphStoreFactory.RelationshipImportResult
 
bulkNext(StoreScanner.RecordConsumer<Reference>) - Method in interface org.neo4j.graphalgo.core.loading.StoreScanner.ScanCursor
 
bulkSize() - Method in interface org.neo4j.graphalgo.core.loading.StoreScanner.ScanCursor
 
BYTES_OBJECT_REF - Static variable in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
bytesPerPage() - Method in class org.neo4j.graphalgo.core.utils.paged.PageAllocator
 
bytesWritten(int) - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListPageSlice
Notify that this many bytes have been written to the AdjacencyListPageSlice.page().

C

calculateEstimates(CompatPropertySizeCalculator) - Method in class org.neo4j.graphalgo.core.utils.export.GraphStoreInput
 
call() - Method in class org.neo4j.graphalgo.core.utils.StatementFunction
 
call(Log) - Method in class org.neo4j.graphalgo.core.loading.ScanningRecordsImporter
 
camelCase() - Method in enum org.neo4j.graphalgo.beta.pregel.annotation.GDSMode
 
canRelease(boolean) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
canRelease(boolean) - Method in interface org.neo4j.graphalgo.api.Graph
 
canRelease(boolean) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
canRelease(boolean) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
canRelease(boolean) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
canRelease(boolean) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
canRunInParallel(ExecutorService) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
capacity() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Returns the number of bits this bitset can hold.
capacity() - Method in class org.neo4j.graphalgo.core.utils.paged.PagedDataStructure
Return the capacity of this data structure.
capacityFor(int, int) - Static method in class org.neo4j.graphalgo.core.utils.paged.PageUtil
 
cardinality() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Returns the number of set bits in the bit set.
cas(long, int, int) - Method in class org.neo4j.graphalgo.core.utils.paged.PagedAtomicIntegerArray
 
castOrThrow(Class<U>) - Static method in class org.neo4j.graphalgo.core.utils.GenericUtil
 
castOrThrow(T, Class<U>) - Static method in class org.neo4j.graphalgo.core.utils.GenericUtil
 
ceilDiv(int, int) - Static method in class org.neo4j.graphalgo.core.utils.BitUtil
 
ceilDiv(long, long) - Static method in class org.neo4j.graphalgo.core.utils.BitUtil
 
chain(T, T) - Static method in class org.neo4j.graphalgo.utils.ExceptionUtil
Adds the current exception to the initial exception as suppressed.
checkedAccept(T) - Method in interface org.neo4j.graphalgo.utils.CheckedConsumer
 
checkedApply(T) - Method in interface org.neo4j.graphalgo.utils.CheckedFunction
 
CheckedConsumer<T,​E extends java.lang.Exception> - Interface in org.neo4j.graphalgo.utils
 
CheckedFunction<T,​R,​E extends java.lang.Exception> - Interface in org.neo4j.graphalgo.utils
 
checkedGet() - Method in interface org.neo4j.graphalgo.utils.CheckedSupplier
 
checkedRun() - Method in interface org.neo4j.graphalgo.utils.CheckedRunnable
 
CheckedRunnable<E extends java.lang.Exception> - Interface in org.neo4j.graphalgo.utils
 
CheckedSupplier<T,​E extends java.lang.Exception> - Interface in org.neo4j.graphalgo.utils
 
clear() - Method in class org.neo4j.graphalgo.core.utils.AtomicDoubleArray
set all elements to 0
clear() - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveCollection
 
clear() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntStack
 
clear() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Resets all bits in the bit set.
clear() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
 
clear() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
 
clear() - Method in class org.neo4j.graphalgo.core.utils.paged.PagedLongStack
 
clear(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Resets the bit at the given index.
cloneIdMapping() - Method in interface org.neo4j.graphalgo.api.IdMapping
 
close() - Method in interface org.neo4j.graphalgo.api.AdjacencyCursor
 
close() - Method in interface org.neo4j.graphalgo.api.AdjacencyList
 
close() - Method in interface org.neo4j.graphalgo.api.AdjacencyOffsets
 
close() - Method in interface org.neo4j.graphalgo.api.PropertyCursor
 
close() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyCursor
 
close() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyList
 
close() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyOffsets
 
close() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
close() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList.Cursor
 
close() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList.DecompressingCursor
 
close() - Method in class org.neo4j.graphalgo.core.huge.TransientFilteredAdjacencyOffsets
 
close() - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListAllocator
 
close() - Method in interface org.neo4j.graphalgo.core.loading.StoreScanner
 
close() - Method in interface org.neo4j.graphalgo.core.loading.StoreScanner.ScanCursor
 
close() - Method in class org.neo4j.graphalgo.core.SecureTransaction
Closing this SecureTransaction only has an effect if it owns a top-level Transaction, in which case Transaction.close() will be called, without calling Transaction.commit().
close() - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveCollection
Free any attached resources.
close() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntStack
 
close() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongResourceFilteringIterator
 
close() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeCursor
Releases the reference to the underlying array so that it might be garbage collected.
close() - Method in class org.neo4j.graphalgo.core.utils.ProgressTimer
 
close() - Method in interface org.neo4j.graphalgo.core.utils.RenamesCurrentThread.Revert
 
close() - Method in class org.neo4j.graphalgo.utils.AutoCloseableThreadLocal
 
close() - Method in class org.neo4j.graphalgo.utils.CloseableThreadLocal
 
CloseableThreadLocal<T> - Class in org.neo4j.graphalgo.utils
Java's builtin ThreadLocal has a serious flaw: it can take an arbitrarily long amount of time to dereference the things you had stored in it, even once the ThreadLocal instance itself is no longer referenced.
CloseableThreadLocal() - Constructor for class org.neo4j.graphalgo.utils.CloseableThreadLocal
 
CollectionUtil - Class in org.neo4j.graphalgo.core.utils
 
combineIntInt(int, int) - Static method in class org.neo4j.graphalgo.core.utils.RawValues
shifts head into the most significant 4 bytes of the long and places the tail in the least significant bytes
combineIntInt(Direction, int, int) - Static method in class org.neo4j.graphalgo.core.utils.RawValues
 
communityCount(long, LongUnaryOperator, ExecutorService, int, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.statistics.CommunityStatistics
 
communityCount(HugeSparseLongArray, ExecutorService, int) - Static method in class org.neo4j.graphalgo.core.utils.statistics.CommunityStatistics
 
communityCountAndHistogram(long, LongUnaryOperator, ExecutorService, int, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.statistics.CommunityStatistics
 
communityCountAndHistogram(HugeSparseLongArray, ExecutorService, int) - Static method in class org.neo4j.graphalgo.core.utils.statistics.CommunityStatistics
 
communitySizes(long, LongUnaryOperator, ExecutorService, int, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.statistics.CommunityStatistics
 
CommunityStatistics - Class in org.neo4j.graphalgo.core.utils.statistics
 
CommunityStatistics.CommunityCountAndHistogram - Interface in org.neo4j.graphalgo.core.utils.statistics
 
compare(int, int) - Method in class org.neo4j.graphalgo.core.utils.AscendingLongComparator
 
compareAndExchange(long, double, double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
Atomically sets the element at position index to the given updated value if the current value, referred to as the witness value, == the expected value.
compareAndExchange(long, long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
Atomically sets the element at position index to the given updated value if the current value, referred to as the witness value, == the expected value.
compareAndSet(long, double, double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
Atomically sets the element at position index to the given updated value if the current value == the expected value.
compareAndSet(long, long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
Atomically sets the element at position index to the given updated value if the current value == the expected value.
compareWithDefaultThreshold(double, double) - Static method in class org.neo4j.graphalgo.core.utils.DoubleUtil
 
compareWithThreshold(double, double, double) - Static method in class org.neo4j.graphalgo.core.utils.DoubleUtil
 
componentCount() - Method in interface org.neo4j.graphalgo.core.utils.statistics.CommunityStatistics.CommunityCountAndHistogram
 
components() - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryEstimation
 
components() - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryTree
 
CompositeAdjacencyCursor - Class in org.neo4j.graphalgo.core.huge
 
CompositeAdjacencyList - Class in org.neo4j.graphalgo.core.huge
 
CompositeAdjacencyOffsets - Class in org.neo4j.graphalgo.core.huge
 
CompositeNodeScan - Class in org.neo4j.graphalgo.core.loading
 
CompositeNodeScan(List<Scan<NodeLabelIndexCursor>>) - Constructor for class org.neo4j.graphalgo.core.loading.CompositeNodeScan
 
CompositeRelationshipsBatchBuffer - Class in org.neo4j.graphalgo.core.loading
 
compress(LongsRef, byte[]) - Static method in class org.neo4j.graphalgo.core.loading.AdjacencyCompression
 
compressDouble(double, byte[]) - Method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Compress a single double.
compressDouble(long, byte[], int) - Method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Compress the double from its bit representation and write result into out.
compressDouble(long, byte[], int) - Method in class org.neo4j.graphalgo.core.loading.NoopDoubleCodec
 
compressDoubles(double[], int, byte[]) - Method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Compress many doubles in one call.
compressed() - Method in interface org.neo4j.graphalgo.core.loading.DoubleCodec.CompressionInfo
 
CompressedLongArray - Class in org.neo4j.graphalgo.core.loading
 
CompressedLongArray(AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.loading.CompressedLongArray
 
CompressedLongArray(AllocationTracker, int) - Constructor for class org.neo4j.graphalgo.core.loading.CompressedLongArray
 
compressedMemoryEstimation(boolean) - Static method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
compressedMemoryEstimation(long, long) - Static method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
compressedMemoryEstimation(RelationshipType, boolean) - Static method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
compressedSize() - Method in interface org.neo4j.graphalgo.core.loading.DoubleCodec.CompressionInfo
 
compressedSize(byte[], int) - Method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Return the number of bytes used to compress the current value.
compressedSize(byte[], int) - Method in class org.neo4j.graphalgo.core.loading.NoopDoubleCodec
 
compressedType() - Method in interface org.neo4j.graphalgo.core.loading.DoubleCodec.CompressionInfo
 
compressing(RelationshipsBuilder, int, int, AllocationTracker, LongAdder, int[], double[], Aggregation[], boolean) - Static method in class org.neo4j.graphalgo.core.loading.AdjacencyBuilder
 
compressionDescription() - Method in interface org.neo4j.graphalgo.core.loading.DoubleCodec.CompressionInfo
 
compute(PregelContext.ComputeContext<C>, Pregel.Messages) - Method in interface org.neo4j.graphalgo.beta.pregel.PregelComputation
The compute method is called individually for each node in every superstep as long as the node receives messages or has not voted to halt yet.
concat(Iterable<PrimitiveLongIterator>) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
concat(Iterable<PrimitiveLongResourceIterator>) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongResourceCollections
 
concat(Iterator<PrimitiveIntIterator>) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
 
concat(PrimitiveLongIterator...) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
concat(PrimitiveLongResourceIterator...) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongResourceCollections
 
concurrency - Variable in class org.neo4j.graphalgo.core.loading.ScanningRecordsImporter
 
concurrency - Variable in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
concurrency() - Method in interface org.neo4j.graphalgo.config.ConcurrencyConfig
 
concurrency() - Method in interface org.neo4j.graphalgo.config.GraphStreamRelationshipPropertiesConfig
 
CONCURRENCY_KEY - Static variable in interface org.neo4j.graphalgo.config.ConcurrencyConfig
 
CONCURRENCY_LIMITATION - Static variable in interface org.neo4j.graphalgo.config.ConcurrencyConfig
 
ConcurrencyConfig - Interface in org.neo4j.graphalgo.config
 
concurrentCopy() - Method in class org.neo4j.graphalgo.api.CSRFilterGraph
 
concurrentCopy() - Method in interface org.neo4j.graphalgo.api.CSRGraph
 
concurrentCopy() - Method in interface org.neo4j.graphalgo.api.Graph
 
concurrentCopy() - Method in interface org.neo4j.graphalgo.api.RelationshipIterator
 
concurrentCopy() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
concurrentCopy() - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
concurrentCopy() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
config() - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext
Allows access to the user-defined Pregel configuration.
config() - Method in interface org.neo4j.graphalgo.core.loading.GraphStoreWithConfig
 
configKeys() - Method in interface org.neo4j.graphalgo.config.BaseConfig
 
ConfigurableSeedConfig - Interface in org.neo4j.graphalgo.config
 
consecutiveIds() - Method in interface org.neo4j.graphalgo.config.ConsecutiveIdsConfig
 
ConsecutiveIdsConfig - Interface in org.neo4j.graphalgo.config
 
ConsecutiveLongNodeProperties - Class in org.neo4j.graphalgo.api.nodeproperties
 
ConsecutiveLongNodeProperties(LongNodeProperties, long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.api.nodeproperties.ConsecutiveLongNodeProperties
 
consume(PrimitiveIntIterator, IntConsumer) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
 
consumer(CheckedConsumer<T, E>) - Static method in interface org.neo4j.graphalgo.utils.CheckedConsumer
 
contains(int) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntSet
 
contains(int[], int) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
 
contains(long) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
contains(long) - Method in interface org.neo4j.graphalgo.api.IdMapping
Returns true iff the nodeId is mapped, otherwise false.
contains(long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
contains(long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
contains(long) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
contains(long) - Method in class org.neo4j.graphalgo.core.loading.IdMap
 
contains(long) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongSet
 
contains(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray
 
contains(long) - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
containsKey(String) - Method in interface org.neo4j.graphalgo.api.NodePropertyStore
 
containsKey(String) - Method in interface org.neo4j.graphalgo.api.RelationshipPropertyStore
 
containsOnlyAllNodesLabel() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
containsOnlyAllNodesLabel() - Method in interface org.neo4j.graphalgo.api.NodeMapping
 
context() - Method in interface org.neo4j.graphalgo.core.GraphLoader
 
Converters - Interface in org.neo4j.graphalgo.core.heavyweight
Warning: These conversions are not safe but will fail for very large graphs.
Converters.IntIntDoublePredicate - Interface in org.neo4j.graphalgo.core.heavyweight
 
copyFrom(CURSOR, CURSOR) - Method in class org.neo4j.graphalgo.core.huge.GraphIntersect
 
copyFrom(LongsRef, CompressedLongArray) - Static method in class org.neo4j.graphalgo.core.loading.AdjacencyCompression
 
copyFrom(TransientAdjacencyList.DecompressingCursor, TransientAdjacencyList.DecompressingCursor) - Method in class org.neo4j.graphalgo.core.huge.HugeGraphIntersect
 
copyOf(long, AllocationTracker) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
Creates a copy of the given array.
copyOf(long, AllocationTracker) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Creates a copy of the given array.
copyOf(long, AllocationTracker) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Creates a copy of the given array.
copyOf(long, AllocationTracker) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
Creates a copy of the given array.
copyTo(HugeDoubleArray, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
Copies the content of this array into the target array.
copyTo(HugeIntArray, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Copies the content of this array into the target array.
copyTo(HugeLongArray, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Copies the content of this array into the target array.
copyTo(HugeObjectArray<T>, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
Copies the content of this array into the target array.
cosine(double[], double[], int) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
cosine(float[], float[], int) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
cosines(double[], double[][], int) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
cosineSquare(double[], double[], int) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
cosineSquareScalar(double, double) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
cosineSquareSkip(double[], double[], int, double) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
count(PrimitiveLongIterator) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
COUNT - org.neo4j.graphalgo.core.Aggregation
 
counts() - Method in interface org.neo4j.graphalgo.api.GraphStoreFactory.RelationshipImportResult
 
create() - Static method in interface org.neo4j.graphalgo.core.utils.mem.AllocationTracker
 
create() - Static method in class org.neo4j.graphalgo.core.utils.mem.InMemoryAllocationTracker
 
create(int) - Method in interface org.neo4j.graphalgo.core.loading.InternalImporter.CreateScanner
 
create(int[]) - Static method in class org.neo4j.graphalgo.core.loading.NodeScannerFactory
 
create(long, long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray.Builder
 
create(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
 
create(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray.Builder
 
create(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray.GrowingBuilder
 
create(Map<NodeLabel, NodeProjection>) - Static method in class org.neo4j.graphalgo.AbstractNodeProjections
 
create(Graph, CONFIG, PregelComputation<CONFIG>, ExecutorService, AllocationTracker) - Static method in class org.neo4j.graphalgo.beta.pregel.Pregel
 
create(AllocationTrackerAdapter) - Static method in class org.neo4j.graphalgo.core.utils.mem.KernelAllocationTracker
 
create(MemoryTrackerProxy) - Static method in interface org.neo4j.graphalgo.core.utils.mem.AllocationTracker
 
create(IdMap, Relationships, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.loading.construction.GraphFactory
 
create(IdMap, GraphSchema, Map<String, NodeProperties>, Relationships.Topology, Optional<Relationships.Properties>, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
create(IdMap, NodeSchema, Map<String, NodeProperties>, Relationships, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.loading.construction.GraphFactory
 
create(AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray.GrowingBuilder
 
createConfig() - Method in interface org.neo4j.graphalgo.core.GraphLoader
 
createDefaultSingleThreadPool() - Static method in class org.neo4j.graphalgo.core.concurrency.Pools
 
createEmptyScanner() - Static method in class org.neo4j.graphalgo.core.loading.InternalImporter
 
createGraphStore(IdsAndProperties, GraphStoreFactory.RelationshipImportResult, AllocationTracker, GraphDimensions) - Method in class org.neo4j.graphalgo.api.CSRGraphStoreFactory
 
createImplicit(String, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
creationTime() - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
creationTime() - Method in interface org.neo4j.graphalgo.core.model.Model
 
creator(long, ImportSizing, StoreScanner<RelationshipReference>) - Method in class org.neo4j.graphalgo.core.loading.ScanningRelationshipsImporter
 
creator(long, ImportSizing, StoreScanner<Record>) - Method in class org.neo4j.graphalgo.core.loading.ScanningRecordsImporter
 
CSRFilterGraph - Class in org.neo4j.graphalgo.api
 
CSRFilterGraph(CSRGraph) - Constructor for class org.neo4j.graphalgo.api.CSRFilterGraph
 
CSRGraph - Interface in org.neo4j.graphalgo.api
A subtype of Graph which exposes datastructures specific to the csr graph representation such as AdjacencyList and AdjacencyOffsets.
CSRGraphStore - Class in org.neo4j.graphalgo.core.loading
 
CSRGraphStoreFactory<CONFIG extends GraphCreateConfig> - Class in org.neo4j.graphalgo.api
 
CSRGraphStoreFactory(CONFIG, GraphLoaderContext, GraphDimensions) - Constructor for class org.neo4j.graphalgo.api.CSRGraphStoreFactory
 
currentIterator() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections.PrimitiveIntConcatingIterator
 
currentIterator() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongConcatingIterator
 
cursor(long) - Method in interface org.neo4j.graphalgo.api.AdjacencyList
 
cursor(long) - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyList
 
cursor(long) - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
cursor(long, CURSOR) - Method in class org.neo4j.graphalgo.core.huge.GraphIntersect
 
cursor(long, TransientAdjacencyList.DecompressingCursor) - Method in class org.neo4j.graphalgo.core.huge.HugeGraphIntersect
 
cursor(TransientAdjacencyList.Cursor, long) - Static method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
Initialise the given cursor with the given offset
cursors() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyCursor
 
cypher(GraphCreateFromCypherConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Cases
 
cypher(GraphCreateFromCypherConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Rewriter
 
cypher(GraphCreateFromCypherConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Visitor
 
CYPHER_QUERY_KEY - Static variable in class org.neo4j.graphalgo.core.ProcedureConstants
 
CypherFactory - Class in org.neo4j.graphalgo.core.loading
 
CypherFactory(GraphCreateFromCypherConfig, GraphLoaderContext) - Constructor for class org.neo4j.graphalgo.core.loading.CypherFactory
 
CypherFactory(GraphCreateFromCypherConfig, GraphLoaderContext, GraphDimensions) - Constructor for class org.neo4j.graphalgo.core.loading.CypherFactory
 
cypherName() - Method in enum org.neo4j.graphalgo.api.nodeproperties.ValueType
 
CypherNodePropertyImporter - Class in org.neo4j.graphalgo.core.loading
 
CypherNodePropertyImporter(Collection<String>, IntObjectMap<List<NodeLabel>>, long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.loading.CypherNodePropertyImporter
 

D

data() - Method in interface org.neo4j.graphalgo.core.model.Model
 
databaseId() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
databaseId() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
db() - Method in class org.neo4j.graphalgo.core.SecureTransaction
Returns the GraphDatabaseService provided to this instance.
DB_NAME_KEY - Static variable in interface org.neo4j.graphalgo.core.utils.export.GraphStoreExportConfig
 
dbName() - Method in interface org.neo4j.graphalgo.core.utils.export.GraphStoreExportConfig
 
dbTemporalTimezone() - Static method in class org.neo4j.graphalgo.core.Settings
 
decompressDouble(byte[], int) - Method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Decompress a single double from the given byte array and return it.
decompressDouble(byte[], int, MutableDouble) - Method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Decompress a single double from the given byte array and write the result into out.
decompressDouble(byte[], int, MutableDouble) - Method in class org.neo4j.graphalgo.core.loading.NoopDoubleCodec
 
decompressDoubles(byte[], int) - Method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Decompress may doubles in one call.
decompressed() - Method in interface org.neo4j.graphalgo.core.loading.DoubleCodec.CompressionInfo
 
decompressingCursor(long) - Method in interface org.neo4j.graphalgo.api.AdjacencyList
Get a new cursor initialised on the given offset
decompressingCursor(long) - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyList
 
decompressingCursor(long) - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
decompressingCursor(TransientAdjacencyList.DecompressingCursor, long) - Static method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
Initialise the given cursor with the given offset
deduplicate(int[]) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
Deduplicates values in the values array.
deduplicate(long[]) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
Deduplicates values in the sorted values array.
DEFAULT - org.neo4j.graphalgo.core.Aggregation
 
DEFAULT - Static variable in class org.neo4j.graphalgo.api.DefaultValue
 
DEFAULT - Static variable in class org.neo4j.graphalgo.core.concurrency.Pools
 
DEFAULT_BATCH_SIZE - Static variable in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
DEFAULT_CONCURRENCY - Static variable in interface org.neo4j.graphalgo.config.ConcurrencyConfig
 
DEFAULT_DIRECTION - Static variable in class org.neo4j.graphalgo.core.utils.Directions
 
DEFAULT_PREFETCH_SIZE - Static variable in interface org.neo4j.graphalgo.core.loading.StoreScanner
 
DEFAULT_SINGLE_THREAD_POOL - Static variable in class org.neo4j.graphalgo.core.concurrency.Pools
 
DEFAULT_THRESHOLD - Static variable in class org.neo4j.graphalgo.core.utils.DoubleUtil
 
DEFAULT_VALUE_KEY - Static variable in class org.neo4j.graphalgo.PropertyMapping
 
defaultDatabaseName() - Static method in class org.neo4j.graphalgo.core.Settings
 
defaultPropertyValue() - Method in interface org.neo4j.graphalgo.api.Relationships.Properties
 
defaultRelationshipType() - Method in interface org.neo4j.graphalgo.core.utils.export.GraphStoreExportConfig
 
defaultValue() - Method in class org.neo4j.graphalgo.PropertyMapping
 
DefaultValue - Class in org.neo4j.graphalgo.api
 
degree() - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext
Returns the degree (number of relationships) of the currently processed node.
degree(long) - Method in interface org.neo4j.graphalgo.api.AdjacencyList
 
degree(long) - Method in interface org.neo4j.graphalgo.api.Degrees
 
degree(long) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
degree(long) - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyList
 
degree(long) - Method in class org.neo4j.graphalgo.core.huge.GraphIntersect
 
degree(long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
degree(long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraphIntersect
 
degree(long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
degree(long) - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
degree(long) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
degreeDistribution(Graph) - Static method in class org.neo4j.graphalgo.api.GraphStatistics
 
degreePartition(Graph, long) - Static method in class org.neo4j.graphalgo.core.utils.partition.PartitionUtils
 
degreePartition(PrimitiveLongIterator, Degrees, long) - Static method in class org.neo4j.graphalgo.core.utils.partition.PartitionUtils
 
degreeProducer(long, long, Random) - Method in enum org.neo4j.graphalgo.beta.generator.RelationshipDistribution
Produces a unary function which accepts a node id parameter and returns the number of outgoing relationships that should be generated for this node.
Degrees - Interface in org.neo4j.graphalgo.api
The Degree interface is intended to return the degree of a given node.
degreeWithoutParallelRelationships(long) - Method in interface org.neo4j.graphalgo.api.Degrees
Much slower than just degree() because it may have to look up all relationships.
degreeWithoutParallelRelationships(long) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
degreeWithoutParallelRelationships(long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
degreeWithoutParallelRelationships(long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
degreeWithoutParallelRelationships(long) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
deletedProperties() - Method in interface org.neo4j.graphalgo.core.loading.DeletionResult
 
deletedRelationships() - Method in interface org.neo4j.graphalgo.core.loading.DeletionResult
 
deleteRelationships(RelationshipType) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
deleteRelationships(RelationshipType) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
DeleteRelationshipsConfig - Interface in org.neo4j.graphalgo.config
 
DeletionResult - Interface in org.neo4j.graphalgo.core.loading
 
density(long, long) - Static method in class org.neo4j.graphalgo.api.GraphStatistics
 
density(Graph) - Static method in class org.neo4j.graphalgo.api.GraphStatistics
 
describeCompressedValue(byte[], int, double) - Method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Return debug info about how the current value is compressed.
describeCompressedValue(byte[], int, double) - Method in class org.neo4j.graphalgo.core.loading.NoopDoubleCodec
 
describeCompression(int) - Method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Return some string description on how the data is compressed.
describeCompression(int) - Method in class org.neo4j.graphalgo.core.loading.NoopDoubleCodec
 
description() - Method in annotation type org.neo4j.graphalgo.beta.pregel.annotation.PregelProcedure
A description of the procedure that can be accessed via Cypher.
description() - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryEstimation
 
description() - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryTree
 
didConverge() - Method in interface org.neo4j.graphalgo.beta.pregel.Pregel.PregelResult
 
dimensions - Variable in class org.neo4j.graphalgo.api.GraphStoreFactory
 
dimensions - Variable in class org.neo4j.graphalgo.core.loading.ScanningRecordsImporter
 
dimensions() - Method in class org.neo4j.graphalgo.api.GraphStoreFactory
 
dimensions() - Method in interface org.neo4j.graphalgo.api.GraphStoreFactory.ImportResult
 
dimensions() - Method in interface org.neo4j.graphalgo.api.GraphStoreFactory.RelationshipImportResult
 
dimensions(GraphDimensions) - Method in class org.neo4j.graphalgo.core.loading.NativeNodePropertyImporter.Builder
 
DIRECTION_KEY - Static variable in class org.neo4j.graphalgo.core.ProcedureConstants
 
Directions - Class in org.neo4j.graphalgo.core.utils
Utility class for converting string representation used in cypher queries to neo4j kernel api Direction type.
Directions() - Constructor for class org.neo4j.graphalgo.core.utils.Directions
 
DisjointSetStruct - Interface in org.neo4j.graphalgo.core.utils.paged.dss
Disjoint-set-struct is a data structure that keeps track of a set of elements partitioned into a number of disjoint (non-overlapping) subsets.
DistributionHelper - Class in org.neo4j.graphalgo.core.utils.statistics
 
DOUBLE - org.neo4j.graphalgo.api.nodeproperties.ValueType
 
DOUBLE_ARRAY - org.neo4j.graphalgo.api.nodeproperties.ValueType
 
DOUBLE_DEFAULT_FALLBACK - Static variable in class org.neo4j.graphalgo.api.DefaultValue
 
DoubleArrayNodeProperties - Interface in org.neo4j.graphalgo.api.nodeproperties
 
doubleArrayNodeValue(String) - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext.ComputeContext
Returns the node value for the given node schema key.
doubleArrayProperties(String) - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.CompositeNodeValue
 
doubleArrayValue() - Method in class org.neo4j.graphalgo.api.DefaultValue
 
doubleArrayValue(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.DoubleArrayNodeProperties
 
doubleArrayValue(long) - Method in interface org.neo4j.graphalgo.api.NodeProperties
 
doubleArrayValue(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.FloatArrayNodeProperties
 
doubleArrayValue(long) - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
doubleArrayValue(long) - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
doubleArrayValue(String, long) - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.CompositeNodeValue
 
DoubleCodec - Class in org.neo4j.graphalgo.core.loading
A class for compressing and decompressing doubles.
DoubleCodec() - Constructor for class org.neo4j.graphalgo.core.loading.DoubleCodec
 
DoubleCodec.CompressionInfo - Interface in org.neo4j.graphalgo.core.loading
 
DoubleNodeProperties - Interface in org.neo4j.graphalgo.api.nodeproperties
 
DoubleNodePropertiesBuilder - Class in org.neo4j.graphalgo.core.loading.nodeproperties
 
DoubleNodePropertiesBuilder(long, DefaultValue, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.loading.nodeproperties.DoubleNodePropertiesBuilder
 
doubleNodeValue(String) - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext.ComputeContext
Returns the node value for the given node schema key.
DoubleNullPropertyMap(double) - Constructor for class org.neo4j.graphalgo.core.loading.NullPropertyMap.DoubleNullPropertyMap
 
DoublePageCreator - Class in org.neo4j.graphalgo.core.utils.paged
 
DoublePointer(double) - Constructor for class org.neo4j.graphalgo.core.utils.Pointer.DoublePointer
 
doubleProperties(String) - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.CompositeNodeValue
 
DoubleUtil - Class in org.neo4j.graphalgo.core.utils
 
doubleValue() - Method in class org.neo4j.graphalgo.api.DefaultValue
 
doubleValue(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.DoubleArrayNodeProperties
 
doubleValue(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.DoubleNodeProperties
 
doubleValue(long) - Method in interface org.neo4j.graphalgo.api.NodeProperties
 
doubleValue(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.LongNodeProperties
 
doubleValue(long) - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
doubleValue(long) - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
doubleValue(long) - Method in class org.neo4j.graphalgo.core.loading.NullPropertyMap.DoubleNullPropertyMap
 
doubleValue(String, long) - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.CompositeNodeValue
 
drop(String, String) - Static method in class org.neo4j.graphalgo.core.model.ModelCatalog
 
DuplicateNodeIdException - Exception in org.neo4j.graphalgo.core.loading
 
DuplicateNodeIdException(long) - Constructor for exception org.neo4j.graphalgo.core.loading.DuplicateNodeIdException
 

E

elementAt(int) - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
elementCount() - Method in interface org.neo4j.graphalgo.api.Relationships.Topology
 
ElementIdentifier - Class in org.neo4j.graphalgo
 
ElementProjection - Class in org.neo4j.graphalgo
 
ElementProjection() - Constructor for class org.neo4j.graphalgo.ElementProjection
 
elements() - Method in interface org.neo4j.graphalgo.beta.pregel.PregelSchema
 
elements() - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
elements1() - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongLongPriorityQueue
 
elements2() - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongLongPriorityQueue
 
ElementSchema<SELF extends ElementSchema<SELF,​I>,​I extends ElementIdentifier> - Interface in org.neo4j.graphalgo.api.schema
 
embeddingDimension() - Method in interface org.neo4j.graphalgo.config.EmbeddingDimensionConfig
 
EmbeddingDimensionConfig - Interface in org.neo4j.graphalgo.config
 
empty - Variable in class org.neo4j.graphalgo.core.huge.GraphIntersect
 
empty() - Static method in interface org.neo4j.graphalgo.api.NodePropertyStore
 
empty() - Static method in interface org.neo4j.graphalgo.api.RelationshipPropertyStore
 
empty() - Static method in interface org.neo4j.graphalgo.api.schema.GraphSchema
 
empty() - Static method in interface org.neo4j.graphalgo.core.utils.mem.AllocationTracker
 
empty() - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
 
empty() - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
empty() - Static method in interface org.neo4j.graphalgo.core.utils.mem.MemoryTree
 
EMPTY - Static variable in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongVisitor
 
EMPTY - Static variable in interface org.neo4j.graphalgo.core.utils.RenamesCurrentThread
 
EMPTY_LONG_ARRAY - Static variable in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
emptyIterator() - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
 
emptyIterator() - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
emptyIterator() - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongResourceCollections
 
emptyPages() - Method in class org.neo4j.graphalgo.core.utils.paged.PageAllocator
 
emptyValue(double) - Method in enum org.neo4j.graphalgo.core.Aggregation
 
emptyWithName(String, String) - Static method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
enableAndRun(CheckedRunnable<E>) - Method in enum org.neo4j.graphalgo.utils.GdsFeatureToggles
 
enableDebugLog() - Method in interface org.neo4j.graphalgo.core.utils.export.GraphStoreExportConfig
 
encodedVLongSize(long) - Static method in class org.neo4j.graphalgo.core.loading.VarLongEncoding
The values are equivalent to: BitUtil.ceilDiv(64 - Long.numberOfLeadingZeros(nodeCount - 1), 7)
encodeVLongs(long[], int, byte[], int) - Static method in class org.neo4j.graphalgo.core.loading.VarLongEncoding
 
endField() - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Ends the construction of a sub-component and returns the parent builder.
enterpriseLicenseFile() - Static method in class org.neo4j.graphalgo.core.Settings
 
EnterpriseLicensingExtension - Class in org.neo4j.graphalgo.core
 
EnterpriseLicensingExtension() - Constructor for class org.neo4j.graphalgo.core.EnterpriseLicensingExtension
 
enterpriseUnlocked() - Static method in class org.neo4j.graphalgo.core.Settings
Deprecated.
enumerate() - Method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
enumerate(Collection<T>) - Static method in class org.neo4j.graphalgo.core.utils.CollectionUtil
 
equals(Object) - Method in class org.neo4j.graphalgo.api.DefaultValue
 
equals(Object) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
equals(Object) - Method in class org.neo4j.graphalgo.ElementIdentifier
 
equivalentToNone(Aggregation) - Static method in enum org.neo4j.graphalgo.core.Aggregation
 
errorMessage() - Method in class org.neo4j.graphalgo.core.GdsEdition
 
estimate(GraphDimensions, int) - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryEstimation
 
estimateMemoryUsage(long) - Method in class org.neo4j.graphalgo.core.utils.paged.PageAllocator
 
estimateMemoryUsage(long) - Method in class org.neo4j.graphalgo.core.utils.paged.PageAllocator.Factory
 
estimateMemoryUsage(long, Class<?>) - Method in class org.neo4j.graphalgo.core.utils.paged.PageAllocator.Factory
 
estimateMemoryUsage(GraphDimensions, int) - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryResident
 
estimationDimensions() - Method in class org.neo4j.graphalgo.api.GraphStoreFactory
 
estimationDimensions() - Method in class org.neo4j.graphalgo.core.loading.CypherFactory
 
estimationNodeLabelCount() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
exactDoubleToLong(double) - Static method in class org.neo4j.graphalgo.utils.ValueConversion
 
exactLongToDouble(long) - Static method in class org.neo4j.graphalgo.utils.ValueConversion
 
ExceptionUtil - Class in org.neo4j.graphalgo.utils
 
executor() - Method in interface org.neo4j.graphalgo.api.GraphLoaderContext
 
executorService - Variable in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
exists() - Method in class org.neo4j.graphalgo.PropertyMapping
 
exists(long, long) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
exists(long, long) - Method in interface org.neo4j.graphalgo.api.RelationshipPredicate
 
exists(long, long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
O(n) !
exists(long, long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
exists(long, long) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
O(n) !
exists(String, String) - Static method in class org.neo4j.graphalgo.core.model.ModelCatalog
 
exists(String, NamedDatabaseId, String) - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
ExistsConsumer(long) - Constructor for class org.neo4j.graphalgo.core.huge.HugeGraph.ExistsConsumer
 
EXP_BIAS - Static variable in class org.neo4j.graphalgo.core.loading.DoubleCodec
Bias used in representing a double exponent.
EXP_BIT_MASK - Static variable in class org.neo4j.graphalgo.core.loading.DoubleCodec
Bit mask to isolate the exponent field of a double.
explicitProjections() - Method in class org.neo4j.graphalgo.AbstractProjections
Returns all projections except PROJECT_ALL projections.
ExporterBuilder<T> - Class in org.neo4j.graphalgo.core.write
 
extractValue(Aggregation, Value, double) - Static method in class org.neo4j.graphalgo.core.loading.ReadHelper
 
extractValue(Value, double) - Static method in class org.neo4j.graphalgo.core.loading.ReadHelper
 

F

FACTORY - Static variable in class org.neo4j.graphalgo.core.loading.RelationshipScanCursorBasedScanner
 
FACTORY - Static variable in class org.neo4j.graphalgo.core.utils.BatchingProgressLogger
 
failOnMissingFiles() - Static method in class org.neo4j.graphalgo.core.Settings
 
featureProperties() - Method in interface org.neo4j.graphalgo.config.FeaturePropertiesConfig
 
FeaturePropertiesConfig - Interface in org.neo4j.graphalgo.config
 
fetchNext() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections.PrimitiveIntBaseIterator
Fetches the next item in this iterator.
fetchNext() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections.PrimitiveIntConcatingIterator
 
fetchNext() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections.PrimitiveIntFilteringIterator
 
fetchNext() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongBaseIterator
Fetches the next item in this iterator.
fetchNext() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongConcatingIterator
 
fetchNext() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongFilteringIterator
 
fetchNext() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongRangeIterator
 
field(String, Class<?>) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds the memory consumption of the given class as a sub-component to this builder.
fill(double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
Assigns the specified double value to each element.
fill(double[][], int) - Method in class org.neo4j.graphalgo.core.utils.paged.DoublePageCreator
 
fill(double, int) - Static method in class org.neo4j.graphalgo.core.utils.ArrayUtil
 
fill(int) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Assigns the specified int value to each element.
fill(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Assigns the specified long value to each element.
fill(long[][], int) - Method in class org.neo4j.graphalgo.core.utils.paged.LongPageCreator
 
fill(T) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
Assigns the specified value to each element.
fillPage(double[], long) - Method in class org.neo4j.graphalgo.core.utils.paged.DoublePageCreator
 
fillPage(long[], long) - Method in class org.neo4j.graphalgo.core.utils.paged.LongPageCreator
 
filter(Set<I>) - Method in interface org.neo4j.graphalgo.api.schema.ElementSchema
 
filter(Set<NodeLabel>) - Method in interface org.neo4j.graphalgo.api.schema.NodeSchema
 
filter(Set<RelationshipType>) - Method in interface org.neo4j.graphalgo.api.schema.RelationshipSchema
 
filter(PrimitiveIntIterator, IntPredicate) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
 
filter(PrimitiveLongIterator, LongPredicate) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
filter(PrimitiveLongResourceIterator, LongPredicate) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
filter(PrimitiveLongResourceIterator, LongPredicate) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongResourceCollections
 
FilteredNodeProperties - Class in org.neo4j.graphalgo.core.huge
 
FilteredNodeProperties(NodeProperties, NodeFilteredGraph) - Constructor for class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
FilterGraph - Class in org.neo4j.graphalgo.api
 
FilterGraph(Graph) - Constructor for class org.neo4j.graphalgo.api.FilterGraph
 
filterNodeLabels(Set<NodeLabel>) - Method in interface org.neo4j.graphalgo.api.schema.GraphSchema
 
filterProperties(Set<I>) - Method in interface org.neo4j.graphalgo.api.schema.ElementSchema
 
filterRelationshipTypes(Set<RelationshipType>) - Method in interface org.neo4j.graphalgo.api.schema.GraphSchema
 
find(long) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.IncrementalDisjointSetStruct
Deprecated.
find setId of element p without balancing optimization.
find(long) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.NonInrementalDisjointSetStruct
Deprecated.
 
find(long) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.SequentialDisjointSetStruct
Deprecated.
Find set Id of element p.
findAndBalance(long) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.SequentialDisjointSetStruct
Deprecated.
Find set id of element p and balances the tree structure while searching.
fits(int) - Method in interface org.neo4j.graphalgo.core.utils.partition.Partition
 
fixed(String, long) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a fixed amount of memory consumption in bytes to the builder.
fixed(String, MemoryRange) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a fixed memory range to the builder.
flip(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Toggles the bit at the given index.
FLOAT_ARRAY - org.neo4j.graphalgo.api.nodeproperties.ValueType
 
FLOAT_DEFAULT_FALLBACK - Static variable in class org.neo4j.graphalgo.api.DefaultValue
 
FloatArrayNodeProperties - Interface in org.neo4j.graphalgo.api.nodeproperties
 
FloatArrayNodePropertiesBuilder - Class in org.neo4j.graphalgo.core.loading.nodeproperties
 
FloatArrayNodePropertiesBuilder(long, DefaultValue, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.loading.nodeproperties.FloatArrayNodePropertiesBuilder
 
floatArrayValue() - Method in class org.neo4j.graphalgo.api.DefaultValue
 
floatArrayValue(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.DoubleArrayNodeProperties
 
floatArrayValue(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.FloatArrayNodeProperties
 
floatArrayValue(long) - Method in interface org.neo4j.graphalgo.api.NodeProperties
 
floatArrayValue(long) - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
floatArrayValue(long) - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
floatToDoubleArray(float[]) - Static method in class org.neo4j.graphalgo.core.utils.ArrayUtil
 
flush() - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListBuilder
 
flush() - Method in class org.neo4j.graphalgo.core.loading.TransientAdjacencyListBuilder
 
flushTasks() - Method in interface org.neo4j.graphalgo.core.loading.InternalImporter.CreateScanner
 
flushTasks() - Method in class org.neo4j.graphalgo.core.loading.RelationshipImporter
 
FORBIDDEN_KEYS - Static variable in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
foreach(BoundedLongLongPriorityQueue.Consumer) - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongLongPriorityQueue
 
forEach(BoundedLongPriorityQueue.Consumer) - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
forEachNode(LongPredicate) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
forEachNode(LongPredicate) - Method in interface org.neo4j.graphalgo.api.NodeIterator
Iterate over each nodeId
forEachNode(LongPredicate) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
forEachNode(LongPredicate) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
forEachNode(LongPredicate) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
forEachNode(LongPredicate) - Method in class org.neo4j.graphalgo.core.loading.IdMap
 
forEachRelationship(long, double, RelationshipWithPropertyConsumer) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
forEachRelationship(long, double, RelationshipWithPropertyConsumer) - Method in interface org.neo4j.graphalgo.api.RelationshipIterator
Calls the given consumer function for every relationship of a given node.
forEachRelationship(long, double, RelationshipWithPropertyConsumer) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
forEachRelationship(long, double, RelationshipWithPropertyConsumer) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
forEachRelationship(long, double, RelationshipWithPropertyConsumer) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
forEachRelationship(long, RelationshipConsumer) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
forEachRelationship(long, RelationshipConsumer) - Method in interface org.neo4j.graphalgo.api.RelationshipIterator
Calls the given consumer function for every relationship of a given node.
forEachRelationship(long, RelationshipConsumer) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
forEachRelationship(long, RelationshipConsumer) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
forEachRelationship(long, RelationshipConsumer) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
fork() - Method in class org.neo4j.graphalgo.core.SecureTransaction
Return a new SecureTransaction that owns a newly created top-level Transaction.
forPageSize(int) - Static method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyOffsets
 
forValueType(ValueType) - Static method in interface org.neo4j.graphalgo.api.schema.GraphSchema
 
found - Variable in class org.neo4j.graphalgo.core.huge.HugeGraph.ExistsConsumer
 
free() - Method in class org.neo4j.graphalgo.core.utils.paged.TrackingLongDoubleHashMap
 
freeMemory() - Static method in class org.neo4j.graphalgo.core.utils.mem.GcListenerExtension
 
fromList(Iterable<?>) - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
fromMap(Map<String, ?>) - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
fromMap(Map<String, Object>, NodeLabel) - Static method in class org.neo4j.graphalgo.AbstractNodeProjection
 
fromMap(Map<String, Object>, RelationshipType) - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
fromNumberType(NumberType) - Static method in enum org.neo4j.graphalgo.api.nodeproperties.ValueType
 
fromObject(Object) - Static method in class org.neo4j.graphalgo.AbstractNodeProjections
 
fromObject(Object) - Static method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
fromObject(Object) - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
fromObject(Object, Aggregation) - Static method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
fromObject(Object, NodeLabel) - Static method in class org.neo4j.graphalgo.AbstractNodeProjection
 
fromObject(Object, RelationshipType) - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
fromObject(String, Object) - Static method in class org.neo4j.graphalgo.PropertyMapping
 
fromProcedureConfig(String, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
fromProcedureConfig(String, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
fromString(String) - Static method in class org.neo4j.graphalgo.AbstractNodeProjection
 
fromString(String) - Static method in class org.neo4j.graphalgo.AbstractNodeProjections
 
fromString(String) - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
fromString(String) - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
fromString(String) - Static method in class org.neo4j.graphalgo.core.utils.Directions
 
fromString(String, Direction) - Static method in class org.neo4j.graphalgo.core.utils.Directions
 
function(CheckedFunction<? super T, ? extends R, E>) - Static method in class org.neo4j.graphalgo.utils.ExceptionUtil
 
function(CheckedFunction<T, R, E>) - Static method in interface org.neo4j.graphalgo.utils.CheckedFunction
 

G

gaussianSample(long, long, long, Random) - Static method in class org.neo4j.graphalgo.core.utils.statistics.DistributionHelper
 
GcListenerExtension - Class in org.neo4j.graphalgo.core.utils.mem
 
GcListenerExtension() - Constructor for class org.neo4j.graphalgo.core.utils.mem.GcListenerExtension
 
GdsEdition - Class in org.neo4j.graphalgo.core
 
GdsFeatureToggles - Enum in org.neo4j.graphalgo.utils
 
GDSMode - Enum in org.neo4j.graphalgo.beta.pregel.annotation
 
GenericPointer(G) - Constructor for class org.neo4j.graphalgo.core.utils.Pointer.GenericPointer
 
GenericUtil - Class in org.neo4j.graphalgo.core.utils
 
get() - Method in interface org.neo4j.graphalgo.core.utils.mem.AllocationTracker
 
get() - Method in interface org.neo4j.graphalgo.utils.CheckedSupplier
 
get() - Method in class org.neo4j.graphalgo.utils.CloseableThreadLocal
 
get(int) - Method in class org.neo4j.graphalgo.core.utils.AtomicDoubleArray
get the value at index
get(long) - Method in interface org.neo4j.graphalgo.api.AdjacencyOffsets
 
get(long) - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyOffsets
 
get(long) - Method in class org.neo4j.graphalgo.core.huge.TransientFilteredAdjacencyOffsets
 
get(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Returns the state of the bit at the given index.
get(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
 
get(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
 
get(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
 
get(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
 
get(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
 
get(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
 
get(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray
 
get(long) - Method in class org.neo4j.graphalgo.core.utils.paged.PagedAtomicDoubleArray
 
get(long) - Method in class org.neo4j.graphalgo.core.utils.paged.PagedAtomicIntegerArray
 
get(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleTriangularMatrix
 
get(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongMatrix
 
get(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongTriangularMatrix
 
get(String) - Method in interface org.neo4j.graphalgo.api.NodePropertyStore
 
get(String) - Method in interface org.neo4j.graphalgo.api.RelationshipPropertyStore
 
get(String, String, Class<D>, Class<C>) - Static method in class org.neo4j.graphalgo.core.model.ModelCatalog
 
get(String, NamedDatabaseId, String) - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
get(GraphLoaderContext) - Method in interface org.neo4j.graphalgo.api.GraphStoreFactory.Supplier
 
getAndSet(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Sets a bit and returns the previous value.
getCapacity() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray
 
getCursor(KernelTransaction) - Method in interface org.neo4j.graphalgo.core.loading.StoreScanner
 
getDegreeDistribution(String, NamedDatabaseId, String) - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
getDoubleArray(Value) - Static method in class org.neo4j.graphalgo.utils.ValueConversion
 
getDoubleValue(Value) - Static method in class org.neo4j.graphalgo.utils.ValueConversion
 
getDuration() - Method in class org.neo4j.graphalgo.core.utils.ProgressTimer
 
getFilter(RelationshipType) - Method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
getFilteredMappedNodeId(long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
getFloatArray(Value) - Static method in class org.neo4j.graphalgo.utils.ValueConversion
 
getGraph(String, String, Optional<String>) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
getGraph(Collection<NodeLabel>, Collection<RelationshipType>, Optional<String>) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
getGraph(Collection<NodeLabel>, Collection<RelationshipType>, Optional<String>) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
getGraph(Collection<RelationshipType>, Optional<String>) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
getGraph(NodeLabel, RelationshipType, Optional<String>) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
getGraph(RelationshipType...) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
getGraph(RelationshipType, Optional<String>) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
getGraphStores(String) - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
getGraphStores(String, NamedDatabaseId) - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
getHead(long) - Static method in class org.neo4j.graphalgo.core.utils.RawValues
get the head value
getIntermediateOriginalNodeId(long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
getIntersection(int[], int[]) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
getIntersection(int[], int, int[], int) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
getLog() - Method in class org.neo4j.graphalgo.core.utils.BatchingProgressLogger
 
getLog() - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
getLog() - Method in enum org.neo4j.graphalgo.core.utils.ProgressLogger.NullProgressLogger
 
getLog() - Method in class org.neo4j.graphalgo.core.utils.ProgressLoggerAdapter
Deprecated.
 
getLongArray(Value) - Static method in class org.neo4j.graphalgo.utils.ValueConversion
 
getLongValue(Value) - Static method in class org.neo4j.graphalgo.utils.ValueConversion
 
getMaxDoublePropertyValue() - Method in interface org.neo4j.graphalgo.api.nodeproperties.DoubleNodeProperties
 
getMaxDoublePropertyValue() - Method in interface org.neo4j.graphalgo.api.NodeProperties
 
getMaxDoublePropertyValue() - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
getMaxDoublePropertyValue() - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
getMaxDoublePropertyValue() - Method in class org.neo4j.graphalgo.core.loading.NullPropertyMap.DoubleNullPropertyMap
 
getMaxLongPropertyValue() - Method in interface org.neo4j.graphalgo.api.NodeProperties
 
getMaxLongPropertyValue() - Method in interface org.neo4j.graphalgo.api.nodeproperties.LongNodeProperties
 
getMaxLongPropertyValue() - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
getMaxLongPropertyValue() - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
getMaxLongPropertyValue() - Method in class org.neo4j.graphalgo.core.loading.NullPropertyMap.LongNullPropertyMap
 
getMemoryEstimation(NodeProjections, RelationshipProjections) - Static method in class org.neo4j.graphalgo.core.loading.NativeFactory
 
getNodeLabelTokens(TokenRead) - Method in class org.neo4j.graphalgo.core.GraphDimensionsCypherReader
 
getNodeLabelTokens(TokenRead) - Method in class org.neo4j.graphalgo.core.GraphDimensionsReader
 
getNodeLabelTokens(TokenRead) - Method in class org.neo4j.graphalgo.core.GraphDimensionsStoreReader
 
getNodeProjections() - Method in class org.neo4j.graphalgo.core.GraphDimensionsCypherReader
 
getNodeProjections() - Method in class org.neo4j.graphalgo.core.GraphDimensionsReader
 
getNodeProjections() - Method in class org.neo4j.graphalgo.core.GraphDimensionsStoreReader
 
getObject() - Method in class org.neo4j.graphalgo.api.DefaultValue
 
getObject(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.DoubleArrayNodeProperties
 
getObject(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.DoubleNodeProperties
 
getObject(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.FloatArrayNodeProperties
 
getObject(long) - Method in interface org.neo4j.graphalgo.api.NodeProperties
 
getObject(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.LongArrayNodeProperties
 
getObject(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.LongNodeProperties
 
getObject(long) - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
getObject(long) - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
getObject(long) - Method in class org.neo4j.graphalgo.core.loading.NullPropertyMap.DoubleNullPropertyMap
 
getObject(long) - Method in class org.neo4j.graphalgo.core.loading.NullPropertyMap.LongNullPropertyMap
 
getOrCreatePropertyToken(String) - Method in class org.neo4j.graphalgo.utils.StatementApi
 
getOrCreateRelationshipToken(String) - Method in class org.neo4j.graphalgo.utils.StatementApi
 
getOrDefault(long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
 
getOrDefault(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
 
getOrDefault(long, long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongDoubleMap
 
getRelationshipCountsByType(Read, GraphDimensionsReader.TokenElementIdentifierMappings<NodeLabel>, GraphDimensionsReader.TokenElementIdentifierMappings<RelationshipType>) - Method in class org.neo4j.graphalgo.core.GraphDimensionsReader
 
getRelationshipProjections() - Method in class org.neo4j.graphalgo.core.GraphDimensionsCypherReader
 
getRelationshipProjections() - Method in class org.neo4j.graphalgo.core.GraphDimensionsReader
 
getRelationshipProjections() - Method in class org.neo4j.graphalgo.core.GraphDimensionsStoreReader
 
getRelationshipTypeTokens(TokenRead) - Method in class org.neo4j.graphalgo.core.GraphDimensionsCypherReader
 
getRelationshipTypeTokens(TokenRead) - Method in class org.neo4j.graphalgo.core.GraphDimensionsReader
 
getRelationshipTypeTokens(TokenRead) - Method in class org.neo4j.graphalgo.core.GraphDimensionsStoreReader
 
getSign(long) - Static method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Get the sign bit of a bit representation of a double.
getSignificand(long) - Static method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Get the significand of a bit representation of a double.
getTail(long) - Static method in class org.neo4j.graphalgo.core.utils.RawValues
get the tail value
getTarget(long, long) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
getTarget(long, long) - Method in interface org.neo4j.graphalgo.api.RelationshipAccess
Deprecated.
getTarget(long, long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
getTarget(long, long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
getTarget(long, long) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
GetTargetConsumer(long) - Constructor for class org.neo4j.graphalgo.core.huge.HugeGraph.GetTargetConsumer
 
getUnbiasedExponent(long) - Static method in class org.neo4j.graphalgo.core.loading.DoubleCodec
Get the unbiased exponent of a bit representation of a double.
getUnion() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
getUnion() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
getUnion(String, NamedDatabaseId, String) - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
getUsageString() - Method in interface org.neo4j.graphalgo.core.utils.mem.AllocationTracker
 
getUsageString(String) - Method in interface org.neo4j.graphalgo.core.utils.mem.AllocationTracker
 
getValue(long) - Method in interface org.neo4j.graphalgo.core.mutate.NodePropertyAccessor
 
getWithDimension(GraphLoaderContext, GraphDimensions) - Method in interface org.neo4j.graphalgo.api.GraphStoreFactory.Supplier
 
globalAdjacencyOffsets() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBuilder
 
globalProceduresRegistry() - Method in interface org.neo4j.graphalgo.core.utils.mem.AllocationTrackerExtensionFactory.Dependencies
 
globalPropertyOffsets() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBuilder
 
globalPropertyOffsets(int) - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBuilder
 
graph - Variable in class org.neo4j.graphalgo.api.CSRFilterGraph
 
graph - Variable in class org.neo4j.graphalgo.api.FilterGraph
 
graph - Variable in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
graph() - Method in interface org.neo4j.graphalgo.core.GraphLoader
 
Graph - Interface in org.neo4j.graphalgo.api
 
graphCreateConfig - Variable in class org.neo4j.graphalgo.api.GraphStoreFactory
 
graphCreateConfig - Variable in class org.neo4j.graphalgo.core.GraphDimensionsReader
 
GraphCreateConfig - Interface in org.neo4j.graphalgo.config
 
GraphCreateConfig.Cases<R> - Interface in org.neo4j.graphalgo.config
 
GraphCreateConfig.Rewriter - Interface in org.neo4j.graphalgo.config
 
GraphCreateConfig.Visitor - Interface in org.neo4j.graphalgo.config
 
GraphCreateConfigValidations - Class in org.neo4j.graphalgo.config
 
GraphCreateFromCypherConfig - Interface in org.neo4j.graphalgo.config
 
GraphCreateFromStoreConfig - Interface in org.neo4j.graphalgo.config
 
graphDimensions - Variable in class org.neo4j.graphalgo.core.utils.mem.MemoryTreeWithDimensions
 
graphDimensions() - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryEstimationWithDimensions
 
GraphDimensions - Interface in org.neo4j.graphalgo.core
 
GraphDimensionsCypherReader - Class in org.neo4j.graphalgo.core
 
GraphDimensionsCypherReader(SecureTransaction, GraphCreateFromCypherConfig) - Constructor for class org.neo4j.graphalgo.core.GraphDimensionsCypherReader
 
GraphDimensionsReader<T extends GraphCreateConfig> - Class in org.neo4j.graphalgo.core
 
GraphDimensionsReader(SecureTransaction, T) - Constructor for class org.neo4j.graphalgo.core.GraphDimensionsReader
 
GraphDimensionsStoreReader - Class in org.neo4j.graphalgo.core
 
GraphDimensionsStoreReader(SecureTransaction, GraphCreateFromStoreConfig) - Constructor for class org.neo4j.graphalgo.core.GraphDimensionsStoreReader
 
GraphDimensionsValidation - Class in org.neo4j.graphalgo.core
 
GraphExportNodePropertiesConfig - Interface in org.neo4j.graphalgo.config
 
GraphFactory - Class in org.neo4j.graphalgo.core.loading.construction
 
GraphIntersect<CURSOR extends AdjacencyCursor> - Class in org.neo4j.graphalgo.core.huge
An instance of this is not thread-safe; Iteration/Intersection on multiple threads will throw misleading NullPointerExceptions.
GraphIntersect(CURSOR, CURSOR, CURSOR, CURSOR, long) - Constructor for class org.neo4j.graphalgo.core.huge.GraphIntersect
 
GraphLoader - Interface in org.neo4j.graphalgo.core
 
GraphLoaderContext - Interface in org.neo4j.graphalgo.api
 
graphName() - Method in interface org.neo4j.graphalgo.config.AlgoBaseConfig
 
graphName() - Method in interface org.neo4j.graphalgo.config.DeleteRelationshipsConfig
 
graphName() - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
graphName() - Method in interface org.neo4j.graphalgo.config.GraphExportNodePropertiesConfig
 
graphName() - Method in interface org.neo4j.graphalgo.config.GraphStreamRelationshipPropertiesConfig
 
GraphRemoveNodePropertiesConfig - Interface in org.neo4j.graphalgo.config
 
graphSchema() - Method in interface org.neo4j.graphalgo.core.model.Model
 
GraphSchema - Interface in org.neo4j.graphalgo.api.schema
 
GraphStatistics - Class in org.neo4j.graphalgo.api
 
graphStore() - Method in interface org.neo4j.graphalgo.api.GraphStoreFactory.ImportResult
 
graphStore() - Method in interface org.neo4j.graphalgo.core.GraphLoader
 
graphStore() - Method in interface org.neo4j.graphalgo.core.loading.GraphStoreWithConfig
 
GraphStore - Interface in org.neo4j.graphalgo.api
 
GraphStore.PropertyState - Enum in org.neo4j.graphalgo.api
 
GraphStoreCatalog - Class in org.neo4j.graphalgo.core.loading
 
GraphStoreExport - Class in org.neo4j.graphalgo.core.utils.export
 
GraphStoreExport(GraphStore, GraphDatabaseAPI, GraphStoreExportConfig) - Constructor for class org.neo4j.graphalgo.core.utils.export.GraphStoreExport
 
GraphStoreExport.ImportedProperties - Interface in org.neo4j.graphalgo.core.utils.export
 
GraphStoreExportConfig - Interface in org.neo4j.graphalgo.core.utils.export
 
graphStoreFactory() - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
graphStoreFactory() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
graphStoreFactory() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
graphStoreFactory() - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
graphStoreFactory() - Method in interface org.neo4j.graphalgo.core.GraphLoader
 
GraphStoreFactory<STORE extends GraphStore,​CONFIG extends GraphCreateConfig> - Class in org.neo4j.graphalgo.api
The Abstract Factory defines the construction of the graph
GraphStoreFactory(CONFIG, GraphLoaderContext, GraphDimensions) - Constructor for class org.neo4j.graphalgo.api.GraphStoreFactory
 
GraphStoreFactory.ImportResult<STORE extends GraphStore> - Interface in org.neo4j.graphalgo.api
 
GraphStoreFactory.RelationshipImportResult - Interface in org.neo4j.graphalgo.api
 
GraphStoreFactory.Supplier - Interface in org.neo4j.graphalgo.api
 
GraphStoreInput - Class in org.neo4j.graphalgo.core.utils.export
 
graphStoresCount() - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
graphStoresCount(NamedDatabaseId) - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
GraphStoreValidation - Class in org.neo4j.graphalgo.api
 
GraphStoreWithConfig - Interface in org.neo4j.graphalgo.core.loading
 
GraphStreamNodePropertiesConfig - Interface in org.neo4j.graphalgo.config
 
GraphStreamRelationshipPropertiesConfig - Interface in org.neo4j.graphalgo.config
 
GraphWriteNodePropertiesConfig - Interface in org.neo4j.graphalgo.config
 
GraphWriteRelationshipConfig - Interface in org.neo4j.graphalgo.config
 
groups() - Method in class org.neo4j.graphalgo.core.utils.export.GraphStoreInput
 

H

hashCode() - Method in class org.neo4j.graphalgo.api.DefaultValue
 
hashCode() - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
hashCode() - Method in class org.neo4j.graphalgo.ElementIdentifier
 
hasLabel(long, NodeLabel) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
hasLabel(long, NodeLabel) - Method in interface org.neo4j.graphalgo.api.NodeMapping
 
hasLabel(long, NodeLabel) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
hasLabel(long, NodeLabel) - Method in class org.neo4j.graphalgo.core.loading.IdMap
 
hasLabelInformation() - Method in class org.neo4j.graphalgo.core.loading.NodesBatchBuffer
 
hasMappings() - Method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
hasNext() - Method in class org.neo4j.graphalgo.api.BatchNodeIterable.IdIterator
 
hasNext() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections.PrimitiveIntBaseIterator
 
hasNext() - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntIterator
 
hasNext() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongBaseIterator
 
hasNext() - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongIterator
 
hasNext() - Method in class org.neo4j.graphalgo.core.utils.RandomLongIterator
 
hasNextLong() - Method in interface org.neo4j.graphalgo.api.PropertyCursor
Return true iff there is at least one more target to decode.
hasNextLong() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList.Cursor
 
hasNextVLong() - Method in interface org.neo4j.graphalgo.api.AdjacencyCursor
Return true iff there is at least one more target to decode.
hasNextVLong() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyCursor
 
hasNextVLong() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList.DecompressingCursor
 
hasNodeProperty(Collection<NodeLabel>, String) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
hasNodeProperty(Collection<NodeLabel>, String) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
hasRelationshipProperty() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
hasRelationshipProperty() - Method in interface org.neo4j.graphalgo.api.Graph
 
hasRelationshipProperty() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
hasRelationshipProperty() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
hasRelationshipProperty(Collection<RelationshipType>, String) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
hasRelationshipProperty(Collection<RelationshipType>, String) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
hasRelationshipType(RelationshipType) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
hasRelationshipType(RelationshipType) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
hasValidName() - Method in class org.neo4j.graphalgo.PropertyMapping
 
hasWeights() - Method in class org.neo4j.graphalgo.core.loading.CompressedLongArray
 
head() - Method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
highestNeoId() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
histogram() - Method in interface org.neo4j.graphalgo.core.utils.statistics.CommunityStatistics.CommunityCountAndHistogram
 
HISTOGRAM_PRECISION_DEFAULT - Static variable in class org.neo4j.graphalgo.core.ProcedureConstants
 
httpEnabled() - Static method in class org.neo4j.graphalgo.core.Settings
 
httpsEnabled() - Static method in class org.neo4j.graphalgo.core.Settings
 
HugeArrays - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeAtomicBitSet - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeAtomicDisjointSetStruct - Class in org.neo4j.graphalgo.core.utils.paged.dss
Add adaption of the C++ implementation [1] for the "Wait-free Parallel Algorithms for the Union-Find Problem" [2] with some input from an atomic DSS implementation in Rust [3].
HugeAtomicDisjointSetStruct(long, NodeProperties, AllocationTracker, int) - Constructor for class org.neo4j.graphalgo.core.utils.paged.dss.HugeAtomicDisjointSetStruct
 
HugeAtomicDisjointSetStruct(long, AllocationTracker, int) - Constructor for class org.neo4j.graphalgo.core.utils.paged.dss.HugeAtomicDisjointSetStruct
 
HugeAtomicDoubleArray - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeAtomicDoubleArray() - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
 
HugeAtomicLongArray - Class in org.neo4j.graphalgo.core.utils.paged
A long-indexable version of a AtomicLongArray that can contain more than 2 bn.
HugeAtomicLongArray() - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
 
HugeCursor<Array> - Class in org.neo4j.graphalgo.core.utils.paged
View of data underlying an Huge array, accessible as slices of one or more primitive arrays.
HugeDoubleArray - Class in org.neo4j.graphalgo.core.utils.paged
A long-indexable version of a primitive double array (double[]) that can contain more than 2 bn.
HugeDoubleArray() - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
 
HugeDoubleTriangularMatrix - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeDoubleTriangularMatrix(long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeDoubleTriangularMatrix
 
HugeGraph - Class in org.neo4j.graphalgo.core.huge
Huge Graph contains two array like data structures.
HugeGraph(IdMap, GraphSchema, Map<String, NodeProperties>, long, TransientAdjacencyList, TransientAdjacencyOffsets, boolean, double, TransientAdjacencyList, TransientAdjacencyOffsets, Orientation, boolean, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.huge.HugeGraph
 
HugeGraph.ExistsConsumer - Class in org.neo4j.graphalgo.core.huge
 
HugeGraph.GetTargetConsumer - Class in org.neo4j.graphalgo.core.huge
 
HugeGraphIntersect - Class in org.neo4j.graphalgo.core.huge
 
HugeIntArray - Class in org.neo4j.graphalgo.core.utils.paged
A long-indexable version of a primitive int array (int[]) that can contain more than 2 bn.
HugeIntArray() - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
 
HugeLongArray - Class in org.neo4j.graphalgo.core.utils.paged
A long-indexable version of a primitive long array (long[]) that can contain more than 2 bn.
HugeLongArray() - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
 
HugeLongArrayBuilder - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeLongArrayQueue - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeLongArrayStack - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeLongDoubleMap - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeLongDoubleMap(long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
New instance with sane defaults.
HugeLongDoubleMap(AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
New instance with sane defaults.
HugeLongLongDoubleMap - Class in org.neo4j.graphalgo.core.utils.paged
map with two longs as keys and huge underlying storage, so it can store more than 2B values
HugeLongLongDoubleMap(long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeLongLongDoubleMap
New instance with sane defaults.
HugeLongLongDoubleMap(AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeLongLongDoubleMap
New instance with sane defaults.
HugeLongLongMap - Class in org.neo4j.graphalgo.core.utils.paged
map with long=>long mapping and huge underlying storage, so it can store more than 2B values
HugeLongLongMap(long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
New instance with sane defaults.
HugeLongLongMap(AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
New instance with sane defaults.
HugeLongMatrix - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeLongMatrix(long, long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeLongMatrix
 
HugeLongSquareMatrix - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeLongSquareMatrix(long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeLongSquareMatrix
 
HugeLongTriangularMatrix - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeLongTriangularMatrix(long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeLongTriangularMatrix
 
HugeNodeImporter - Class in org.neo4j.graphalgo.core.loading
 
HugeNodeImporter(HugeLongArrayBuilder, Map<NodeLabel, HugeAtomicBitSet>, IntObjectMap<List<NodeLabel>>, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.loading.HugeNodeImporter
 
HugeNodeImporter.PropertyReader - Interface in org.neo4j.graphalgo.core.loading
 
HugeObjectArray<T> - Class in org.neo4j.graphalgo.core.utils.paged
A long-indexable version of a Object array (T[]) that can contain more than 2 bn.
HugeObjectArray() - Constructor for class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
 
HugeParallelGraphImporter<T extends java.lang.Runnable> - Interface in org.neo4j.graphalgo.core.loading
 
HugeSparseLongArray - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeSparseLongArray.Builder - Class in org.neo4j.graphalgo.core.utils.paged
 
HugeSparseLongArray.GrowingBuilder - Class in org.neo4j.graphalgo.core.utils.paged
 
humanReadable(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
Returns size in human-readable units.

I

identity(int) - Static method in class org.neo4j.graphalgo.core.utils.paged.DoublePageCreator
 
identity(int) - Static method in class org.neo4j.graphalgo.core.utils.paged.LongPageCreator
 
IdIterable(long, long) - Constructor for class org.neo4j.graphalgo.api.BatchNodeIterable.IdIterable
 
IdIterator(long) - Constructor for class org.neo4j.graphalgo.api.BatchNodeIterable.IdIterator
 
idMap() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
idMap() - Method in class org.neo4j.graphalgo.core.loading.IdsAndProperties
 
IdMap - Class in org.neo4j.graphalgo.core.loading
This is basically a long to int mapper.
IdMap(HugeLongArray, HugeSparseLongArray, Map<NodeLabel, BitSet>, long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.loading.IdMap
initialize the map with pre-built sub arrays
IdMapBuilder - Class in org.neo4j.graphalgo.core.loading
 
IdMapping - Interface in org.neo4j.graphalgo.api
Bi-directional mapping between two id spaces.
IdsAndProperties - Class in org.neo4j.graphalgo.core.loading
 
IdsAndProperties(IdMap, Map<NodeLabel, Map<String, NodeProperties>>) - Constructor for class org.neo4j.graphalgo.core.loading.IdsAndProperties
 
idType() - Method in class org.neo4j.graphalgo.core.utils.export.GraphStoreInput
 
IGNORE - Static variable in interface org.neo4j.graphalgo.core.GraphDimensions
 
IGNORE_VALUE - Static variable in class org.neo4j.graphalgo.core.loading.AdjacencyBuilder
 
ignoring(AllocationTrackerAdapter) - Static method in class org.neo4j.graphalgo.core.utils.mem.InMemoryAllocationTracker
 
IMPLICIT_GRAPH_NAME - Static variable in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
implicitCreateConfig() - Method in interface org.neo4j.graphalgo.config.AlgoBaseConfig
 
importNodes(NodesBatchBuffer, HugeNodeImporter.PropertyReader) - Method in class org.neo4j.graphalgo.core.loading.HugeNodeImporter
 
importNodes(NodesBatchBuffer, Read, CursorFactory, PageCursorTracer, MemoryTracker, NativeNodePropertyImporter) - Method in class org.neo4j.graphalgo.core.loading.HugeNodeImporter
 
importNodes(NodesBatchBuffer, Read, CursorFactory, PageCursorTracer, MemoryTracker, NativeNodePropertyImporter) - Method in interface org.neo4j.graphalgo.core.loading.NodeImporter
 
importRelationships(RelationshipsBatchBuffer, RelationshipImporter.PropertyReader) - Method in interface org.neo4j.graphalgo.core.loading.RelationshipImporter.Imports
 
imports(Orientation, boolean) - Method in class org.neo4j.graphalgo.core.loading.RelationshipImporter
 
ImportSizing - Class in org.neo4j.graphalgo.core.loading
 
IncrementalDisjointSetStruct - Class in org.neo4j.graphalgo.core.utils.paged.dss
Deprecated.
IncrementalDisjointSetStruct(long, NodeProperties, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.dss.IncrementalDisjointSetStruct
Deprecated.
Initialize the struct with the given size.
IndexedNodePropertyImporter - Class in org.neo4j.graphalgo.core.loading
 
indexInPage(long, int) - Static method in class org.neo4j.graphalgo.core.utils.paged.PageUtil
 
indexInPage(long, long) - Static method in class org.neo4j.graphalgo.core.utils.paged.PageUtil
 
indexOf(PrimitiveLongIterator, long) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
Returns the index of the given item in the iterator(zero-based).
init() - Method in class org.neo4j.graphalgo.core.utils.mem.AllocationTrackerLifecycleAdapter
 
init(PregelContext.InitContext<C>) - Method in interface org.neo4j.graphalgo.beta.pregel.PregelComputation
The init method is called in the beginning of the first superstep (iteration) of the Pregel computation and allows initializing node values.
initialValue() - Method in class org.neo4j.graphalgo.utils.AutoCloseableThreadLocal
 
initialValue() - Method in class org.neo4j.graphalgo.utils.CloseableThreadLocal
 
initNodesBuilder() - Static method in class org.neo4j.graphalgo.core.loading.construction.GraphFactory
 
initProgressLogger() - Method in class org.neo4j.graphalgo.api.GraphStoreFactory
 
initProgressLogger() - Method in class org.neo4j.graphalgo.core.loading.CypherFactory
 
initProgressLogger() - Method in class org.neo4j.graphalgo.core.loading.NativeFactory
 
initRelationshipsBuilder() - Static method in class org.neo4j.graphalgo.core.loading.construction.GraphFactory
 
inlineBuilder() - Method in class org.neo4j.graphalgo.AbstractNodeProjection.Builder
 
inlineBuilder() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjection.Builder
 
InMemoryAllocationTracker - Class in org.neo4j.graphalgo.core.utils.mem
 
InMemoryAllocationTracker() - Constructor for class org.neo4j.graphalgo.core.utils.mem.InMemoryAllocationTracker
 
InnerNodePropertiesBuilder - Class in org.neo4j.graphalgo.core.loading.nodeproperties
 
InnerNodePropertiesBuilder() - Constructor for class org.neo4j.graphalgo.core.loading.nodeproperties.InnerNodePropertiesBuilder
 
input() - Method in interface org.neo4j.graphalgo.core.loading.DoubleCodec.CompressionInfo
 
insert(byte[], int, int) - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListPageSlice
Write some bytes at the current AdjacencyListPageSlice.offset().
instance() - Static method in class org.neo4j.graphalgo.core.GdsEdition
 
instance() - Static method in class org.neo4j.graphalgo.core.loading.NoopDoubleCodec
 
INSTANCE - org.neo4j.graphalgo.core.utils.ProgressLogger.NullProgressLogger
 
IntBinaryPredicate - Interface in org.neo4j.graphalgo.api
 
INTEGER_DEFAULT_FALLBACK - Static variable in class org.neo4j.graphalgo.api.DefaultValue
 
InternalImporter - Class in org.neo4j.graphalgo.core.loading
 
InternalImporter.CreateScanner - Interface in org.neo4j.graphalgo.core.loading
 
internalRelationshipTypes(GraphStore) - Method in interface org.neo4j.graphalgo.config.AlgoBaseConfig
 
intersectAll(long, IntersectionConsumer) - Method in interface org.neo4j.graphalgo.api.RelationshipIntersect
 
intersectAll(long, IntersectionConsumer) - Method in class org.neo4j.graphalgo.core.huge.GraphIntersect
 
intersection() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
intersection() - Method in interface org.neo4j.graphalgo.api.Graph
 
intersection(long) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
intersection(long) - Method in interface org.neo4j.graphalgo.api.Graph
 
intersection(long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
intersection(long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
intersection(long) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
intersection(LongHashSet, LongHashSet) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
intersection2(long[], long[]) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
intersection3(long[], long[]) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
intersection4(long[], long[]) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
IntersectionConsumer - Interface in org.neo4j.graphalgo.api
 
Intersections - Class in org.neo4j.graphalgo.core.utils
 
Intersections() - Constructor for class org.neo4j.graphalgo.core.utils.Intersections
 
IntPointer(int) - Constructor for class org.neo4j.graphalgo.core.utils.Pointer.IntPointer
 
isAsynchronous() - Method in interface org.neo4j.graphalgo.beta.pregel.PregelConfig
 
isEmpty() - Method in class org.neo4j.graphalgo.AbstractNodeProjections
 
isEmpty() - Method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
isEmpty() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
isEmpty() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
isEmpty() - Method in interface org.neo4j.graphalgo.api.Graph
 
isEmpty() - Method in interface org.neo4j.graphalgo.api.NodePropertyStore
 
isEmpty() - Method in interface org.neo4j.graphalgo.api.RelationshipPropertyStore
 
isEmpty() - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveCollection
 
isEmpty() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntStack
 
isEmpty() - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
isEmpty() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Returns true iff no bit is set.
isEmpty() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArrayQueue
 
isEmpty() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArrayStack
 
isEmpty() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
 
isEmpty() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongDoubleMap
 
isEmpty() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
 
isEmpty() - Method in class org.neo4j.graphalgo.core.utils.paged.PagedLongStack
 
isEnabled() - Method in enum org.neo4j.graphalgo.utils.GdsFeatureToggles
 
isFictitiousLoading() - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
isFull() - Method in class org.neo4j.graphalgo.core.loading.RecordsBatchBuffer
 
isIncremental() - Method in interface org.neo4j.graphalgo.config.SeedConfig
 
isInitialSuperstep() - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext.ComputeContext
Indicates if the current superstep is the first superstep.
isInvalidLicense() - Method in class org.neo4j.graphalgo.core.GdsEdition
 
isMultiGraph() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
isMultiGraph() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
isMultiGraph() - Method in interface org.neo4j.graphalgo.api.Graph
Whether the graph is guaranteed to have no parallel relationships.
isMultiGraph() - Method in interface org.neo4j.graphalgo.api.Relationships.Topology
 
isMultiGraph() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
isMultiGraph() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
isOnCommunityEdition() - Method in class org.neo4j.graphalgo.core.GdsEdition
 
isOnEnterpriseEdition() - Method in class org.neo4j.graphalgo.core.GdsEdition
 
isPowerOfTwo(int) - Static method in class org.neo4j.graphalgo.core.utils.BitUtil
 
isPowerOfTwo(long) - Static method in class org.neo4j.graphalgo.core.utils.BitUtil
 
isTracking(AllocationTracker) - Static method in interface org.neo4j.graphalgo.core.utils.mem.AllocationTracker
 
isUndirected() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
isUndirected() - Method in interface org.neo4j.graphalgo.api.Graph
 
isUndirected() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
isUndirected() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
isValid() - Method in interface org.neo4j.graphalgo.core.SignatureTool.LicenseCheckResult
 
iteration() - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.ComputeStep
 
IterationsConfig - Interface in org.neo4j.graphalgo.config
 
iterator() - Method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
iterator() - Method in class org.neo4j.graphalgo.api.BatchNodeIterable.IdIterable
 
iterator() - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.Messages
 
iterator() - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntIterable
 
iterator() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntStack
 
iterator() - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongIterable
 
iterator() - Method in class org.neo4j.graphalgo.core.utils.LazyBatchCollection
 
iterator() - Method in class org.neo4j.graphalgo.core.utils.LazyMappingCollection
 
iterator() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
 
iterator() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
 
iterator() - Method in class org.neo4j.graphalgo.core.utils.SetBitsIterable
 
iterator(int...) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
 
iterator(long...) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
iterator(Resource, long...) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongResourceCollections
 

J

join(Collection<String>) - Static method in class org.neo4j.graphalgo.utils.StringJoining
 
join(Collection<String>, CharSequence) - Static method in class org.neo4j.graphalgo.utils.StringJoining
 
join(Collection<String>, CharSequence, CharSequence, CharSequence) - Static method in class org.neo4j.graphalgo.utils.StringJoining
 
join(Stream<String>) - Static method in class org.neo4j.graphalgo.utils.StringJoining
 
join(Stream<String>, CharSequence) - Static method in class org.neo4j.graphalgo.utils.StringJoining
 
joinVerbose(Collection<String>) - Static method in class org.neo4j.graphalgo.utils.StringJoining
 

K

KernelAllocationTracker - Class in org.neo4j.graphalgo.core.utils.mem
 
key() - Method in interface org.neo4j.graphalgo.api.NodeProperty
 
key() - Method in interface org.neo4j.graphalgo.api.RelationshipProperty
 
keySet() - Method in interface org.neo4j.graphalgo.api.NodePropertyStore
 
keySet() - Method in interface org.neo4j.graphalgo.api.RelationshipPropertyStore
 

L

label() - Method in class org.neo4j.graphalgo.AbstractNodeProjection
 
LABEL_KEY - Static variable in class org.neo4j.graphalgo.AbstractNodeProjection
 
labelIds() - Method in class org.neo4j.graphalgo.core.loading.NodesBatchBuffer
 
labelProjection() - Method in class org.neo4j.graphalgo.AbstractNodeProjections
 
labels() - Method in class org.neo4j.graphalgo.core.loading.MultipleNodeLabelIndexReference
 
labels() - Method in class org.neo4j.graphalgo.core.loading.NodeCursorReference
 
labels() - Method in class org.neo4j.graphalgo.core.loading.NodeLabelIndexReference
 
labels() - Method in class org.neo4j.graphalgo.core.loading.NodeRecordReference
 
labels() - Method in interface org.neo4j.graphalgo.core.loading.NodeReference
 
LazyBatchCollection<T> - Class in org.neo4j.graphalgo.core.utils
 
LazyBatchCollection.BatchSupplier<T> - Interface in org.neo4j.graphalgo.core.utils
 
LazyMappingCollection<T,​U> - Class in org.neo4j.graphalgo.core.utils
 
length() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList.Cursor
 
length() - Method in class org.neo4j.graphalgo.core.loading.CompressedLongArray
 
length() - Method in class org.neo4j.graphalgo.core.loading.RecordsBatchBuffer
 
length() - Method in class org.neo4j.graphalgo.core.utils.AtomicDoubleArray
return capacity
limit - Variable in class org.neo4j.graphalgo.core.utils.paged.HugeCursor
the limit of the array, exclusive – the first index not to be contained
LINEAR_SEARCH_LIMIT - Static variable in class org.neo4j.graphalgo.core.utils.ArrayUtil
 
linearSearch(int[], int, int) - Static method in class org.neo4j.graphalgo.core.utils.ArrayUtil
 
linearSearch2(int[], int, int, int) - Static method in class org.neo4j.graphalgo.core.utils.ArrayUtil
 
linearSearch2index(int[], int, int, int) - Static method in class org.neo4j.graphalgo.core.utils.ArrayUtil
 
linearSearchIndex(int[], int, int) - Static method in class org.neo4j.graphalgo.core.utils.ArrayUtil
 
list() - Method in interface org.neo4j.graphalgo.api.Relationships.Topology
 
list(String) - Static method in class org.neo4j.graphalgo.core.model.ModelCatalog
 
list(String, String) - Static method in class org.neo4j.graphalgo.core.model.ModelCatalog
 
listOf(String...) - Static method in class org.neo4j.graphalgo.NodeLabel
 
listOf(String...) - Static method in class org.neo4j.graphalgo.RelationshipType
 
loadCsvFileUrlRoot() - Static method in class org.neo4j.graphalgo.core.Settings
 
loadingContext - Variable in class org.neo4j.graphalgo.api.GraphStoreFactory
 
loadPropertyTokens(Map<? extends ElementIdentifier, ? extends ElementProjection>, TokenRead) - Method in class org.neo4j.graphalgo.core.GraphDimensionsReader
 
log() - Method in interface org.neo4j.graphalgo.api.GraphLoaderContext
 
logFinish() - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
logFinish(String) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
logLoadingSummary(GraphStore, Optional<AllocationTracker>) - Method in class org.neo4j.graphalgo.api.CSRGraphStoreFactory
 
logMessage(String) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
logMessage(Supplier<String>) - Method in class org.neo4j.graphalgo.core.utils.BatchingProgressLogger
 
logMessage(Supplier<String>) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
logMessage(Supplier<String>) - Method in enum org.neo4j.graphalgo.core.utils.ProgressLogger.NullProgressLogger
 
logMessage(Supplier<String>) - Method in class org.neo4j.graphalgo.core.utils.ProgressLoggerAdapter
Deprecated.
 
logProgress() - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
logProgress(double) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
Deprecated.
logProgress(double, double) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
Deprecated.
logProgress(double, double, Supplier<String>) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
Deprecated.
logProgress(double, Supplier<String>) - Method in class org.neo4j.graphalgo.core.utils.BatchingProgressLogger
 
logProgress(double, Supplier<String>) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
Deprecated.
logProgress(double, Supplier<String>) - Method in enum org.neo4j.graphalgo.core.utils.ProgressLogger.NullProgressLogger
 
logProgress(double, Supplier<String>) - Method in class org.neo4j.graphalgo.core.utils.ProgressLoggerAdapter
Deprecated.
 
logProgress(long) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
logProgress(long, Supplier<String>) - Method in class org.neo4j.graphalgo.core.utils.BatchingProgressLogger
 
logProgress(long, Supplier<String>) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
logProgress(long, Supplier<String>) - Method in enum org.neo4j.graphalgo.core.utils.ProgressLogger.NullProgressLogger
 
logProgress(long, Supplier<String>) - Method in class org.neo4j.graphalgo.core.utils.ProgressLoggerAdapter
Deprecated.
 
logProgress(Supplier<String>) - Method in class org.neo4j.graphalgo.core.utils.BatchingProgressLogger
 
logProgress(Supplier<String>) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
logProgress(Supplier<String>) - Method in enum org.neo4j.graphalgo.core.utils.ProgressLogger.NullProgressLogger
 
logProgress(Supplier<String>) - Method in class org.neo4j.graphalgo.core.utils.ProgressLoggerAdapter
Deprecated.
 
logStart() - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
logStart(String) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
LONG - org.neo4j.graphalgo.api.nodeproperties.ValueType
 
LONG_ARRAY - org.neo4j.graphalgo.api.nodeproperties.ValueType
 
LONG_DEFAULT_FALLBACK - Static variable in class org.neo4j.graphalgo.api.DefaultValue
 
LongArrayNodeProperties - Interface in org.neo4j.graphalgo.api.nodeproperties
 
longArrayNodeValue(String) - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext.ComputeContext
Returns the node value for the given node schema key.
longArrayProperties(String) - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.CompositeNodeValue
 
longArrayValue() - Method in class org.neo4j.graphalgo.api.DefaultValue
 
longArrayValue(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.LongArrayNodeProperties
 
longArrayValue(long) - Method in interface org.neo4j.graphalgo.api.NodeProperties
 
longArrayValue(long) - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
longArrayValue(long) - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
longArrayValue(String, long) - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.CompositeNodeValue
 
LongIfChangedNodeProperties - Class in org.neo4j.graphalgo.api.nodeproperties
 
LongNodeProperties - Interface in org.neo4j.graphalgo.api.nodeproperties
 
LongNodePropertiesBuilder - Class in org.neo4j.graphalgo.core.loading.nodeproperties
 
LongNodePropertiesBuilder(long, DefaultValue, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.loading.nodeproperties.LongNodePropertiesBuilder
 
longNodeValue(String) - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext.ComputeContext
Returns the node value for the given node schema key.
LongNullPropertyMap(long) - Constructor for class org.neo4j.graphalgo.core.loading.NullPropertyMap.LongNullPropertyMap
 
LongPageCreator - Class in org.neo4j.graphalgo.core.utils.paged
 
LongPointer(long) - Constructor for class org.neo4j.graphalgo.core.utils.Pointer.LongPointer
 
longProperties(String) - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.CompositeNodeValue
 
longToIntConsumer(IntConsumer) - Static method in interface org.neo4j.graphalgo.core.heavyweight.Converters
 
longToIntConsumer(IntBinaryPredicate) - Static method in interface org.neo4j.graphalgo.core.heavyweight.Converters
 
longToIntConsumer(Converters.IntIntDoublePredicate) - Static method in interface org.neo4j.graphalgo.core.heavyweight.Converters
 
longToIntPredicate(IntPredicate) - Static method in interface org.neo4j.graphalgo.core.heavyweight.Converters
 
longValue() - Method in class org.neo4j.graphalgo.api.DefaultValue
 
longValue(long) - Method in class org.neo4j.graphalgo.api.nodeproperties.ConsecutiveLongNodeProperties
 
longValue(long) - Method in class org.neo4j.graphalgo.api.nodeproperties.LongIfChangedNodeProperties
 
longValue(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.LongNodeProperties
 
longValue(long) - Method in interface org.neo4j.graphalgo.api.NodeProperties
 
longValue(long) - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
longValue(long) - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
longValue(long) - Method in class org.neo4j.graphalgo.core.loading.NullPropertyMap.LongNullPropertyMap
 
longValue(String, long) - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.CompositeNodeValue
 
lookup(String) - Static method in enum org.neo4j.graphalgo.core.Aggregation
 
lowerCase() - Method in enum org.neo4j.graphalgo.beta.pregel.annotation.GDSMode
 

M

map(DoubleUnaryOperator) - Method in class org.neo4j.graphalgo.core.utils.Pointer.DoublePointer
 
map(IntFunction<T>, PrimitiveIntIterator) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
 
map(IntUnaryOperator) - Method in class org.neo4j.graphalgo.core.utils.Pointer.IntPointer
 
map(LongFunction<T>, PrimitiveLongIterator) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
map(LongUnaryOperator) - Method in class org.neo4j.graphalgo.core.utils.Pointer.LongPointer
 
map(UnaryOperator<G>) - Method in class org.neo4j.graphalgo.core.utils.Pointer.GenericPointer
 
map(Pointer.BooleanUnaryOperator) - Method in class org.neo4j.graphalgo.core.utils.Pointer.BoolPointer
 
mappings() - Method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
mapToSet(PrimitiveIntIterator, IntFunction<T>) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
 
max - Variable in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
max(int) - Static method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongLongPriorityQueue
 
max(int) - Static method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
max(MemoryRange) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
MAX - org.neo4j.graphalgo.core.Aggregation
 
MAX_ARRAY_LENGTH - Static variable in class org.neo4j.graphalgo.core.utils.ArrayUtil
 
MAX_ARRAY_LENGTH_SHIFT - Static variable in enum org.neo4j.graphalgo.utils.GdsFeatureToggles
 
MAX_ARRAY_LENGTH_SHIFT_DEFAULT_SETTING - Static variable in enum org.neo4j.graphalgo.utils.GdsFeatureToggles
 
MAX_ITERATIONS_KEY - Static variable in interface org.neo4j.graphalgo.config.IterationsConfig
 
MAX_NODE_COUNT - Static variable in interface org.neo4j.graphalgo.core.utils.partition.Partition
 
MAXIMUM_LOG_INTERVAL - Static variable in class org.neo4j.graphalgo.core.utils.BatchingProgressLogger
 
maxIterations() - Method in interface org.neo4j.graphalgo.config.IterationsConfig
 
maxRelCount() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
MEMORY_ESTIMATION - Static variable in class org.neo4j.graphalgo.core.utils.paged.dss.NonInrementalDisjointSetStruct
Deprecated.
 
memoryEstimation() - Method in class org.neo4j.graphalgo.api.GraphStoreFactory
 
memoryEstimation() - Static method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyOffsets
 
memoryEstimation() - Method in class org.neo4j.graphalgo.core.loading.CypherFactory
 
memoryEstimation() - Static method in class org.neo4j.graphalgo.core.loading.IdMap
 
memoryEstimation() - Method in class org.neo4j.graphalgo.core.loading.NativeFactory
 
memoryEstimation() - Static method in class org.neo4j.graphalgo.core.loading.nodeproperties.NodePropertiesFromStoreBuilder
 
memoryEstimation() - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryEstimationWithDimensions
 
memoryEstimation() - Static method in class org.neo4j.graphalgo.core.utils.paged.dss.IncrementalDisjointSetStruct
Deprecated.
 
memoryEstimation() - Static method in class org.neo4j.graphalgo.core.utils.paged.dss.NonInrementalDisjointSetStruct
Deprecated.
 
memoryEstimation() - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
 
memoryEstimation() - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
 
memoryEstimation(boolean) - Static method in class org.neo4j.graphalgo.core.utils.paged.dss.HugeAtomicDisjointSetStruct
 
memoryEstimation(int) - Static method in class org.neo4j.graphalgo.core.utils.paged.TrackingLongDoubleHashMap
 
memoryEstimation(int) - Static method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongLongPriorityQueue
 
memoryEstimation(int) - Static method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
memoryEstimation(int, long) - Static method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyOffsets
 
memoryEstimation(long) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
 
memoryEstimation(long) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
 
memoryEstimation(long) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
 
memoryEstimation(long) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
 
memoryEstimation(long) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
 
memoryEstimation(long) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
 
memoryEstimation(long, long) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray
 
memoryEstimation(PregelSchema) - Static method in class org.neo4j.graphalgo.beta.pregel.Pregel
 
memoryEstimation(MemoryEstimation) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
 
MemoryEstimation - Interface in org.neo4j.graphalgo.core.utils.mem
A description of an object that has resources residing in memory.
MemoryEstimations - Class in org.neo4j.graphalgo.core.utils.mem
 
MemoryEstimations.Builder - Class in org.neo4j.graphalgo.core.utils.mem
 
MemoryEstimations.MemoryEstimationSetup - Interface in org.neo4j.graphalgo.core.utils.mem
 
MemoryEstimations.MemoryRangeModifier - Interface in org.neo4j.graphalgo.core.utils.mem
 
MemoryEstimationWithDimensions - Interface in org.neo4j.graphalgo.core.utils.mem
 
MemoryRange - Class in org.neo4j.graphalgo.core.utils.mem
Represents a range of positive byte values.
MemoryResident - Interface in org.neo4j.graphalgo.core.utils.mem
A calculation of an object that has resources residing in memory.
memoryTransactionMaxSize() - Static method in class org.neo4j.graphalgo.core.Settings
 
memoryTree - Variable in class org.neo4j.graphalgo.core.utils.mem.MemoryTreeWithDimensions
 
MemoryTree - Interface in org.neo4j.graphalgo.core.utils.mem
A tree shaped description of an object that has resources residing in memory.
MemoryTreeWithDimensions - Class in org.neo4j.graphalgo.core.utils.mem
 
MemoryTreeWithDimensions(MemoryTree, GraphDimensions) - Constructor for class org.neo4j.graphalgo.core.utils.mem.MemoryTreeWithDimensions
 
memoryUsage() - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryTree
 
MemoryUsage - Class in org.neo4j.graphalgo.core.utils.mem
 
merge(double, double) - Method in enum org.neo4j.graphalgo.core.Aggregation
 
merge(SequentialDisjointSetStruct) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.SequentialDisjointSetStruct
Deprecated.
Merges the given DisjointSetStruct into this one.
mergeWith(PropertyMappings) - Method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
message() - Method in interface org.neo4j.graphalgo.core.SignatureTool.LicenseCheckResult
 
min - Variable in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
min(int) - Static method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongLongPriorityQueue
 
min(int) - Static method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
MIN - org.neo4j.graphalgo.core.Aggregation
 
MIN_PAGE_SIZE - Static variable in class org.neo4j.graphalgo.core.loading.ImportSizing
 
Model<DATA,​CONFIG extends ModelConfig & BaseConfig> - Interface in org.neo4j.graphalgo.core.model
 
MODEL_NAME_KEY - Static variable in interface org.neo4j.graphalgo.config.ModelConfig
 
MODEL_TYPE_KEY - Static variable in interface org.neo4j.graphalgo.config.ModelConfig
 
ModelCatalog - Class in org.neo4j.graphalgo.core.model
 
ModelConfig - Interface in org.neo4j.graphalgo.config
 
modelName() - Method in interface org.neo4j.graphalgo.config.ModelConfig
 
modes() - Method in annotation type org.neo4j.graphalgo.beta.pregel.annotation.PregelProcedure
The procedure modes to generate.
modificationTime() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
modificationTime() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
modify(MemoryRange, GraphDimensions, int) - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.MemoryRangeModifier
 
MultipleNodeLabelIndexReference - Class in org.neo4j.graphalgo.core.loading
 
MutableIntValue - Class in org.neo4j.graphalgo.core.loading
 
MutableIntValue() - Constructor for class org.neo4j.graphalgo.core.loading.MutableIntValue
 
MUTATE - org.neo4j.graphalgo.beta.pregel.annotation.GDSMode
 
MUTATE_PROPERTY_KEY - Static variable in interface org.neo4j.graphalgo.config.MutatePropertyConfig
 
MutateConfig - Interface in org.neo4j.graphalgo.config
 
mutateProperty() - Method in interface org.neo4j.graphalgo.beta.pregel.PregelConfig
 
mutateProperty() - Method in interface org.neo4j.graphalgo.config.MutatePropertyConfig
 
MutatePropertyConfig - Interface in org.neo4j.graphalgo.config
 
MutateRelationshipConfig - Interface in org.neo4j.graphalgo.config
 
mutateRelationshipType() - Method in interface org.neo4j.graphalgo.config.MutateRelationshipConfig
 

N

name - Variable in class org.neo4j.graphalgo.ElementIdentifier
 
name() - Method in annotation type org.neo4j.graphalgo.beta.pregel.annotation.PregelProcedure
The namespace and name for the procedure, as a period-separated string.
name() - Method in interface org.neo4j.graphalgo.core.model.Model
 
name() - Method in class org.neo4j.graphalgo.ElementIdentifier
 
NativeFactory - Class in org.neo4j.graphalgo.core.loading
 
NativeFactory(GraphCreateFromStoreConfig, GraphLoaderContext) - Constructor for class org.neo4j.graphalgo.core.loading.NativeFactory
 
NativeFactory(GraphCreateFromStoreConfig, GraphLoaderContext, GraphDimensions) - Constructor for class org.neo4j.graphalgo.core.loading.NativeFactory
 
NativeNodePropertyImporter - Class in org.neo4j.graphalgo.core.loading
 
NativeNodePropertyImporter.Builder - Class in org.neo4j.graphalgo.core.loading
 
NATURAL - org.neo4j.graphalgo.Orientation
 
nearbyPowerOfTwo(int) - Static method in class org.neo4j.graphalgo.core.utils.BitUtil
 
nearbyPowerOfTwo(long) - Static method in class org.neo4j.graphalgo.core.utils.BitUtil
 
neo4jHome() - Static method in class org.neo4j.graphalgo.core.Settings
 
neoPropertyKey() - Method in class org.neo4j.graphalgo.PropertyMapping
property name in the graph (a:Node {`propertyKey`:xyz})
newAdjacencyListBuilder() - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListBuilderFactory
 
newAllocator() - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListBuilder
 
newAllocator() - Method in class org.neo4j.graphalgo.core.loading.TransientAdjacencyListBuilder
 
newArray(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
Creates a new array of the given size, tracking the memory requirements into the given AllocationTracker.
newArray(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
Creates a new array of the given size, tracking the memory requirements into the given AllocationTracker.
newArray(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
Creates a new array of the given size, tracking the memory requirements into the given AllocationTracker.
newArray(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Creates a new array of the given size, tracking the memory requirements into the given AllocationTracker.
newArray(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Creates a new array of the given size, tracking the memory requirements into the given AllocationTracker.
newArray(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.PagedAtomicDoubleArray
 
newArray(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.PagedAtomicIntegerArray
 
newArray(long, DoublePageCreator, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
Creates a new array of the given size, tracking the memory requirements into the given AllocationTracker.
newArray(long, LongPageCreator, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
Creates a new array of the given size, tracking the memory requirements into the given AllocationTracker.
newArray(Class<T>, long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
Creates a new array of the given size, tracking the memory requirements into the given AllocationTracker.
newBatch(long, long) - Method in interface org.neo4j.graphalgo.core.utils.LazyBatchCollection.BatchSupplier
 
newCopy(long[]) - Static method in class org.neo4j.graphalgo.core.loading.RadixSort
 
newCursor() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
Returns a new HugeCursor for this array.
newCursor() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Returns a new HugeCursor for this array.
newCursor() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Returns a new HugeCursor for this array.
newCursor() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
Returns a new HugeCursor for this array.
newHistogram(int) - Static method in class org.neo4j.graphalgo.core.loading.RadixSort
 
newImporter(long, PrimitiveLongIterable) - Method in interface org.neo4j.graphalgo.core.loading.HugeParallelGraphImporter
Return a new Runnable.
newInstance(ExtensionContext, EnterpriseLicensingExtension.Dependencies) - Method in class org.neo4j.graphalgo.core.EnterpriseLicensingExtension
 
newInstance(ExtensionContext, AllocationTrackerExtensionFactory.Dependencies) - Method in class org.neo4j.graphalgo.core.utils.mem.AllocationTrackerExtensionFactory
 
newInstance(ExtensionContext, GcListenerExtension.Dependencies) - Method in class org.neo4j.graphalgo.core.utils.mem.GcListenerExtension
 
newLogger(Log, long, String, int) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger.ProgressLoggerFactory
 
newOffsets(long[][]) - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyOffsetsFactory
 
newPage() - Method in class org.neo4j.graphalgo.core.utils.paged.PageAllocator
 
newPage() - Method in interface org.neo4j.graphalgo.core.utils.paged.PageAllocator.PageFactory
 
newPage(AllocationTracker) - Method in interface org.neo4j.graphalgo.core.utils.paged.PageAllocator.PageFactory
 
newQueue(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArrayQueue
 
newScanner(int, SecureTransaction) - Method in interface org.neo4j.graphalgo.core.loading.StoreScanner.Factory
 
newStack(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArrayStack
 
next - Variable in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongBaseIterator
 
next() - Method in class org.neo4j.graphalgo.api.BatchNodeIterable.IdIterator
 
next() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections.PrimitiveIntBaseIterator
 
next() - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntIterator
 
next() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongBaseIterator
 
next() - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongIterator
 
next() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeCursor
Try to load the next page and return the success of this load.
next(int) - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections.PrimitiveIntBaseIterator
Called from inside an implementation of PrimitiveIntCollections.PrimitiveIntBaseIterator.fetchNext() if a next item was found.
next(long) - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongBaseIterator
Called from inside an implementation of PrimitiveLongCollections.PrimitiveLongBaseIterator.fetchNext() if a next item was found.
nextHighestPowerOfTwo(int) - Static method in class org.neo4j.graphalgo.core.utils.BitUtil
returns the next highest power of two, or the current value if it's already a power of two or zero
nextHighestPowerOfTwo(long) - Static method in class org.neo4j.graphalgo.core.utils.BitUtil
returns the next highest power of two, or the current value if it's already a power of two or zero
nextLong() - Method in interface org.neo4j.graphalgo.api.PropertyCursor
Read the next target id.
nextLong() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList.Cursor
 
nextLong() - Method in class org.neo4j.graphalgo.core.utils.RandomLongIterator
 
nextVLong() - Method in interface org.neo4j.graphalgo.api.AdjacencyCursor
Read and decode the next target id.
nextVLong() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyCursor
 
nextVLong() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList.DecompressingCursor
 
NO - org.neo4j.graphalgo.config.RandomGraphGeneratorConfig.AllowSelfLoops
 
NO_MESSAGE - Static variable in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
NO_PROPERTY_VALUE - Static variable in class org.neo4j.graphalgo.core.huge.HugeGraph
 
NO_PROPERTY_VALUE - Static variable in class org.neo4j.graphalgo.core.loading.CypherNodePropertyImporter
 
NO_SUCH_LABEL - Static variable in interface org.neo4j.graphalgo.core.GraphDimensions
 
NO_SUCH_RELATIONSHIP_TYPE - Static variable in interface org.neo4j.graphalgo.core.GraphDimensions
 
NODE_COUNT_KEY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
NODE_LABELS_KEY - Static variable in interface org.neo4j.graphalgo.config.AlgoBaseConfig
 
NODE_PROJECTION_KEY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
NODE_PROPERTIES_KEY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
NODE_QUERY_KEY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
nodeCount - Variable in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
nodeCount() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
nodeCount() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
nodeCount() - Method in interface org.neo4j.graphalgo.api.IdMapping
Number of mapped nodeIds.
nodeCount() - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext
Number of nodes in the input graph.
nodeCount() - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
nodeCount() - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
nodeCount() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
nodeCount() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
nodeCount() - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
nodeCount() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
nodeCount() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
nodeCount() - Method in class org.neo4j.graphalgo.core.loading.IdMap
 
nodeCount() - Method in interface org.neo4j.graphalgo.core.utils.partition.Partition
 
nodeCount(long) - Method in class org.neo4j.graphalgo.core.loading.NativeNodePropertyImporter.Builder
 
NodeCursorReference - Class in org.neo4j.graphalgo.core.loading
 
NodeFilteredGraph - Class in org.neo4j.graphalgo.core.huge
 
NodeFilteredGraph(CSRGraph, IdMap) - Constructor for class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
nodeId - Variable in exception org.neo4j.graphalgo.core.loading.DuplicateNodeIdException
 
nodeId() - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext
The identifier of the node that is currently processed.
nodeId() - Method in class org.neo4j.graphalgo.core.loading.MultipleNodeLabelIndexReference
 
nodeId() - Method in class org.neo4j.graphalgo.core.loading.NodeCursorReference
 
nodeId() - Method in class org.neo4j.graphalgo.core.loading.NodeLabelIndexReference
 
nodeId() - Method in class org.neo4j.graphalgo.core.loading.NodeRecordReference
 
nodeId() - Method in interface org.neo4j.graphalgo.core.loading.NodeReference
 
NodeImporter - Interface in org.neo4j.graphalgo.core.loading
 
nodeIterator() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
nodeIterator() - Method in interface org.neo4j.graphalgo.api.NodeIterator
 
nodeIterator() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
nodeIterator() - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
nodeIterator() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
nodeIterator() - Method in class org.neo4j.graphalgo.core.loading.IdMap
 
NodeIterator - Interface in org.neo4j.graphalgo.api
Iterate over each node Id until either all nodes have been consumed or the consumer decides to stop the iteration.
NodeLabel - Class in org.neo4j.graphalgo
 
NodeLabel(String) - Constructor for class org.neo4j.graphalgo.NodeLabel
 
nodeLabelIdentifiers(GraphStore) - Method in interface org.neo4j.graphalgo.config.AlgoBaseConfig
 
nodeLabelIdentifiers(GraphStore) - Method in interface org.neo4j.graphalgo.config.GraphExportNodePropertiesConfig
 
NodeLabelIndexReference - Class in org.neo4j.graphalgo.core.loading
 
nodeLabels() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
nodeLabels() - Method in interface org.neo4j.graphalgo.config.AlgoBaseConfig
 
nodeLabels() - Method in interface org.neo4j.graphalgo.config.GraphExportNodePropertiesConfig
 
nodeLabels() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
nodeLabels(long) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
nodeLabels(long) - Method in interface org.neo4j.graphalgo.api.Graph
 
nodeLabels(long) - Method in interface org.neo4j.graphalgo.api.NodeMapping
 
nodeLabels(long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
nodeLabels(long) - Method in class org.neo4j.graphalgo.core.loading.IdMap
 
nodeLabelTokens() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
nodeMapping() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
nodeMapping() - Method in interface org.neo4j.graphalgo.api.Graph
 
nodeMapping() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
nodeMapping() - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
nodeMapping() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
NodeMapping - Interface in org.neo4j.graphalgo.api
 
nodeProjections() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
nodeProjections() - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
nodeProperties() - Method in interface org.neo4j.graphalgo.api.NodePropertyStore
 
nodeProperties() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
nodeProperties() - Method in interface org.neo4j.graphalgo.config.GraphExportNodePropertiesConfig
 
nodeProperties() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
nodeProperties(String) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
nodeProperties(String) - Method in interface org.neo4j.graphalgo.api.NodePropertyContainer
Return the property values for a property key
nodeProperties(String) - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext.InitContext
Returns the property values for the given property key.
nodeProperties(String) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
nodeProperties(String) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
nodeProperties(String) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
NodeProperties - Interface in org.neo4j.graphalgo.api
 
NodePropertiesFromStoreBuilder - Class in org.neo4j.graphalgo.core.loading.nodeproperties
 
NodeProperty - Interface in org.neo4j.graphalgo.api
 
NodePropertyAccessor - Interface in org.neo4j.graphalgo.core.mutate
 
NodePropertyContainer - Interface in org.neo4j.graphalgo.api
Getter interface for node properties.
nodePropertyCount() - Method in interface org.neo4j.graphalgo.core.utils.export.GraphStoreExport.ImportedProperties
 
NodePropertyExporter - Class in org.neo4j.graphalgo.core.write
 
NodePropertyExporter(SecureTransaction, long, LongUnaryOperator, TerminationFlag, ProgressLogger, int, ExecutorService) - Constructor for class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
NodePropertyExporter.Builder - Class in org.neo4j.graphalgo.core.write
 
NodePropertyExporter.NodeProperty - Interface in org.neo4j.graphalgo.core.write
 
NodePropertyExporter.ResolvedNodeProperty - Interface in org.neo4j.graphalgo.core.write
 
NodePropertyExporter.WriteConsumer - Interface in org.neo4j.graphalgo.core.write
 
nodePropertyKeys() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
nodePropertyKeys() - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext.InitContext
Returns the node property keys stored in the input graph.
nodePropertyKeys() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
nodePropertyKeys(Collection<NodeLabel>) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
nodePropertyKeys(NodeLabel) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
nodePropertyKeys(NodeLabel) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
nodePropertyState(String) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
nodePropertyState(String) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
NodePropertyStore - Interface in org.neo4j.graphalgo.api
 
NodePropertyStore.Builder - Class in org.neo4j.graphalgo.api
 
nodePropertyTokens() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
nodePropertyType(NodeLabel, String) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
nodePropertyType(NodeLabel, String) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
nodePropertyValues() - Method in interface org.neo4j.graphalgo.api.NodePropertyStore
 
nodePropertyValues(String) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
nodePropertyValues(String) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
nodePropertyValues(NodeLabel, String) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
nodePropertyValues(NodeLabel, String) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
nodeQuery() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
NodeRecordReference - Class in org.neo4j.graphalgo.core.loading
 
NodeReference - Interface in org.neo4j.graphalgo.core.loading
 
nodes() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
nodes() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
nodes(Collector) - Method in class org.neo4j.graphalgo.core.utils.export.GraphStoreInput
 
NodesBatchBuffer - Class in org.neo4j.graphalgo.core.loading
 
NodesBuilder - Class in org.neo4j.graphalgo.core.loading.construction
 
NodeScannerFactory - Class in org.neo4j.graphalgo.core.loading
 
nodeSchema() - Method in interface org.neo4j.graphalgo.api.schema.GraphSchema
 
NodeSchema - Interface in org.neo4j.graphalgo.api.schema
 
NodeSchema.Builder - Class in org.neo4j.graphalgo.api.schema
 
NodesScanner - Class in org.neo4j.graphalgo.core.loading
 
nodeValues() - Method in interface org.neo4j.graphalgo.beta.pregel.Pregel.PregelResult
 
NodeWeightConfig - Interface in org.neo4j.graphalgo.config
 
nodeWeightProperty() - Method in interface org.neo4j.graphalgo.config.NodeWeightConfig
 
NONE - org.neo4j.graphalgo.core.Aggregation
 
NonInrementalDisjointSetStruct - Class in org.neo4j.graphalgo.core.utils.paged.dss
Deprecated.
NonInrementalDisjointSetStruct(long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.dss.NonInrementalDisjointSetStruct
Deprecated.
Initialize the struct with the given size.
NoopDoubleCodec - Class in org.neo4j.graphalgo.core.loading
 
normalizePropertyValue(double) - Method in enum org.neo4j.graphalgo.core.Aggregation
 
NOT_FOUND - Static variable in interface org.neo4j.graphalgo.api.AdjacencyCursor
 
now() - Static method in class org.neo4j.graphalgo.core.utils.TimeUtil
 
NULL_CONTEXT_FOR_FICTITIOUS_LOADING - Static variable in interface org.neo4j.graphalgo.api.GraphLoaderContext
 
NULL_LOGGER - Static variable in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
NULL_TREE - Static variable in interface org.neo4j.graphalgo.core.utils.mem.MemoryTree
 
NullPropertyMap - Class in org.neo4j.graphalgo.core.loading
NodeProperties implementation which always returns a given default property value upon invocation.
NullPropertyMap() - Constructor for class org.neo4j.graphalgo.core.loading.NullPropertyMap
 
NullPropertyMap.DoubleNullPropertyMap - Class in org.neo4j.graphalgo.core.loading
 
NullPropertyMap.LongNullPropertyMap - Class in org.neo4j.graphalgo.core.loading
 
numberAlignedPartitioning(int, long, long) - Static method in class org.neo4j.graphalgo.core.utils.partition.PartitionUtils
 
numberOfMappings() - Method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
numberOfPages() - Method in class org.neo4j.graphalgo.core.loading.ImportSizing
 
numPages(long) - Method in class org.neo4j.graphalgo.core.utils.paged.PagedDataStructure
 
numPagesFor(long, int) - Static method in class org.neo4j.graphalgo.core.utils.paged.PageUtil
 
numPagesFor(long, int, long) - Static method in class org.neo4j.graphalgo.core.utils.paged.PageUtil
 

O

of(boolean) - Static method in enum org.neo4j.graphalgo.config.RandomGraphGeneratorConfig.AllowSelfLoops
 
of(double...) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
 
of(int...) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
 
of(int, long) - Static method in class org.neo4j.graphalgo.core.loading.ImportSizing
 
of(int, long, Supplier<T>, T[]) - Static method in class org.neo4j.graphalgo.core.utils.paged.PageAllocator
 
of(int, long, PageAllocator.PageFactory<T>, T[]) - Static method in class org.neo4j.graphalgo.core.utils.paged.PageAllocator
 
of(int, DoubleUnaryOperator) - Static method in class org.neo4j.graphalgo.core.utils.paged.DoublePageCreator
 
of(int, LongUnaryOperator) - Static method in class org.neo4j.graphalgo.core.utils.paged.LongPageCreator
 
of(long) - Static method in interface org.neo4j.graphalgo.core.GraphDimensions
 
of(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
of(long[]) - Static method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyOffsets
 
of(long...) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
 
of(long, long) - Static method in interface org.neo4j.graphalgo.core.GraphDimensions
 
of(long, long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
of(long, long) - Static method in interface org.neo4j.graphalgo.core.utils.partition.Partition
 
of(long, long, LazyBatchCollection.BatchSupplier<T>) - Static method in class org.neo4j.graphalgo.core.utils.LazyBatchCollection
 
of(long, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArrayBuilder
 
of(long, AllocationTracker, DefaultValue) - Static method in class org.neo4j.graphalgo.core.loading.nodeproperties.NodePropertiesFromStoreBuilder
 
of(long, Orientation, boolean, AdjacencyList, AdjacencyOffsets, AdjacencyList, AdjacencyOffsets, double) - Static method in interface org.neo4j.graphalgo.api.Relationships
 
of(String) - Static method in class org.neo4j.graphalgo.NodeLabel
 
of(String) - Static method in class org.neo4j.graphalgo.RelationshipType
 
of(Class<?>) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
Creates a MemoryEstimation for the fields of the given class.
of(Object) - Static method in class org.neo4j.graphalgo.api.DefaultValue
 
of(String) - Static method in class org.neo4j.graphalgo.AbstractNodeProjection
 
of(String) - Static method in enum org.neo4j.graphalgo.Orientation
 
of(String) - Static method in class org.neo4j.graphalgo.PropertyMapping
 
of(String, Object) - Static method in class org.neo4j.graphalgo.PropertyMapping
Creates a PropertyMapping.
of(String, Object, Aggregation) - Static method in class org.neo4j.graphalgo.PropertyMapping
 
of(String, String) - Static method in interface org.neo4j.graphalgo.config.DeleteRelationshipsConfig
 
of(String, String, long, long, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
of(String, String, Object) - Static method in class org.neo4j.graphalgo.PropertyMapping
 
of(String, String, Object, Object, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
of(String, String, Object, Aggregation) - Static method in class org.neo4j.graphalgo.PropertyMapping
 
of(String, String, String, String, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
of(String, String, String, Optional<String>, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.GraphWriteRelationshipConfig
 
of(String, String, String, GraphSchema, D, C) - Static method in interface org.neo4j.graphalgo.core.model.Model
 
of(String, String, List<String>, List<String>, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.GraphRemoveNodePropertiesConfig
 
of(String, String, List<String>, List<String>, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.GraphStreamNodePropertiesConfig
 
of(String, String, List<String>, List<String>, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.GraphStreamRelationshipPropertiesConfig
 
of(String, String, List<String>, List<String>, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.config.GraphWriteNodePropertiesConfig
 
of(String, String, Aggregation) - Static method in class org.neo4j.graphalgo.PropertyMapping
 
of(String, Optional<String>, Optional<GraphCreateConfig>, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.beta.pregel.PregelConfig
 
of(String, GraphStore.PropertyState, NodeProperties) - Static method in interface org.neo4j.graphalgo.api.NodeProperty
 
of(String, Aggregation) - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
of(String, Aggregation) - Static method in class org.neo4j.graphalgo.PropertyMapping
 
of(String, CypherMapWrapper) - Static method in interface org.neo4j.graphalgo.core.utils.export.GraphStoreExportConfig
 
of(String, MemoryRange) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
 
of(String, MemoryResident) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
Creates a MemoryEstimation using the given MemoryResident function.
of(String, Orientation) - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
of(String, NumberType, GraphStore.PropertyState, Relationships.Properties) - Static method in interface org.neo4j.graphalgo.api.RelationshipProperty
 
of(Collection<T>, Function<T, U>) - Static method in class org.neo4j.graphalgo.core.utils.LazyMappingCollection
 
of(Consumer<ImmutableDeletionResult.Builder>) - Static method in interface org.neo4j.graphalgo.core.loading.DeletionResult
 
of(List<? extends CSRGraph>) - Static method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
of(Map<NodeLabel, Map<String, ValueType>>) - Static method in interface org.neo4j.graphalgo.api.schema.NodeSchema
 
of(Map<RelationshipType, Map<String, ValueType>>) - Static method in interface org.neo4j.graphalgo.api.schema.RelationshipSchema
 
of(Map<RelationshipType, RelationshipsBuilder>, ObjectLongMap<RelationshipType>, GraphDimensions) - Static method in interface org.neo4j.graphalgo.api.GraphStoreFactory.RelationshipImportResult
 
of(GraphLoaderContext, ProgressLogger, IdMapping, StoreScanner<RelationshipReference>, Collection<SingleTypeRelationshipImporter.Builder>) - Static method in class org.neo4j.graphalgo.core.loading.RelationshipsScanner
 
of(GraphStore, String, NodeProperties) - Static method in class org.neo4j.graphalgo.api.nodeproperties.LongIfChangedNodeProperties
 
of(GraphStore, GraphCreateConfig) - Static method in interface org.neo4j.graphalgo.core.loading.GraphStoreWithConfig
 
of(NodeSchema, RelationshipSchema) - Static method in interface org.neo4j.graphalgo.api.schema.GraphSchema
 
of(GraphDimensions, STORE) - Static method in interface org.neo4j.graphalgo.api.GraphStoreFactory.ImportResult
 
of(IdMap, Map<NodeLabel, Map<PropertyMapping, NodeProperties>>) - Static method in class org.neo4j.graphalgo.core.loading.IdsAndProperties
 
of(RelationshipsBatchBuffer...) - Static method in class org.neo4j.graphalgo.core.loading.CompositeRelationshipsBatchBuffer
 
of(SecureTransaction, Graph, TerminationFlag) - Static method in class org.neo4j.graphalgo.core.write.RelationshipExporter
 
of(SecureTransaction, StoreScanner<NodeReference>, LongSet, ProgressLogger, NodeImporter, NativeNodePropertyImporter, TerminationFlag) - Static method in class org.neo4j.graphalgo.core.loading.NodesScanner
 
of(NodePropertyExporter.NodeProperty, int) - Static method in interface org.neo4j.graphalgo.core.write.NodePropertyExporter.ResolvedNodeProperty
 
of(PropertyMapping...) - Static method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
of(GraphDatabaseService) - Static method in class org.neo4j.graphalgo.core.SecureTransaction
Creates a new SecureTransaction with AccessMode.Static.FULL access.
of(GraphDatabaseService, Transaction) - Static method in class org.neo4j.graphalgo.core.SecureTransaction
Creates a new SecureTransaction with the same SecurityContext as the provided Transaction.
of(GraphDatabaseService, Transaction, SecurityContext) - Static method in class org.neo4j.graphalgo.core.SecureTransaction
Creates a new SecureTransaction with the given SecurityContext, ignoring the context within the Transaction.
of(GraphDatabaseService, Graph, TerminationFlag) - Static method in class org.neo4j.graphalgo.core.write.RelationshipExporter
 
of(GraphDatabaseService, SecurityContext) - Static method in class org.neo4j.graphalgo.core.SecureTransaction
Creates a new SecureTransaction with the given SecurityContext.
of(NamedDatabaseId, HugeGraph, String, Optional<String>, int, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
of(NamedDatabaseId, IdMap, Map<NodeLabel, Map<String, NodeProperties>>, Map<RelationshipType, Relationships.Topology>, Map<RelationshipType, Map<String, Relationships.Properties>>, int, AllocationTracker) - Static method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
of(T...) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
 
ofArray(Class<T>) - Static method in class org.neo4j.graphalgo.core.utils.paged.PageAllocator
 
ofArray(Class<T>, int) - Static method in class org.neo4j.graphalgo.core.utils.paged.PageAllocator
 
offer(long, double) - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
offer(long, long, double) - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongLongPriorityQueue
 
offer(NodeReference) - Method in class org.neo4j.graphalgo.core.loading.NodesBatchBuffer
 
offer(RelationshipReference) - Method in class org.neo4j.graphalgo.core.loading.CompositeRelationshipsBatchBuffer
 
offer(RelationshipReference) - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
offer(Reference) - Method in interface org.neo4j.graphalgo.core.loading.StoreScanner.RecordConsumer
Imports the record at a given position and return the new position.
offset - Variable in class org.neo4j.graphalgo.core.utils.paged.HugeCursor
the offset into the array
offset() - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListPageSlice
Start offset for safe writes into the AdjacencyListPageSlice.page().
offsets() - Method in interface org.neo4j.graphalgo.api.Relationships.Topology
 
onlineBackupEnabled() - Static method in class org.neo4j.graphalgo.core.Settings
 
or(long, int) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Computes the bit-wise OR (|) of the existing value and the provided value at the given index.
or(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Computes the bit-wise OR (|) of the existing value and the provided value at the given index.
order() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleTriangularMatrix
 
org.neo4j.graphalgo - package org.neo4j.graphalgo
 
org.neo4j.graphalgo.api - package org.neo4j.graphalgo.api
 
org.neo4j.graphalgo.api.nodeproperties - package org.neo4j.graphalgo.api.nodeproperties
 
org.neo4j.graphalgo.api.schema - package org.neo4j.graphalgo.api.schema
 
org.neo4j.graphalgo.beta.generator - package org.neo4j.graphalgo.beta.generator
 
org.neo4j.graphalgo.beta.pregel - package org.neo4j.graphalgo.beta.pregel
 
org.neo4j.graphalgo.beta.pregel.annotation - package org.neo4j.graphalgo.beta.pregel.annotation
 
org.neo4j.graphalgo.config - package org.neo4j.graphalgo.config
 
org.neo4j.graphalgo.core - package org.neo4j.graphalgo.core
 
org.neo4j.graphalgo.core.concurrency - package org.neo4j.graphalgo.core.concurrency
 
org.neo4j.graphalgo.core.heavyweight - package org.neo4j.graphalgo.core.heavyweight
 
org.neo4j.graphalgo.core.huge - package org.neo4j.graphalgo.core.huge
 
org.neo4j.graphalgo.core.loading - package org.neo4j.graphalgo.core.loading
 
org.neo4j.graphalgo.core.loading.construction - package org.neo4j.graphalgo.core.loading.construction
 
org.neo4j.graphalgo.core.loading.nodeproperties - package org.neo4j.graphalgo.core.loading.nodeproperties
 
org.neo4j.graphalgo.core.model - package org.neo4j.graphalgo.core.model
 
org.neo4j.graphalgo.core.mutate - package org.neo4j.graphalgo.core.mutate
 
org.neo4j.graphalgo.core.utils - package org.neo4j.graphalgo.core.utils
 
org.neo4j.graphalgo.core.utils.collection.primitive - package org.neo4j.graphalgo.core.utils.collection.primitive
 
org.neo4j.graphalgo.core.utils.export - package org.neo4j.graphalgo.core.utils.export
 
org.neo4j.graphalgo.core.utils.mem - package org.neo4j.graphalgo.core.utils.mem
 
org.neo4j.graphalgo.core.utils.paged - package org.neo4j.graphalgo.core.utils.paged
 
org.neo4j.graphalgo.core.utils.paged.dss - package org.neo4j.graphalgo.core.utils.paged.dss
 
org.neo4j.graphalgo.core.utils.partition - package org.neo4j.graphalgo.core.utils.partition
 
org.neo4j.graphalgo.core.utils.queue - package org.neo4j.graphalgo.core.utils.queue
 
org.neo4j.graphalgo.core.utils.statistics - package org.neo4j.graphalgo.core.utils.statistics
 
org.neo4j.graphalgo.core.write - package org.neo4j.graphalgo.core.write
 
org.neo4j.graphalgo.utils - package org.neo4j.graphalgo.utils
 
orientation() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
orientation() - Method in interface org.neo4j.graphalgo.api.Relationships.Topology
 
orientation() - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
Orientation - Enum in org.neo4j.graphalgo
 
ORIENTATION_KEY - Static variable in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
oversize(long, int) - Static method in class org.neo4j.graphalgo.core.utils.paged.HugeArrays
Huge version of Lucene oversize for arrays.

P

p1 - Variable in class org.neo4j.graphalgo.core.utils.paged.PaddedAtomicLong
 
p2 - Variable in class org.neo4j.graphalgo.core.utils.paged.PaddedAtomicLong
 
p3 - Variable in class org.neo4j.graphalgo.core.utils.paged.PaddedAtomicLong
 
p4 - Variable in class org.neo4j.graphalgo.core.utils.paged.PaddedAtomicLong
 
p5 - Variable in class org.neo4j.graphalgo.core.utils.paged.PaddedAtomicLong
 
p6 - Variable in class org.neo4j.graphalgo.core.utils.paged.PaddedAtomicLong
 
p7 - Variable in class org.neo4j.graphalgo.core.utils.paged.PaddedAtomicLong
 
PaddedAtomicLong - Class in org.neo4j.graphalgo.core.utils.paged
 
PaddedAtomicLong() - Constructor for class org.neo4j.graphalgo.core.utils.paged.PaddedAtomicLong
 
PaddedAtomicLong(long) - Constructor for class org.neo4j.graphalgo.core.utils.paged.PaddedAtomicLong
 
page() - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListPageSlice
The current page.
PAGE_MASK - Static variable in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
PAGE_SHIFT - Static variable in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
PAGE_SIZE - Static variable in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
PageAllocator<T> - Class in org.neo4j.graphalgo.core.utils.paged
 
PageAllocator() - Constructor for class org.neo4j.graphalgo.core.utils.paged.PageAllocator
 
PageAllocator.Factory<T> - Class in org.neo4j.graphalgo.core.utils.paged
 
PageAllocator.PageFactory<T> - Interface in org.neo4j.graphalgo.core.utils.paged
 
pagecacheMemory() - Static method in class org.neo4j.graphalgo.core.Settings
 
PagedAtomicDoubleArray - Class in org.neo4j.graphalgo.core.utils.paged
 
PagedAtomicIntegerArray - Class in org.neo4j.graphalgo.core.utils.paged
 
PagedDataStructure<T> - Class in org.neo4j.graphalgo.core.utils.paged
 
PagedLongStack - Class in org.neo4j.graphalgo.core.utils.paged
 
PagedLongStack(long, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.PagedLongStack
 
pageIndex(long, int) - Static method in class org.neo4j.graphalgo.core.utils.paged.PageUtil
 
pageSize() - Method in class org.neo4j.graphalgo.core.loading.ImportSizing
 
pageSize() - Method in class org.neo4j.graphalgo.core.utils.paged.PageAllocator
 
pageSizeFor(int) - Static method in class org.neo4j.graphalgo.core.utils.paged.PageUtil
 
PageUtil - Class in org.neo4j.graphalgo.core.utils.paged
 
pair(RelationshipType, RelationshipProjection, RelationshipType, RelationshipProjection) - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
parallel(ExecutorService, int) - Method in class org.neo4j.graphalgo.core.write.ExporterBuilder
 
parallelForEachNode(Graph, int, LongConsumer) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
parallelStream(T, int, Function<T, R>) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Executes the given function in parallel on the given BaseStream, using a FJ pool of the requested size.
parallelStreamConsume(T, int, Consumer<T>) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Executes the given function in parallel on the given BaseStream, using a FJ pool of the requested size.
ParallelUtil - Class in org.neo4j.graphalgo.core.concurrency
 
parameters() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
parent() - Method in class org.neo4j.graphalgo.core.utils.paged.dss.IncrementalDisjointSetStruct
Deprecated.
 
parent() - Method in class org.neo4j.graphalgo.core.utils.paged.dss.NonInrementalDisjointSetStruct
Deprecated.
 
parse(Object) - Static method in enum org.neo4j.graphalgo.beta.generator.RelationshipDistribution
 
parse(Object) - Static method in enum org.neo4j.graphalgo.core.Aggregation
 
parse(Object) - Static method in enum org.neo4j.graphalgo.Orientation
 
Partition - Interface in org.neo4j.graphalgo.core.utils.partition
 
PartitionUtils - Class in org.neo4j.graphalgo.core.utils.partition
 
passThrough(int) - Static method in class org.neo4j.graphalgo.core.utils.paged.DoublePageCreator
 
passThrough(int) - Static method in class org.neo4j.graphalgo.core.utils.paged.LongPageCreator
 
pearson(double[], double[], int) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
pearsonSkip(double[], double[], int, double) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
peek() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntStack
 
peek() - Method in class org.neo4j.graphalgo.core.utils.paged.PagedLongStack
 
peekVLong() - Method in interface org.neo4j.graphalgo.api.AdjacencyCursor
Decode and peek the next target id.
peekVLong() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyCursor
 
peekVLong() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList.DecompressingCursor
 
perGraphDimension(String, BiFunction<GraphDimensions, Integer, MemoryRange>) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a new sub-component to the builder.
perNode(String, LongUnaryOperator) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a new sub-component to the builder.
perNode(String, MemoryEstimation) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a MemoryEstimation as a sub-component to the builder.
PERSISTENT - org.neo4j.graphalgo.api.GraphStore.PropertyState
 
perThread(String, long) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a new sub-component to the builder.
perThread(String, IntToLongFunction) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a new sub-component to the builder.
perThread(String, MemoryEstimation) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a MemoryEstimation as a sub-component to the builder.
Pointer - Class in org.neo4j.graphalgo.core.utils
 
Pointer.BooleanUnaryOperator - Interface in org.neo4j.graphalgo.core.utils
 
Pointer.BoolPointer - Class in org.neo4j.graphalgo.core.utils
 
Pointer.DoublePointer - Class in org.neo4j.graphalgo.core.utils
 
Pointer.GenericPointer<G> - Class in org.neo4j.graphalgo.core.utils
 
Pointer.IntPointer - Class in org.neo4j.graphalgo.core.utils
 
Pointer.LongPointer - Class in org.neo4j.graphalgo.core.utils
 
poll() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntStack
 
Pools - Class in org.neo4j.graphalgo.core.concurrency
 
pop() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArrayStack
 
pop() - Method in class org.neo4j.graphalgo.core.utils.paged.PagedLongStack
 
POWER_LAW - org.neo4j.graphalgo.beta.generator.RelationshipDistribution
 
powerLawSample(long, long, double, Random) - Static method in class org.neo4j.graphalgo.core.utils.statistics.DistributionHelper
 
Pregel<CONFIG extends PregelConfig> - Class in org.neo4j.graphalgo.beta.pregel
 
Pregel.CompositeNodeValue - Class in org.neo4j.graphalgo.beta.pregel
 
Pregel.ComputeStep<CONFIG extends PregelConfig> - Class in org.neo4j.graphalgo.beta.pregel
 
Pregel.Messages - Class in org.neo4j.graphalgo.beta.pregel
 
Pregel.PregelResult - Interface in org.neo4j.graphalgo.beta.pregel
 
PregelComputation<C extends PregelConfig> - Interface in org.neo4j.graphalgo.beta.pregel
Main interface to express user-defined logic using the Pregel framework.
PregelConfig - Interface in org.neo4j.graphalgo.beta.pregel
 
PregelContext<CONFIG extends PregelConfig> - Class in org.neo4j.graphalgo.beta.pregel
 
PregelContext.ComputeContext<CONFIG extends PregelConfig> - Class in org.neo4j.graphalgo.beta.pregel
A context that is used during the computation.
PregelContext.InitContext<CONFIG extends PregelConfig> - Class in org.neo4j.graphalgo.beta.pregel
A context that is used during the initialization phase, which is before the first superstep is being executed.
PregelProcedure - Annotation Type in org.neo4j.graphalgo.beta.pregel.annotation
 
PregelSchema - Interface in org.neo4j.graphalgo.beta.pregel
 
PregelSchema.Builder - Class in org.neo4j.graphalgo.beta.pregel
 
PregelSchema.Visibility - Enum in org.neo4j.graphalgo.beta.pregel
 
preLoadedPropertyReader() - Static method in class org.neo4j.graphalgo.core.loading.RelationshipImporter
 
prepare() - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListAllocator
 
previousPowerOfTwo(int) - Static method in class org.neo4j.graphalgo.core.utils.BitUtil
returns the previous highest power of two, or the current value if it's already a power of two or zero
previousPowerOfTwo(long) - Static method in class org.neo4j.graphalgo.core.utils.BitUtil
returns the previous highest power of two, or the current value if it's already a power of two or zero
PrimitiveCollection - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveIntBaseIterator() - Constructor for class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections.PrimitiveIntBaseIterator
 
PrimitiveIntCollection - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveIntCollections - Class in org.neo4j.graphalgo.core.utils.collection.primitive
Basic and common primitive int collection utils and manipulations.
PrimitiveIntCollections.PrimitiveIntBaseIterator - Class in org.neo4j.graphalgo.core.utils.collection.primitive
Base iterator for simpler implementations of PrimitiveIntIterators.
PrimitiveIntCollections.PrimitiveIntConcatingIterator - Class in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveIntCollections.PrimitiveIntFilteringIterator - Class in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveIntConcatingIterator(Iterator<PrimitiveIntIterator>) - Constructor for class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections.PrimitiveIntConcatingIterator
 
PrimitiveIntFilteringIterator(PrimitiveIntIterator) - Constructor for class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections.PrimitiveIntFilteringIterator
 
PrimitiveIntIterable - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveIntIterator - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveIntSet - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveIntStack - Class in org.neo4j.graphalgo.core.utils.collection.primitive
Like a Stack<Integer> but for primitive ints.
PrimitiveIntStack() - Constructor for class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntStack
 
PrimitiveIntStack(int) - Constructor for class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntStack
 
PrimitiveIntVisitor<E extends java.lang.Exception> - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveLongBaseIterator() - Constructor for class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongBaseIterator
 
PrimitiveLongCollection - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveLongCollections - Class in org.neo4j.graphalgo.core.utils.collection.primitive
Basic and common primitive int collection utils and manipulations.
PrimitiveLongCollections.PrimitiveLongBaseIterator - Class in org.neo4j.graphalgo.core.utils.collection.primitive
Base iterator for simpler implementations of PrimitiveLongIterators.
PrimitiveLongCollections.PrimitiveLongConcatingIterator - Class in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveLongCollections.PrimitiveLongFilteringIterator - Class in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveLongCollections.PrimitiveLongRangeIterator - Class in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveLongCollections.PrimitiveLongResourceFilteringIterator - Class in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveLongConcatingIterator(Iterator<? extends PrimitiveLongIterator>) - Constructor for class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongConcatingIterator
 
PrimitiveLongIterable - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
primitiveLongIterator() - Method in class org.neo4j.graphalgo.core.utils.SetBitsIterable
 
PrimitiveLongIterator - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveLongResourceCollections - Class in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveLongResourceCollections() - Constructor for class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongResourceCollections
 
PrimitiveLongResourceIterator - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveLongSet - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
PrimitiveLongVisitor<E extends java.lang.Exception> - Interface in org.neo4j.graphalgo.core.utils.collection.primitive
 
priorities() - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongLongPriorityQueue
 
priorities() - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
PRIVATE - org.neo4j.graphalgo.beta.pregel.PregelSchema.Visibility
 
ProcedureConstants - Class in org.neo4j.graphalgo.core
 
procedureUnrestricted() - Static method in class org.neo4j.graphalgo.core.Settings
 
progressLogger - Variable in class org.neo4j.graphalgo.api.GraphStoreFactory
 
progressLogger - Variable in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
ProgressLogger - Interface in org.neo4j.graphalgo.core.utils
 
ProgressLogger.NullProgressLogger - Enum in org.neo4j.graphalgo.core.utils
 
ProgressLogger.ProgressLoggerFactory - Interface in org.neo4j.graphalgo.core.utils
 
ProgressLoggerAdapter - Class in org.neo4j.graphalgo.core.utils
Deprecated.
ProgressLoggerAdapter(Log, String) - Constructor for class org.neo4j.graphalgo.core.utils.ProgressLoggerAdapter
Deprecated.
 
ProgressTimer - Class in org.neo4j.graphalgo.core.utils
 
PROJECT_ALL - Static variable in class org.neo4j.graphalgo.ElementProjection
 
projectAll() - Method in class org.neo4j.graphalgo.AbstractNodeProjection
 
projectAll() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
projectAll() - Method in class org.neo4j.graphalgo.ElementIdentifier
 
projectAll() - Method in class org.neo4j.graphalgo.ElementProjection
 
projectAll() - Method in class org.neo4j.graphalgo.NodeLabel
 
projectAll() - Method in class org.neo4j.graphalgo.RelationshipType
 
projection() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBuilder
 
projections() - Method in class org.neo4j.graphalgo.AbstractNodeProjections
 
projections() - Method in class org.neo4j.graphalgo.AbstractProjections
 
projections() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
properties - Variable in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
properties() - Method in class org.neo4j.graphalgo.AbstractNodeProjection
 
properties() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
properties() - Method in interface org.neo4j.graphalgo.api.Relationships
 
properties() - Method in interface org.neo4j.graphalgo.api.schema.ElementSchema
 
properties() - Method in interface org.neo4j.graphalgo.api.schema.NodeSchema
 
properties() - Method in interface org.neo4j.graphalgo.api.schema.RelationshipSchema
 
properties() - Method in class org.neo4j.graphalgo.core.loading.IdsAndProperties
 
properties() - Method in class org.neo4j.graphalgo.core.loading.NodesBatchBuffer
 
properties() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBuilder
 
properties() - Method in interface org.neo4j.graphalgo.core.write.NodePropertyExporter.NodeProperty
 
properties() - Method in class org.neo4j.graphalgo.ElementProjection
 
properties(int) - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBuilder
 
PROPERTIES_KEY - Static variable in class org.neo4j.graphalgo.ElementProjection
 
PROPERTIES_REFERENCE_OFFSET - Static variable in class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
propertiesImported() - Method in class org.neo4j.graphalgo.core.loading.NodesScanner
 
propertiesImported() - Method in interface org.neo4j.graphalgo.core.loading.RecordScanner
 
propertiesImported() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsScanner
 
propertiesMustExistForEachNodeLabel() - Method in interface org.neo4j.graphalgo.config.FeaturePropertiesConfig
Returns true iff all properties must exist for each node label.
propertiesReference() - Method in class org.neo4j.graphalgo.core.loading.MultipleNodeLabelIndexReference
 
propertiesReference() - Method in class org.neo4j.graphalgo.core.loading.NodeCursorReference
 
propertiesReference() - Method in class org.neo4j.graphalgo.core.loading.NodeLabelIndexReference
 
propertiesReference() - Method in class org.neo4j.graphalgo.core.loading.NodeRecordReference
 
propertiesReference() - Method in interface org.neo4j.graphalgo.core.loading.NodeReference
 
propertiesReference() - Method in class org.neo4j.graphalgo.core.loading.RelationshipRecordReference
 
propertiesReference() - Method in interface org.neo4j.graphalgo.core.loading.RelationshipReference
 
propertiesReference() - Method in class org.neo4j.graphalgo.core.loading.RelationshipScanCursorReference
 
propertiesWritten - Variable in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
propertiesWritten() - Method in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
property() - Method in interface org.neo4j.graphalgo.api.RelationshipCursor
 
property() - Method in interface org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder.Relationship
 
PROPERTY_KEY - Static variable in class org.neo4j.graphalgo.PropertyMapping
 
propertyColumns() - Method in class org.neo4j.graphalgo.core.loading.CypherNodePropertyImporter
 
PropertyCursor - Interface in org.neo4j.graphalgo.api
 
propertyKey() - Method in interface org.neo4j.graphalgo.core.write.NodePropertyExporter.NodeProperty
 
propertyKey() - Method in class org.neo4j.graphalgo.PropertyMapping
property key in the result map Graph.nodeProperties(`propertyKey`)
PropertyMapping - Class in org.neo4j.graphalgo
 
PropertyMapping() - Constructor for class org.neo4j.graphalgo.PropertyMapping
 
propertyMappings(Map<NodeLabel, PropertyMappings>) - Method in class org.neo4j.graphalgo.core.loading.NativeNodePropertyImporter.Builder
 
propertyNameOverride() - Method in interface org.neo4j.graphalgo.config.ConfigurableSeedConfig
 
propertyToken() - Method in interface org.neo4j.graphalgo.core.write.NodePropertyExporter.ResolvedNodeProperty
 
PUBLIC - org.neo4j.graphalgo.beta.pregel.PregelSchema.Visibility
 
push(int) - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntStack
 
push(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArrayStack
 
push(long) - Method in class org.neo4j.graphalgo.core.utils.paged.PagedLongStack
 
putIfAbsent(long, Supplier<T>) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
If the value at the given index is null, attempts to compute its value using the given supplier and enters it into this array unless null.
putIfAbsent(String, NodeProperty) - Method in class org.neo4j.graphalgo.api.NodePropertyStore.Builder
 
putIfAbsent(String, RelationshipProperty) - Method in class org.neo4j.graphalgo.api.RelationshipPropertyStore.Builder
 

R

radixSort(long[], long[], int[], int) - Static method in class org.neo4j.graphalgo.core.loading.RadixSort
 
RadixSort - Class in org.neo4j.graphalgo.core.loading
 
RadixSort() - Constructor for class org.neo4j.graphalgo.core.loading.RadixSort
 
radixSort2(long[], long[], int[], int) - Static method in class org.neo4j.graphalgo.core.loading.RadixSort
 
random(RandomGraphGeneratorConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Cases
 
random(RandomGraphGeneratorConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Rewriter
 
random(RandomGraphGeneratorConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Visitor
 
RANDOM - org.neo4j.graphalgo.beta.generator.RelationshipDistribution
 
RandomGraphGeneratorConfig - Interface in org.neo4j.graphalgo.config
 
RandomGraphGeneratorConfig.AllowSelfLoops - Enum in org.neo4j.graphalgo.config
 
RandomLongIterator - Class in org.neo4j.graphalgo.core.utils
iterates over a range of long values in random order using a https://en.wikipedia.org/wiki/Linear_congruential_generator without having to have all the numbers in memory.
RandomLongIterator(long, long) - Constructor for class org.neo4j.graphalgo.core.utils.RandomLongIterator
 
RandomLongIterator(long, long, Random) - Constructor for class org.neo4j.graphalgo.core.utils.RandomLongIterator
 
RandomLongIterator(long, Random) - Constructor for class org.neo4j.graphalgo.core.utils.RandomLongIterator
 
range(long, long) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
rangePartition(int, long) - Static method in class org.neo4j.graphalgo.core.utils.partition.PartitionUtils
 
rangePartition(int, long, long) - Static method in class org.neo4j.graphalgo.core.utils.partition.PartitionUtils
 
rangePerGraphDimension(String, BiFunction<GraphDimensions, Integer, MemoryRange>) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a new sub-component to the builder.
rangePerNode(String, LongFunction<MemoryRange>) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Adds a new sub-component to the builder.
ranIterations() - Method in interface org.neo4j.graphalgo.beta.pregel.Pregel.PregelResult
 
rawCursor() - Method in interface org.neo4j.graphalgo.api.AdjacencyList
 
rawCursor() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyList
 
rawCursor() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
rawDecompressingCursor() - Method in interface org.neo4j.graphalgo.api.AdjacencyList
Returns a new, uninitialized delta cursor.
rawDecompressingCursor() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyList
 
rawDecompressingCursor() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
RawValues - Class in org.neo4j.graphalgo.core.utils
 
READ_CONCURRENCY_KEY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
readConcurrency() - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
ReadHelper - Class in org.neo4j.graphalgo.core.loading
 
readParallel(int, int, BatchNodeIterable, ExecutorService, HugeParallelGraphImporter<T>) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Executes read operations in parallel, based on the given batch size and executor.
readParallel(int, long, ExecutorService, BiLongConsumer) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
readProperties(PropertyCursor, int[], double[], Aggregation[], double[]) - Static method in class org.neo4j.graphalgo.core.loading.ReadHelper
 
readProperty(long[], int, int[], double[], Aggregation[], boolean) - Method in interface org.neo4j.graphalgo.core.loading.RelationshipImporter.PropertyReader
Load the relationship properties for the given batch of relationships.
readProperty(long[], int, int[], double[], Aggregation[], boolean) - Method in class org.neo4j.graphalgo.core.loading.RelationshipPropertiesBatchBuffer
 
readProperty(long, long[], long, long) - Method in interface org.neo4j.graphalgo.core.loading.HugeNodeImporter.PropertyReader
 
RecordReference<Record> - Interface in org.neo4j.graphalgo.core.loading
 
RecordsBatchBuffer<Reference> - Class in org.neo4j.graphalgo.core.loading
 
RecordScanner - Interface in org.neo4j.graphalgo.core.loading
 
recordsImported() - Method in class org.neo4j.graphalgo.core.loading.NodesScanner
 
recordsImported() - Method in interface org.neo4j.graphalgo.core.loading.RecordScanner
 
recordsImported() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsScanner
 
registerPropertiesForLabels(List<String>) - Method in class org.neo4j.graphalgo.core.loading.CypherNodePropertyImporter
 
RELATIONSHIP_COUNT_KEY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
RELATIONSHIP_DISTRIBUTION_KEY - Static variable in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
RELATIONSHIP_PROJECTION_KEY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
RELATIONSHIP_PROPERTIES_KEY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
RELATIONSHIP_PROPERTY_KEY - Static variable in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
RELATIONSHIP_PROPERTY_MAX_KEY - Static variable in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
RELATIONSHIP_PROPERTY_MIN_KEY - Static variable in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
RELATIONSHIP_PROPERTY_NAME_KEY - Static variable in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
RELATIONSHIP_PROPERTY_TYPE_KEY - Static variable in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
RELATIONSHIP_PROPERTY_VALUE_KEY - Static variable in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
RELATIONSHIP_QUERY_KEY - Static variable in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
RELATIONSHIP_REFERENCE_OFFSET - Static variable in class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
RELATIONSHIP_SEED_KEY - Static variable in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
RELATIONSHIP_TYPES - Static variable in class org.neo4j.graphalgo.core.ProcedureConstants
 
RelationshipAccess - Interface in org.neo4j.graphalgo.api
Deprecated.
RelationshipConsumer - Interface in org.neo4j.graphalgo.api
TODO: Define interface contract, esp regarding source/target node ids returned and how that maps to relationship direction consumer interface for relationships without property.
relationshipCount() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
relationshipCount() - Method in interface org.neo4j.graphalgo.api.Graph
 
relationshipCount() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
relationshipCount() - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext
Number of relationships in the input graph.
relationshipCount() - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
relationshipCount() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
relationshipCount() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
relationshipCount() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
relationshipCount(RelationshipType) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
relationshipCount(RelationshipType) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
relationshipCounts() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
RelationshipCursor - Interface in org.neo4j.graphalgo.api
 
relationshipDistribution() - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
RelationshipDistribution - Enum in org.neo4j.graphalgo.beta.generator
 
RelationshipExporter - Class in org.neo4j.graphalgo.core.write
 
RelationshipExporter.Builder - Class in org.neo4j.graphalgo.core.write
 
relationshipId() - Method in class org.neo4j.graphalgo.core.loading.RelationshipRecordReference
 
relationshipId() - Method in interface org.neo4j.graphalgo.core.loading.RelationshipReference
 
relationshipId() - Method in class org.neo4j.graphalgo.core.loading.RelationshipScanCursorReference
 
RelationshipImporter - Class in org.neo4j.graphalgo.core.loading
 
RelationshipImporter(AllocationTracker, AdjacencyBuilder) - Constructor for class org.neo4j.graphalgo.core.loading.RelationshipImporter
 
RelationshipImporter.Imports - Interface in org.neo4j.graphalgo.core.loading
 
RelationshipImporter.PropertyReader - Interface in org.neo4j.graphalgo.core.loading
 
RelationshipIntersect - Interface in org.neo4j.graphalgo.api
 
RelationshipIterator - Interface in org.neo4j.graphalgo.api
 
RelationshipPredicate - Interface in org.neo4j.graphalgo.api
 
relationshipProducer(long, long, Random) - Method in enum org.neo4j.graphalgo.beta.generator.RelationshipDistribution
Produces a unary function which accepts a node id parameter and returns another node id to wich the node will be connected.
relationshipProjections() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
relationshipProjections() - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
relationshipProperties() - Method in interface org.neo4j.graphalgo.api.RelationshipPropertyStore
 
relationshipProperties() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
relationshipProperties() - Method in interface org.neo4j.graphalgo.config.GraphStreamRelationshipPropertiesConfig
 
RelationshipProperties - Interface in org.neo4j.graphalgo.api
Getter for property values at relationships
RelationshipPropertiesBatchBuffer - Class in org.neo4j.graphalgo.core.loading
 
relationshipProperty() - Method in interface org.neo4j.graphalgo.config.GraphWriteRelationshipConfig
 
relationshipProperty() - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
relationshipProperty(long, long) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
relationshipProperty(long, long) - Method in interface org.neo4j.graphalgo.api.RelationshipProperties
Returns the property value for a relationship defined by its source and target nodes.
relationshipProperty(long, long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
relationshipProperty(long, long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
relationshipProperty(long, long) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
relationshipProperty(long, long, double) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
relationshipProperty(long, long, double) - Method in interface org.neo4j.graphalgo.api.RelationshipProperties
get value of property on relationship between source and target node id
relationshipProperty(long, long, double) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
relationshipProperty(long, long, double) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
relationshipProperty(long, long, double) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
RelationshipProperty - Interface in org.neo4j.graphalgo.api
 
relationshipPropertyCount() - Method in interface org.neo4j.graphalgo.core.utils.export.GraphStoreExport.ImportedProperties
 
relationshipPropertyKeys() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
relationshipPropertyKeys() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
relationshipPropertyKeys(Collection<RelationshipType>) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
relationshipPropertyKeys(RelationshipType) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
relationshipPropertyKeys(RelationshipType) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
RelationshipPropertyStore - Interface in org.neo4j.graphalgo.api
 
RelationshipPropertyStore.Builder - Class in org.neo4j.graphalgo.api
 
relationshipPropertyTokens() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
RelationshipPropertyTranslator - Interface in org.neo4j.graphalgo.core.write
 
relationshipPropertyType(String) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
relationshipPropertyType(String) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
relationshipQuery() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
RelationshipRecordReference - Class in org.neo4j.graphalgo.core.loading
 
RelationshipRecordReference(RelationshipRecord) - Constructor for class org.neo4j.graphalgo.core.loading.RelationshipRecordReference
 
relationshipReference() - Method in class org.neo4j.graphalgo.core.loading.MultipleNodeLabelIndexReference
 
relationshipReference() - Method in class org.neo4j.graphalgo.core.loading.NodeCursorReference
 
relationshipReference() - Method in class org.neo4j.graphalgo.core.loading.NodeLabelIndexReference
 
relationshipReference() - Method in class org.neo4j.graphalgo.core.loading.NodeRecordReference
 
relationshipReference() - Method in interface org.neo4j.graphalgo.core.loading.NodeReference
 
RelationshipReference - Interface in org.neo4j.graphalgo.core.loading
 
relationships() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
relationships(Collector) - Method in class org.neo4j.graphalgo.core.utils.export.GraphStoreInput
 
Relationships - Interface in org.neo4j.graphalgo.api
 
Relationships.Properties - Interface in org.neo4j.graphalgo.api
 
Relationships.Topology - Interface in org.neo4j.graphalgo.api
 
RelationshipsBatchBuffer - Class in org.neo4j.graphalgo.core.loading
 
RelationshipsBatchBuffer(IdMapping, int, int) - Constructor for class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
RelationshipsBatchBuffer(IdMapping, int, int, boolean) - Constructor for class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
RelationshipsBuilder - Class in org.neo4j.graphalgo.core.loading.construction
 
RelationshipsBuilder - Class in org.neo4j.graphalgo.core.loading
 
RelationshipsBuilder(IdMapping, Orientation, boolean, Aggregation, boolean, int, ExecutorService, AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder
 
RelationshipsBuilder(RelationshipProjection, AdjacencyListBuilderFactory, AdjacencyOffsetsFactory) - Constructor for class org.neo4j.graphalgo.core.loading.RelationshipsBuilder
 
RelationshipsBuilder.Relationship - Interface in org.neo4j.graphalgo.core.loading.construction
 
RelationshipScanCursorBasedScanner - Class in org.neo4j.graphalgo.core.loading
 
RelationshipScanCursorReference - Class in org.neo4j.graphalgo.core.loading
 
RelationshipScanCursorReference(RelationshipScanCursor) - Constructor for class org.neo4j.graphalgo.core.loading.RelationshipScanCursorReference
 
relationshipSchema() - Method in interface org.neo4j.graphalgo.api.schema.GraphSchema
 
RelationshipSchema - Interface in org.neo4j.graphalgo.api.schema
 
RelationshipSchema.Builder - Class in org.neo4j.graphalgo.api.schema
 
relationshipSeed() - Method in interface org.neo4j.graphalgo.config.RandomGraphGeneratorConfig
 
RelationshipsScanner - Class in org.neo4j.graphalgo.core.loading
 
relationshipTopology() - Method in class org.neo4j.graphalgo.api.CSRFilterGraph
 
relationshipTopology() - Method in interface org.neo4j.graphalgo.api.CSRGraph
 
relationshipTopology() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
relationshipTopology() - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
relationshipTopology() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
relationshipType() - Method in interface org.neo4j.graphalgo.config.DeleteRelationshipsConfig
 
relationshipType() - Method in interface org.neo4j.graphalgo.config.GraphWriteRelationshipConfig
 
RelationshipType - Class in org.neo4j.graphalgo
 
RelationshipType(String) - Constructor for class org.neo4j.graphalgo.RelationshipType
 
relationshipTypeIdentifiers(GraphStore) - Method in interface org.neo4j.graphalgo.config.GraphStreamRelationshipPropertiesConfig
 
relationshipTypes() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
relationshipTypes() - Method in interface org.neo4j.graphalgo.config.AlgoBaseConfig
 
relationshipTypes() - Method in interface org.neo4j.graphalgo.config.GraphStreamRelationshipPropertiesConfig
 
relationshipTypes() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
relationshipTypeTokenMapping() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
relationshipTypeTokens() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
RelationshipWeightConfig - Interface in org.neo4j.graphalgo.config
 
relationshipWeightProperty() - Method in interface org.neo4j.graphalgo.config.RelationshipWeightConfig
 
RelationshipWithPropertyConsumer - Interface in org.neo4j.graphalgo.api
 
release() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
release() - Method in interface org.neo4j.graphalgo.api.Graph
Release all resources which are not part of the result or IdMapping
release() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
release() - Method in interface org.neo4j.graphalgo.api.NodeProperties
Release internal data structures and return an estimate how many bytes were freed.
release() - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
release() - Method in class org.neo4j.graphalgo.beta.pregel.Pregel
 
release() - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
release() - Method in class org.neo4j.graphalgo.core.loading.CompressedLongArray
 
release() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
release() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
Destroys the data, allowing the underlying storage arrays to be collected as garbage.
release() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
Destroys the data, allowing the underlying storage arrays to be collected as garbage.
release() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
Destroys the data, allowing the underlying storage arrays to be collected as garbage.
release() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Destroys the data, allowing the underlying storage arrays to be collected as garbage.
release() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Destroys the data, allowing the underlying storage arrays to be collected as garbage.
release() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
 
release() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongDoubleMap
 
release() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
 
release() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
Destroys the data, allowing the underlying storage arrays to be collected as garbage.
release() - Method in class org.neo4j.graphalgo.core.utils.paged.PagedDataStructure
 
release() - Method in class org.neo4j.graphalgo.core.utils.paged.PagedLongStack
 
release() - Method in class org.neo4j.graphalgo.core.utils.paged.TrackingLongDoubleHashMap
 
releaseProperties() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
releaseProperties() - Method in interface org.neo4j.graphalgo.api.Graph
Release only the properties associated with that graph.
releaseProperties() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
releaseProperties() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
releaseTopology() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
releaseTopology() - Method in interface org.neo4j.graphalgo.api.Graph
Release only the topological data associated with that graph.
releaseTopology() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
releaseTopology() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
remaining() - Method in interface org.neo4j.graphalgo.api.AdjacencyCursor
Return how many targets are still left to be decoded.
remaining() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyCursor
 
remaining() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList.DecompressingCursor
 
remove() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArrayQueue
 
remove(int) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntSet
 
remove(long) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongSet
 
remove(long) - Method in interface org.neo4j.graphalgo.core.utils.mem.AllocationTracker
Remove the given number of bytes from the total tracked amount.
remove(long) - Method in class org.neo4j.graphalgo.core.utils.mem.InMemoryAllocationTracker
 
remove(long) - Method in class org.neo4j.graphalgo.core.utils.mem.KernelAllocationTracker
 
remove(String, NamedDatabaseId, String, Consumer<GraphStoreWithConfig>, boolean) - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
removeAllLoadedGraphs() - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
removeAllLoadedModels() - Static method in class org.neo4j.graphalgo.core.model.ModelCatalog
 
removeNodeProperty(NodeLabel, String) - Method in interface org.neo4j.graphalgo.api.GraphStore
 
removeNodeProperty(NodeLabel, String) - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
removeProperty(String) - Method in class org.neo4j.graphalgo.api.NodePropertyStore.Builder
 
RenamesCurrentThread - Interface in org.neo4j.graphalgo.core.utils
 
RenamesCurrentThread.Revert - Interface in org.neo4j.graphalgo.core.utils
 
renameThread(String) - Static method in interface org.neo4j.graphalgo.core.utils.RenamesCurrentThread
 
render() - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryTree
Renders the memory requirements into a human readable representation.
render(StringBuilder, MemoryTree, int) - Static method in interface org.neo4j.graphalgo.core.utils.mem.MemoryTree
 
renderMap() - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryTree
 
reserveBatch(CompositeNodeCursor, int) - Method in class org.neo4j.graphalgo.core.loading.CompositeNodeScan
 
reset() - Method in class org.neo4j.graphalgo.core.loading.CompositeRelationshipsBatchBuffer
 
reset() - Method in class org.neo4j.graphalgo.core.loading.RecordsBatchBuffer
 
reset() - Method in class org.neo4j.graphalgo.core.utils.RandomLongIterator
Reset the iterator to the beginning of this iteration.
reset() - Method in enum org.neo4j.graphalgo.utils.GdsFeatureToggles
 
reset(long) - Method in class org.neo4j.graphalgo.core.utils.BatchingProgressLogger
 
reset(long) - Method in enum org.neo4j.graphalgo.core.utils.ProgressLogger.NullProgressLogger
 
reset(long) - Method in interface org.neo4j.graphalgo.core.utils.ProgressLogger
 
reset(long) - Method in class org.neo4j.graphalgo.core.utils.ProgressLoggerAdapter
Deprecated.
 
RESIDENT_MEMORY - Static variable in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
 
residentMemory() - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryTree
 
resolve(Aggregation) - Static method in enum org.neo4j.graphalgo.core.Aggregation
 
resolveWith(int) - Method in interface org.neo4j.graphalgo.core.write.NodePropertyExporter.NodeProperty
 
resourceIterator(PrimitiveLongIterator, Resource) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
Wraps a PrimitiveLongIterator in a PrimitiveLongResourceIterator which closes the provided resource in Resource.close().
result() - Method in class org.neo4j.graphalgo.core.loading.CypherNodePropertyImporter
 
result() - Method in class org.neo4j.graphalgo.core.loading.NativeNodePropertyImporter
 
REVERSE - org.neo4j.graphalgo.Orientation
 
rootCause(Throwable) - Static method in class org.neo4j.graphalgo.utils.ExceptionUtil
Returns the root cause of an exception.
run() - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.ComputeStep
 
run() - Method in class org.neo4j.graphalgo.beta.pregel.Pregel
 
run() - Method in class org.neo4j.graphalgo.core.utils.StatementAction
 
run() - Method in interface org.neo4j.graphalgo.utils.CheckedRunnable
 
run(Runnable, ExecutorService) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Runs a single task and waits until it's finished.
run(Collection<? extends Runnable>, boolean, ExecutorService, Collection<Future<?>>) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
run(Collection<? extends Runnable>, Runnable, ExecutorService, Collection<Future<?>>) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
run(Collection<? extends Runnable>, ExecutorService) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Runs a collection of Runnables in parallel for their side-effects.
run(Collection<? extends Runnable>, ExecutorService, Collection<Future<?>>) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
run(AllocationTracker) - Method in class org.neo4j.graphalgo.core.utils.export.GraphStoreExport
 
run(CheckedRunnable<E>) - Static method in class org.neo4j.graphalgo.utils.ExceptionUtil
 
RUN_CHECK_NODE_COUNT - Static variable in interface org.neo4j.graphalgo.core.utils.TerminationFlag
 
runFromTests() - Method in class org.neo4j.graphalgo.core.utils.export.GraphStoreExport
Runs with default configuration geared towards unit/integration test environments, for example, lower default buffer sizes.
runnable(CheckedRunnable<E>) - Static method in interface org.neo4j.graphalgo.utils.CheckedRunnable
 
running() - Method in interface org.neo4j.graphalgo.core.utils.TerminationFlag
 
running() - Method in class org.neo4j.graphalgo.core.utils.TerminationFlagImpl
 
RUNNING_TRUE - Static variable in interface org.neo4j.graphalgo.core.utils.TerminationFlag
 
runWithConcurrency(int, Collection<? extends Runnable>, long, long, TimeUnit, ExecutorService) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Try to run all tasks for their side-effects using at most concurrency threads at once.
runWithConcurrency(int, Collection<? extends Runnable>, long, long, TimeUnit, TerminationFlag, ExecutorService) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Try to run all tasks for their side-effects using at most concurrency threads at once.
runWithConcurrency(int, Collection<? extends Runnable>, long, ExecutorService) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Try to run all tasks for their side-effects using at most concurrency threads at once.
runWithConcurrency(int, Collection<? extends Runnable>, long, TimeUnit, ExecutorService) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Try to run all tasks for their side-effects using at most concurrency threads at once.
runWithConcurrency(int, Collection<? extends Runnable>, long, TimeUnit, TerminationFlag, ExecutorService) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Try to run all tasks for their side-effects using at most concurrency threads at once.
runWithConcurrency(int, Collection<? extends Runnable>, ExecutorService) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Try to run all tasks for their side-effects using at most concurrency threads at once.
runWithConcurrency(int, Collection<? extends Runnable>, TerminationFlag, ExecutorService) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
Try to run all tasks for their side-effects using at most concurrency threads at once.

S

sameSet(long, long) - Method in interface org.neo4j.graphalgo.core.utils.paged.dss.DisjointSetStruct
Deprecated.
use only in tests
sameSet(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.HugeAtomicDisjointSetStruct
 
sameSet(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.SequentialDisjointSetStruct
Deprecated.
 
scan(StoreScanner.ScanCursor<Reference>) - Method in class org.neo4j.graphalgo.core.loading.RecordsBatchBuffer
 
ScanningRecordsImporter<Record,​T> - Class in org.neo4j.graphalgo.core.loading
 
ScanningRecordsImporter(StoreScanner.Factory<Record>, String, GraphLoaderContext, GraphDimensions, int) - Constructor for class org.neo4j.graphalgo.core.loading.ScanningRecordsImporter
 
ScanningRelationshipsImporter - Class in org.neo4j.graphalgo.core.loading
 
ScanningRelationshipsImporter(GraphCreateConfig, GraphLoaderContext, GraphDimensions, ProgressLogger, IdMapping, Map<RelationshipType, RelationshipsBuilder>, int) - Constructor for class org.neo4j.graphalgo.core.loading.ScanningRelationshipsImporter
 
schema() - Method in class org.neo4j.graphalgo.api.FilterGraph
 
schema() - Method in interface org.neo4j.graphalgo.api.Graph
 
schema() - Method in interface org.neo4j.graphalgo.api.GraphStore
 
schema() - Method in class org.neo4j.graphalgo.beta.pregel.Pregel.CompositeNodeValue
 
schema() - Method in interface org.neo4j.graphalgo.beta.pregel.PregelComputation
The schema describes the node property layout.
schema() - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
schema() - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
schema() - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
schema() - Method in class org.neo4j.graphalgo.core.loading.CSRGraphStore
 
SecureTransaction - Class in org.neo4j.graphalgo.core
Manage transactions by making sure that the correct SecurityContext is applied.
SecureTransaction.TxConsumer<E extends java.lang.Exception> - Interface in org.neo4j.graphalgo.core
 
SecureTransaction.TxFunction<T,​E extends java.lang.Exception> - Interface in org.neo4j.graphalgo.core
 
SeedConfig - Interface in org.neo4j.graphalgo.config
 
seedProperty() - Method in interface org.neo4j.graphalgo.config.ConfigurableSeedConfig
 
seedProperty() - Method in interface org.neo4j.graphalgo.config.SeedConfig
 
sendTo(long, double) - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext.ComputeContext
Sends the given message to the target node.
sendToNeighbors(double) - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext.ComputeContext
Sends the given message to all neighbors of the node.
SequentialDisjointSetStruct - Class in org.neo4j.graphalgo.core.utils.paged.dss
Deprecated.
SequentialDisjointSetStruct() - Constructor for class org.neo4j.graphalgo.core.utils.paged.dss.SequentialDisjointSetStruct
Deprecated.
 
set(int, double) - Method in class org.neo4j.graphalgo.core.utils.AtomicDoubleArray
Sets the element at position i to the given value.
set(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Sets the bit at the given index to true.
set(long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
Sets the long value at the given index to the given value.
set(long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
Sets the double value at the given index to the given value.
set(long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.PagedAtomicDoubleArray
 
set(long, int) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Sets the int value at the given index to the given value.
set(long, int) - Method in class org.neo4j.graphalgo.core.utils.paged.PagedAtomicIntegerArray
 
set(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Sets the bits from the startIndex (inclusive) to the endIndex (exclusive).
set(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
Sets the long value at the given index to the given value.
set(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Sets the long value at the given index to the given value.
set(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray.Builder
 
set(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray.GrowingBuilder
 
set(long, long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleTriangularMatrix
 
set(long, long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongDoubleMap
 
set(long, long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongMatrix
 
set(long, long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongTriangularMatrix
 
set(long, Value) - Method in class org.neo4j.graphalgo.core.loading.nodeproperties.NodePropertiesFromStoreBuilder
 
set(long, T) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
Sets the value at the given index to the given value.
set(GraphCreateConfig, GraphStore) - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
set(Model<?, ?>) - Static method in class org.neo4j.graphalgo.core.model.ModelCatalog
 
set(T) - Method in class org.neo4j.graphalgo.utils.CloseableThreadLocal
 
setAll(long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
Set all entries in the array to the given value.
setAll(LongFunction<T>) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
Set all elements using the provided generator function to compute each element.
setAll(LongToDoubleFunction) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
Set all elements using the provided generator function to compute each element.
setAll(LongToIntFunction) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Set all elements using the provided generator function to compute each element.
setAll(LongUnaryOperator) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Set all elements using the provided generator function to compute each element.
SetBitsIterable - Class in org.neo4j.graphalgo.core.utils
An iterable over the set bits in a BitSet.
SetBitsIterable(BitSet) - Constructor for class org.neo4j.graphalgo.core.utils.SetBitsIterable
 
SetBitsIterable(BitSet, long) - Constructor for class org.neo4j.graphalgo.core.utils.SetBitsIterable
 
setDegreeDistribution(String, NamedDatabaseId, String, Map<String, Object>) - Static method in class org.neo4j.graphalgo.core.loading.GraphStoreCatalog
 
setIdOf(long) - Method in interface org.neo4j.graphalgo.core.utils.paged.dss.DisjointSetStruct
Find set Id of element p.
setIdOf(long) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.HugeAtomicDisjointSetStruct
 
setIdOf(long) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.IncrementalDisjointSetStruct
Deprecated.
 
setIdOf(long) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.NonInrementalDisjointSetStruct
Deprecated.
 
setIfAbsent(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeSparseLongArray.Builder
 
setNodeValue(String, double) - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext
Sets a node double value for given the node schema key.
setNodeValue(String, double[]) - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext
Sets a node long value for given the node schema key.
setNodeValue(String, long) - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext
Sets a node long value for given the node schema key.
setNodeValue(String, long[]) - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext
Sets a node long value for given the node schema key.
setNonDefaultAggregation(Aggregation) - Method in class org.neo4j.graphalgo.PropertyMapping
 
Settings - Class in org.neo4j.graphalgo.core
 
setToCommunityEdition() - Method in class org.neo4j.graphalgo.core.GdsEdition
 
setToEnterpriseEdition() - Method in class org.neo4j.graphalgo.core.GdsEdition
 
setToInvalidLicense(String) - Method in class org.neo4j.graphalgo.core.GdsEdition
 
setup(String, Function<GraphDimensions, MemoryEstimation>) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
Creates a MemoryEstimation using the given function.
setup(String, MemoryEstimations.MemoryEstimationSetup) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
Creates a MemoryEstimation using the given MemoryEstimations.MemoryEstimationSetup function.
setup(GraphDimensions, int) - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.MemoryEstimationSetup
 
shouldSkip(double, double, boolean) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
SignatureTool - Class in org.neo4j.graphalgo.core
 
SignatureTool.LicenseCheckResult - Interface in org.neo4j.graphalgo.core
 
SIGNIFICAND_BITS - Static variable in class org.neo4j.graphalgo.core.loading.DoubleCodec
The number of physical bits in the significand of a double number.
SIGNIFICANT_BIT_MASK - Static variable in class org.neo4j.graphalgo.core.loading.DoubleCodec
Bit mask to isolate the significand field of a double.
single(PrimitiveLongIterator, long) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
single(NodeLabel, NodeProjection) - Static method in class org.neo4j.graphalgo.AbstractNodeProjections
 
single(RelationshipType, RelationshipProjection) - Static method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
SINGLE - org.neo4j.graphalgo.core.Aggregation
 
singleTypeAndProperty(RelationshipType, Optional<String>) - Method in interface org.neo4j.graphalgo.api.schema.RelationshipSchema
 
size() - Method in interface org.neo4j.graphalgo.api.AdjacencyCursor
Return how many targets can be decoded in total.
size() - Method in interface org.neo4j.graphalgo.api.NodeProperties
 
size() - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
size() - Method in class org.neo4j.graphalgo.core.huge.CompositeAdjacencyCursor
 
size() - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
size() - Method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList.DecompressingCursor
 
size() - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveCollection
 
size() - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntStack
 
size() - Method in class org.neo4j.graphalgo.core.utils.LazyBatchCollection
 
size() - Method in class org.neo4j.graphalgo.core.utils.LazyMappingCollection
 
size() - Method in interface org.neo4j.graphalgo.core.utils.paged.dss.DisjointSetStruct
Number of elements stored in the data structure.
size() - Method in class org.neo4j.graphalgo.core.utils.paged.dss.HugeAtomicDisjointSetStruct
 
size() - Method in class org.neo4j.graphalgo.core.utils.paged.dss.IncrementalDisjointSetStruct
Deprecated.
element (node) count
size() - Method in class org.neo4j.graphalgo.core.utils.paged.dss.NonInrementalDisjointSetStruct
Deprecated.
 
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
Returns the number of bits in the bitset.
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
Returns the length of this array.
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
Returns the length of this array.
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
Returns the length of this array.
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
Returns the length of this array.
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
Returns the length of this array.
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArrayQueue
 
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArrayStack
 
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
 
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongDoubleMap
 
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
 
size() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
Returns the length of this array.
size() - Method in class org.neo4j.graphalgo.core.utils.paged.PagedDataStructure
Return the size of this data structure.
size() - Method in class org.neo4j.graphalgo.core.utils.paged.PagedLongStack
 
size() - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongLongPriorityQueue
 
size() - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
sizeOf() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
 
sizeOf() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
 
sizeOf() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
sizeOf() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
sizeOf() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
sizeOf() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
 
sizeOf() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
 
sizeOf() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
sizeOf(Object) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfArray(long, long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfBitset(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfByteArray(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfCharArray(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfDoubleArray(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfEmptyOpenHashContainer() - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfFloatArray(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfHugeAtomicBitset(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfInstance(Class<?>) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
Returns the shallow instance size in bytes an instance of the given class would occupy.
sizeOfIntArray(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfLongArray(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfLongDoubleHashMap(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfObjectArray(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfObjectArrayElements(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfOpenHashContainer(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
sizeOfShortArray(long) - Static method in class org.neo4j.graphalgo.core.utils.mem.MemoryUsage
 
SKIP_ORPHANS - org.neo4j.graphalgo.utils.GdsFeatureToggles
 
skipUntil(CURSOR, long) - Method in class org.neo4j.graphalgo.core.huge.GraphIntersect
Get the node id strictly greater than (>) the provided target.
skipUntil(TransientAdjacencyList.DecompressingCursor, long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraphIntersect
 
sortBySource() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
sortByTarget() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
source - Variable in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongFilteringIterator
 
sourceId() - Method in interface org.neo4j.graphalgo.api.RelationshipCursor
 
sourceNodeId() - Method in interface org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder.Relationship
 
sourceNodeIds() - Method in interface org.neo4j.graphalgo.config.SourceNodesConfig
 
sourceNodeReference() - Method in class org.neo4j.graphalgo.core.loading.RelationshipRecordReference
 
sourceNodeReference() - Method in interface org.neo4j.graphalgo.core.loading.RelationshipReference
 
sourceNodeReference() - Method in class org.neo4j.graphalgo.core.loading.RelationshipScanCursorReference
 
sourceNodes() - Method in interface org.neo4j.graphalgo.config.SourceNodesConfig
 
SourceNodesConfig - Interface in org.neo4j.graphalgo.config
 
spareInts() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
spareLongs() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsBatchBuffer
 
spliterator() - Method in class org.neo4j.graphalgo.core.utils.SetBitsIterable
 
start() - Static method in class org.neo4j.graphalgo.core.utils.ProgressTimer
 
start(LongConsumer) - Static method in class org.neo4j.graphalgo.core.utils.ProgressTimer
 
START_NODE_ID - Static variable in interface org.neo4j.graphalgo.api.IdMapping
Defines the lower bound of mapped ids TODO: function?
startField(String) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Starts the construction of new sub-components.
startField(String, Class<?>) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations.Builder
Starts the construction of new sub-components.
startNode() - Method in interface org.neo4j.graphalgo.core.utils.partition.Partition
 
state() - Method in interface org.neo4j.graphalgo.api.NodeProperty
 
state() - Method in interface org.neo4j.graphalgo.api.RelationshipProperty
 
StatementAction - Class in org.neo4j.graphalgo.core.utils
 
StatementAction(SecureTransaction) - Constructor for class org.neo4j.graphalgo.core.utils.StatementAction
 
StatementApi - Class in org.neo4j.graphalgo.utils
 
StatementApi(SecureTransaction) - Constructor for class org.neo4j.graphalgo.utils.StatementApi
 
StatementApi.TxConsumer - Interface in org.neo4j.graphalgo.utils
 
StatementApi.TxFunction<T> - Interface in org.neo4j.graphalgo.utils
 
StatementFunction<T> - Class in org.neo4j.graphalgo.core.utils
 
StatementFunction(SecureTransaction) - Constructor for class org.neo4j.graphalgo.core.utils.StatementFunction
 
STATS - org.neo4j.graphalgo.beta.pregel.annotation.GDSMode
 
stop() - Method in class org.neo4j.graphalgo.core.utils.ProgressTimer
 
storage() - Method in class org.neo4j.graphalgo.core.loading.CompressedLongArray
 
store(GraphCreateFromStoreConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Cases
 
store(GraphCreateFromStoreConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Rewriter
 
store(GraphCreateFromStoreConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Visitor
 
storeInternalLogPath() - Static method in class org.neo4j.graphalgo.core.Settings
 
StoreScanner<Reference> - Interface in org.neo4j.graphalgo.core.loading
 
StoreScanner.Factory<Reference> - Interface in org.neo4j.graphalgo.core.loading
 
StoreScanner.RecordConsumer<Reference> - Interface in org.neo4j.graphalgo.core.loading
 
StoreScanner.ScanCursor<Reference> - Interface in org.neo4j.graphalgo.core.loading
 
storeSize() - Method in interface org.neo4j.graphalgo.core.loading.StoreScanner
 
stream() - Method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
stream() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
 
stream() - Method in class org.neo4j.graphalgo.core.utils.SetBitsIterable
 
STREAM - org.neo4j.graphalgo.beta.pregel.annotation.GDSMode
 
streamRelationships(long, double) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
streamRelationships(long, double) - Method in interface org.neo4j.graphalgo.api.RelationshipIterator
 
streamRelationships(long, double) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
streamRelationships(long, double) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
StringJoining - Class in org.neo4j.graphalgo.utils
 
sudo() - Method in interface org.neo4j.graphalgo.config.BaseConfig
 
sudo() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
SUDO_KEY - Static variable in interface org.neo4j.graphalgo.config.BaseConfig
 
sum() - Method in class org.neo4j.graphalgo.core.utils.paged.PaddedAtomicLong
 
SUM - org.neo4j.graphalgo.core.Aggregation
 
sumSquareDelta(double[], double[], int) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
sumSquareDeltas(double[], double[][], int) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
sumSquareDeltaSkip(double[], double[], int, double) - Static method in class org.neo4j.graphalgo.core.utils.Intersections
 
SUPER_NORMAL_EXPONENT - Static variable in class org.neo4j.graphalgo.core.loading.DoubleCodec
Exponent in representing a NaN or Infinity value.
superstep() - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext.ComputeContext
Returns the current superstep (0-based).
supplier(CheckedSupplier<? extends T, E>) - Static method in class org.neo4j.graphalgo.utils.ExceptionUtil
 
supplier(CheckedSupplier<T, E>) - Static method in interface org.neo4j.graphalgo.utils.CheckedSupplier
 
supportedSignificandWith() - Method in class org.neo4j.graphalgo.core.loading.DoubleCodec
 
synchronizedPut(long, double) - Method in class org.neo4j.graphalgo.core.utils.paged.TrackingLongDoubleHashMap
 

T

target - Variable in class org.neo4j.graphalgo.core.huge.HugeGraph.GetTargetConsumer
 
targetId() - Method in interface org.neo4j.graphalgo.api.RelationshipCursor
 
targetNodeId() - Method in interface org.neo4j.graphalgo.core.loading.construction.RelationshipsBuilder.Relationship
 
targetNodeReference() - Method in class org.neo4j.graphalgo.core.loading.RelationshipRecordReference
 
targetNodeReference() - Method in interface org.neo4j.graphalgo.core.loading.RelationshipReference
 
targetNodeReference() - Method in class org.neo4j.graphalgo.core.loading.RelationshipScanCursorReference
 
TASK_LOADING - Static variable in class org.neo4j.graphalgo.api.GraphStoreFactory
 
tasks(int, Function<Integer, ? extends Runnable>) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
tasks(int, Supplier<? extends Runnable>) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
TEMPORARY_MEMORY - Static variable in class org.neo4j.graphalgo.core.utils.mem.MemoryEstimations
 
terminationFlag - Variable in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
terminationFlag() - Method in interface org.neo4j.graphalgo.api.GraphLoaderContext
 
TerminationFlag - Interface in org.neo4j.graphalgo.core.utils
 
TerminationFlagImpl - Class in org.neo4j.graphalgo.core.utils
 
TerminationFlagImpl(KernelTransaction) - Constructor for class org.neo4j.graphalgo.core.utils.TerminationFlagImpl
 
test(int) - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections.PrimitiveIntFilteringIterator
 
test(int, int) - Method in interface org.neo4j.graphalgo.api.IntBinaryPredicate
 
test(int, int, double) - Method in interface org.neo4j.graphalgo.core.heavyweight.Converters.IntIntDoublePredicate
 
test(long) - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections.PrimitiveLongFilteringIterator
 
threadCount(int, int) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
threadCount(long, long) - Static method in class org.neo4j.graphalgo.core.concurrency.ParallelUtil
 
threadName() - Method in class org.neo4j.graphalgo.core.loading.IndexedNodePropertyImporter
 
threadName() - Method in class org.neo4j.graphalgo.core.loading.NodesScanner
 
threadName() - Method in class org.neo4j.graphalgo.core.loading.RelationshipsScanner
 
threadName() - Method in interface org.neo4j.graphalgo.core.utils.RenamesCurrentThread
 
threadPool - Variable in class org.neo4j.graphalgo.core.loading.ScanningRecordsImporter
 
THRESHOLD_1_BYTE - Static variable in class org.neo4j.graphalgo.core.loading.VarLongEncoding
 
THRESHOLD_2_BYTE - Static variable in class org.neo4j.graphalgo.core.loading.VarLongEncoding
 
THRESHOLD_3_BYTE - Static variable in class org.neo4j.graphalgo.core.loading.VarLongEncoding
 
THRESHOLD_4_BYTE - Static variable in class org.neo4j.graphalgo.core.loading.VarLongEncoding
 
THRESHOLD_5_BYTE - Static variable in class org.neo4j.graphalgo.core.loading.VarLongEncoding
 
THRESHOLD_6_BYTE - Static variable in class org.neo4j.graphalgo.core.loading.VarLongEncoding
 
THRESHOLD_7_BYTE - Static variable in class org.neo4j.graphalgo.core.loading.VarLongEncoding
 
THRESHOLD_8_BYTE - Static variable in class org.neo4j.graphalgo.core.loading.VarLongEncoding
 
throwIfUnchecked(Throwable) - Static method in class org.neo4j.graphalgo.utils.ExceptionUtil
Rethrows exception if it is an instance of RuntimeException or Error.
times(long) - Method in interface org.neo4j.graphalgo.core.utils.mem.MemoryEstimation
 
times(long) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
TimeUtil - Class in org.neo4j.graphalgo.core.utils
 
TimeUtil() - Constructor for class org.neo4j.graphalgo.core.utils.TimeUtil
 
toArray() - Method in class org.neo4j.graphalgo.core.utils.AtomicDoubleArray
 
toArray() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeDoubleArray
toArray() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeIntArray
toArray() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongArray
toArray() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeObjectArray
toBitSet() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicBitSet
 
toggle(boolean) - Method in enum org.neo4j.graphalgo.utils.GdsFeatureToggles
 
toIterator(PrimitiveLongIterator) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
tokenNodeLabelMapping() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
tokenRelationshipTypeMapping() - Method in interface org.neo4j.graphalgo.core.GraphDimensions
 
tolerance() - Method in interface org.neo4j.graphalgo.config.ToleranceConfig
 
TOLERANCE_DEFAULT - Static variable in class org.neo4j.graphalgo.core.ProcedureConstants
 
ToleranceConfig - Interface in org.neo4j.graphalgo.config
 
toList(PrimitiveIntIterator) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
Pulls all items from the iterator and puts them into a List, boxing each int.
toMap() - Method in interface org.neo4j.graphalgo.api.schema.ElementSchema
 
toMap() - Method in interface org.neo4j.graphalgo.api.schema.GraphSchema
 
toMap() - Method in interface org.neo4j.graphalgo.config.BaseConfig
 
toMappedNodeId(long) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
toMappedNodeId(long) - Method in interface org.neo4j.graphalgo.api.IdMapping
Map original nodeId to inner nodeId
toMappedNodeId(long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
toMappedNodeId(long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
toMappedNodeId(long) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
toMappedNodeId(long) - Method in class org.neo4j.graphalgo.core.loading.IdMap
 
toObject() - Method in class org.neo4j.graphalgo.AbstractNodeProjections
 
toObject() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
toObject() - Method in class org.neo4j.graphalgo.ElementProjection
 
toObject(boolean) - Method in class org.neo4j.graphalgo.AbstractPropertyMappings
 
toObject(boolean) - Method in class org.neo4j.graphalgo.PropertyMapping
 
toOriginalId - Variable in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
toOriginalNodeId(long) - Method in class org.neo4j.graphalgo.api.FilterGraph
 
toOriginalNodeId(long) - Method in interface org.neo4j.graphalgo.api.IdMapping
Map inner nodeId back to original nodeId
toOriginalNodeId(long) - Method in class org.neo4j.graphalgo.core.huge.HugeGraph
 
toOriginalNodeId(long) - Method in class org.neo4j.graphalgo.core.huge.NodeFilteredGraph
 
toOriginalNodeId(long) - Method in class org.neo4j.graphalgo.core.huge.UnionGraph
 
toOriginalNodeId(long) - Method in class org.neo4j.graphalgo.core.loading.IdMap
 
topLevelKernelTransaction() - Method in class org.neo4j.graphalgo.core.SecureTransaction
Returns the KernelTransaction for the provided top-level Transaction.
topology() - Method in interface org.neo4j.graphalgo.api.Relationships
 
toPrimitiveIterator(Iterator<Integer>) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
 
toPrimitiveIterator(Iterator<Long>) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
 
toSet(PrimitiveIntIterator) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollections
Pulls all items from the iterator and puts them into a Set, boxing each int.
toSet(PrimitiveLongIterator) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
Pulls all items from the iterator and puts them into a Set, boxing each long.
toSet(PrimitiveLongSet) - Static method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollections
Convert primitive set into a plain old java Set, boxing each long.
toString() - Method in class org.neo4j.graphalgo.api.DefaultValue
 
toString() - Method in class org.neo4j.graphalgo.core.utils.AtomicDoubleArray
 
toString() - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
toString() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongDoubleMap
Convert the contents of this map to a human-friendly string.
toString() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongDoubleMap
Convert the contents of this map to a human-friendly string.
toString() - Method in class org.neo4j.graphalgo.core.utils.paged.HugeLongLongMap
Convert the contents of this map to a human-friendly string.
toString() - Method in class org.neo4j.graphalgo.ElementIdentifier
 
toString(Direction) - Static method in class org.neo4j.graphalgo.core.utils.Directions
 
toValue(double) - Method in interface org.neo4j.graphalgo.core.write.RelationshipPropertyTranslator
 
trackedBytes() - Method in interface org.neo4j.graphalgo.core.utils.mem.AllocationTracker
Return the current total of tracked bytes.
trackedBytes() - Method in class org.neo4j.graphalgo.core.utils.mem.InMemoryAllocationTracker
 
trackedBytes() - Method in class org.neo4j.graphalgo.core.utils.mem.KernelAllocationTracker
 
tracker - Variable in class org.neo4j.graphalgo.core.loading.ScanningRecordsImporter
 
tracker() - Method in interface org.neo4j.graphalgo.api.GraphLoaderContext
 
tracker(AllocationTracker) - Method in class org.neo4j.graphalgo.core.loading.NativeNodePropertyImporter.Builder
 
TrackingLongDoubleHashMap - Class in org.neo4j.graphalgo.core.utils.paged
 
TrackingLongDoubleHashMap(AllocationTracker) - Constructor for class org.neo4j.graphalgo.core.utils.paged.TrackingLongDoubleHashMap
 
trainConfig() - Method in interface org.neo4j.graphalgo.core.model.Model
 
transaction - Variable in class org.neo4j.graphalgo.core.loading.ScanningRecordsImporter
 
transaction() - Method in interface org.neo4j.graphalgo.api.GraphLoaderContext
 
transactionStateAllocation() - Static method in class org.neo4j.graphalgo.core.Settings
 
transactionStateMaxOffHeapMemory() - Static method in class org.neo4j.graphalgo.core.Settings
 
TRANSIENT - org.neo4j.graphalgo.api.GraphStore.PropertyState
 
TransientAdjacencyList - Class in org.neo4j.graphalgo.core.huge
 
TransientAdjacencyList(byte[][]) - Constructor for class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
TransientAdjacencyList.Cursor - Class in org.neo4j.graphalgo.core.huge
 
TransientAdjacencyList.DecompressingCursor - Class in org.neo4j.graphalgo.core.huge
 
TransientAdjacencyListBuilder - Class in org.neo4j.graphalgo.core.loading
 
TransientAdjacencyOffsets - Class in org.neo4j.graphalgo.core.huge
 
TransientAdjacencyOffsets() - Constructor for class org.neo4j.graphalgo.core.huge.TransientAdjacencyOffsets
 
TransientFilteredAdjacencyOffsets - Class in org.neo4j.graphalgo.core.huge
 
TransientFilteredAdjacencyOffsets(IdMap, AdjacencyOffsets) - Constructor for class org.neo4j.graphalgo.core.huge.TransientFilteredAdjacencyOffsets
 
translateId(long) - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
tx - Variable in class org.neo4j.graphalgo.utils.StatementApi
 
type() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
type() - Method in interface org.neo4j.graphalgo.api.NodeProperty
 
type() - Method in interface org.neo4j.graphalgo.api.RelationshipProperty
 
type(String, String) - Static method in class org.neo4j.graphalgo.core.model.ModelCatalog
 
TYPE_KEY - Static variable in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
typeFilter() - Method in class org.neo4j.graphalgo.AbstractRelationshipProjections
 
typeTokenId() - Method in class org.neo4j.graphalgo.core.loading.RelationshipRecordReference
 
typeTokenId() - Method in interface org.neo4j.graphalgo.core.loading.RelationshipReference
 
typeTokenId() - Method in class org.neo4j.graphalgo.core.loading.RelationshipScanCursorReference
 

U

udc() - Static method in class org.neo4j.graphalgo.core.Settings
 
unchecked(CheckedRunnable<E>) - Static method in class org.neo4j.graphalgo.utils.ExceptionUtil
 
uncompress(long[]) - Method in class org.neo4j.graphalgo.core.loading.CompressedLongArray
 
uncompressedMemoryEstimation(boolean) - Static method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
uncompressedMemoryEstimation(RelationshipType, boolean) - Static method in class org.neo4j.graphalgo.core.huge.TransientAdjacencyList
 
UNDIRECTED - org.neo4j.graphalgo.Orientation
 
UNIFORM - org.neo4j.graphalgo.beta.generator.RelationshipDistribution
 
uniformSample(long, Random) - Static method in class org.neo4j.graphalgo.core.utils.statistics.DistributionHelper
 
union(long, long) - Method in interface org.neo4j.graphalgo.core.utils.paged.dss.DisjointSetStruct
Joins the set of p (Sp) with set of q (Sq).
union(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.HugeAtomicDisjointSetStruct
 
union(long, long) - Method in class org.neo4j.graphalgo.core.utils.paged.dss.SequentialDisjointSetStruct
Deprecated.
 
union(GraphSchema) - Method in interface org.neo4j.graphalgo.api.schema.GraphSchema
 
union(NodeSchema) - Method in interface org.neo4j.graphalgo.api.schema.NodeSchema
 
union(RelationshipSchema) - Method in interface org.neo4j.graphalgo.api.schema.RelationshipSchema
 
union(MemoryRange) - Method in class org.neo4j.graphalgo.core.utils.mem.MemoryRange
 
union(SELF) - Method in interface org.neo4j.graphalgo.api.schema.ElementSchema
 
UnionGraph - Class in org.neo4j.graphalgo.core.huge
 
UnionNodeProperties - Class in org.neo4j.graphalgo.api
 
UnionNodeProperties(NodeMapping, Map<NodeLabel, NodeProperties>) - Constructor for class org.neo4j.graphalgo.api.UnionNodeProperties
 
unionProperties(Map<I, Map<String, ValueType>>) - Method in interface org.neo4j.graphalgo.api.schema.ElementSchema
 
UNKNOWN - org.neo4j.graphalgo.api.nodeproperties.ValueType
 
update(long, DoubleUnaryOperator) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicDoubleArray
Atomically updates the element at index index with the results of applying the given function, returning the updated value.
update(long, LongUnaryOperator) - Method in class org.neo4j.graphalgo.core.utils.paged.HugeAtomicLongArray
Atomically updates the element at index index with the results of applying the given function, returning the updated value.
updateElementAt(int, long) - Method in class org.neo4j.graphalgo.core.utils.queue.BoundedLongPriorityQueue
 
USE_KERNEL_TRACKER - org.neo4j.graphalgo.utils.GdsFeatureToggles
 
USE_PRE_AGGREGATION - org.neo4j.graphalgo.utils.GdsFeatureToggles
 
USE_PROPERTY_VALUE_INDEX - org.neo4j.graphalgo.utils.GdsFeatureToggles
 
username() - Method in interface org.neo4j.graphalgo.config.BaseConfig
 
username() - Method in interface org.neo4j.graphalgo.core.GraphLoader
 
username() - Method in interface org.neo4j.graphalgo.core.model.Model
 

V

v - Variable in class org.neo4j.graphalgo.core.utils.Pointer.BoolPointer
 
v - Variable in class org.neo4j.graphalgo.core.utils.Pointer.DoublePointer
 
v - Variable in class org.neo4j.graphalgo.core.utils.Pointer.GenericPointer
 
v - Variable in class org.neo4j.graphalgo.core.utils.Pointer.IntPointer
 
v - Variable in class org.neo4j.graphalgo.core.utils.Pointer.LongPointer
 
validate() - Method in interface org.neo4j.graphalgo.core.utils.export.GraphStoreExportConfig
 
validate(GraphStore) - Method in interface org.neo4j.graphalgo.config.DeleteRelationshipsConfig
 
validate(GraphStore) - Method in interface org.neo4j.graphalgo.config.GraphExportNodePropertiesConfig
 
validate(GraphStore) - Method in interface org.neo4j.graphalgo.config.GraphStreamRelationshipPropertiesConfig
 
validate(GraphStore) - Method in interface org.neo4j.graphalgo.config.GraphWriteRelationshipConfig
 
validate(GraphDimensions, GraphCreateFromStoreConfig) - Static method in class org.neo4j.graphalgo.core.GraphDimensionsValidation
 
validate(GraphStoreWithConfig, CONFIG) - Static method in class org.neo4j.graphalgo.api.GraphStoreValidation
 
validateConcurrency() - Method in interface org.neo4j.graphalgo.config.ConcurrencyConfig
 
validateConcurrency(int, String) - Static method in interface org.neo4j.graphalgo.config.ConcurrencyConfig
 
validateIsUndirectedGraph(GraphCreateConfig, CONFIG) - Static method in class org.neo4j.graphalgo.config.GraphCreateConfigValidations
 
validateIterations() - Method in interface org.neo4j.graphalgo.config.IterationsConfig
 
validateOrientationCombinations(GraphCreateConfig, CONFIG) - Static method in class org.neo4j.graphalgo.config.GraphCreateConfigValidations
Validates that Orientation.UNDIRECTED is not mixed with Orientation.NATURAL and Orientation.REVERSE.
validateProjectionsAreNotEmpty() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
validateProperties() - Method in class org.neo4j.graphalgo.PropertyMapping
 
validateReadConcurrency() - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
validateRelationships() - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig
 
validateRelationships() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromCypherConfig
 
validateSourceNodeIsLoaded(long, long) - Static method in class org.neo4j.graphalgo.utils.ExceptionUtil
 
validateTargetNodeIsLoaded(long, long) - Static method in class org.neo4j.graphalgo.utils.ExceptionUtil
 
validateWriteConcurrency() - Method in interface org.neo4j.graphalgo.config.WriteConfig
 
validNodeLabels(GraphStore) - Method in interface org.neo4j.graphalgo.config.GraphExportNodePropertiesConfig
Returns the node labels that are to be considered for writing properties.
validRelationshipTypes(GraphStore) - Method in interface org.neo4j.graphalgo.config.GraphStreamRelationshipPropertiesConfig
Returns the relationship types that are to be considered for streaming properties.
value - Variable in class org.neo4j.graphalgo.core.loading.MutableIntValue
 
value() - Method in enum org.neo4j.graphalgo.config.RandomGraphGeneratorConfig.AllowSelfLoops
 
value(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.DoubleArrayNodeProperties
 
value(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.DoubleNodeProperties
 
value(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.FloatArrayNodeProperties
 
value(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.LongArrayNodeProperties
 
value(long) - Method in class org.neo4j.graphalgo.api.nodeproperties.LongIfChangedNodeProperties
 
value(long) - Method in interface org.neo4j.graphalgo.api.nodeproperties.LongNodeProperties
 
value(long) - Method in interface org.neo4j.graphalgo.api.NodeProperties
 
value(long) - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
value(long) - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
value(long) - Method in class org.neo4j.graphalgo.core.loading.NullPropertyMap.DoubleNullPropertyMap
 
value(long) - Method in class org.neo4j.graphalgo.core.loading.NullPropertyMap.LongNullPropertyMap
 
ValueConversion - Class in org.neo4j.graphalgo.utils
 
valueOf(String) - Static method in enum org.neo4j.graphalgo.api.GraphStore.PropertyState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.graphalgo.api.nodeproperties.ValueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.graphalgo.beta.generator.RelationshipDistribution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.graphalgo.beta.pregel.annotation.GDSMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.graphalgo.beta.pregel.PregelSchema.Visibility
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.graphalgo.config.RandomGraphGeneratorConfig.AllowSelfLoops
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.graphalgo.core.Aggregation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.graphalgo.core.utils.ProgressLogger.NullProgressLogger
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.graphalgo.Orientation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.neo4j.graphalgo.utils.GdsFeatureToggles
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.neo4j.graphalgo.api.GraphStore.PropertyState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.graphalgo.api.nodeproperties.ValueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.neo4j.graphalgo.api.NodeProperty
 
values() - Method in interface org.neo4j.graphalgo.api.RelationshipProperty
 
values() - Method in interface org.neo4j.graphalgo.api.RelationshipPropertyStore
 
values() - Static method in enum org.neo4j.graphalgo.beta.generator.RelationshipDistribution
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.graphalgo.beta.pregel.annotation.GDSMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.graphalgo.beta.pregel.PregelSchema.Visibility
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.graphalgo.config.RandomGraphGeneratorConfig.AllowSelfLoops
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.graphalgo.core.Aggregation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.graphalgo.core.utils.ProgressLogger.NullProgressLogger
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.graphalgo.Orientation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.neo4j.graphalgo.utils.GdsFeatureToggles
Returns an array containing the constants of this enum type, in the order they are declared.
valueType() - Method in interface org.neo4j.graphalgo.api.nodeproperties.DoubleArrayNodeProperties
 
valueType() - Method in interface org.neo4j.graphalgo.api.nodeproperties.DoubleNodeProperties
 
valueType() - Method in interface org.neo4j.graphalgo.api.nodeproperties.FloatArrayNodeProperties
 
valueType() - Method in interface org.neo4j.graphalgo.api.nodeproperties.LongArrayNodeProperties
 
valueType() - Method in interface org.neo4j.graphalgo.api.nodeproperties.LongNodeProperties
 
valueType() - Method in interface org.neo4j.graphalgo.api.NodeProperties
 
valueType() - Method in class org.neo4j.graphalgo.api.UnionNodeProperties
 
valueType() - Method in class org.neo4j.graphalgo.core.huge.FilteredNodeProperties
 
valueType() - Method in class org.neo4j.graphalgo.core.loading.NullPropertyMap.DoubleNullPropertyMap
 
valueType() - Method in class org.neo4j.graphalgo.core.loading.NullPropertyMap.LongNullPropertyMap
 
ValueType - Enum in org.neo4j.graphalgo.api.nodeproperties
 
VarLongEncoding - Class in org.neo4j.graphalgo.core.loading
 
verify(String) - Static method in class org.neo4j.graphalgo.core.SignatureTool
 
verifyProperties(Set<String>, Set<String>, String) - Method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
visit(GraphCreateFromCypherConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Visitor
 
visit(GraphCreateFromStoreConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Visitor
 
visit(RandomGraphGeneratorConfig) - Method in interface org.neo4j.graphalgo.config.GraphCreateConfig.Visitor
 
visited(int) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntVisitor
Visit the given entry.
visited(long) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongVisitor
Visit the given entry.
visitKeys(PrimitiveIntVisitor<E>) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntCollection
Visit the keys of this collection, until all have been visited or the visitor returns 'true'.
visitKeys(PrimitiveIntVisitor<E>) - Method in class org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveIntStack
 
visitKeys(PrimitiveLongVisitor<E>) - Method in interface org.neo4j.graphalgo.core.utils.collection.primitive.PrimitiveLongCollection
Visit the keys of this collection, until all have been visited or the visitor returns 'true'.
voteToHalt() - Method in class org.neo4j.graphalgo.beta.pregel.PregelContext.ComputeContext
Notify the execution framework that this node intends to stop the computation.

W

withAdditionalPropertyMappings(PropertyMappings) - Method in class org.neo4j.graphalgo.AbstractNodeProjection
 
withAdditionalPropertyMappings(PropertyMappings) - Method in class org.neo4j.graphalgo.AbstractRelationshipProjection
 
withAdditionalPropertyMappings(PropertyMappings) - Method in class org.neo4j.graphalgo.ElementProjection
 
withCheckInterval(long) - Method in class org.neo4j.graphalgo.core.utils.TerminationFlagImpl
 
withDefaultAggregation(Aggregation) - Method in class org.neo4j.graphalgo.AbstractPropertyMappings.Builder
 
withInitial(Supplier<T>) - Static method in class org.neo4j.graphalgo.utils.CloseableThreadLocal
 
withInitial(CheckedSupplier<T, ?>) - Static method in class org.neo4j.graphalgo.utils.AutoCloseableThreadLocal
 
withLog(Log) - Method in class org.neo4j.graphalgo.core.write.ExporterBuilder
 
withLogIntervalMillis(int) - Method in class org.neo4j.graphalgo.core.utils.ProgressLoggerAdapter
Deprecated.
 
withNormalizedPropertyMappings() - Method in interface org.neo4j.graphalgo.config.GraphCreateFromStoreConfig
 
withRelationPropertyTranslator(RelationshipPropertyTranslator) - Method in class org.neo4j.graphalgo.core.write.RelationshipExporter.Builder
 
withRestrictedAccess(AccessMode.Static) - Method in class org.neo4j.graphalgo.core.SecureTransaction
Returns a new SecureTransaction restricted by the provided AccessMode.
wrap(boolean) - Static method in class org.neo4j.graphalgo.core.utils.Pointer
 
wrap(double) - Static method in class org.neo4j.graphalgo.core.utils.Pointer
 
wrap(int) - Static method in class org.neo4j.graphalgo.core.utils.Pointer
 
wrap(long) - Static method in class org.neo4j.graphalgo.core.utils.Pointer
 
wrap(KernelTransaction) - Static method in interface org.neo4j.graphalgo.core.utils.TerminationFlag
 
wrap(KernelTransaction, long) - Static method in interface org.neo4j.graphalgo.core.utils.TerminationFlag
 
wrap(T) - Static method in class org.neo4j.graphalgo.core.utils.Pointer
 
write(String) - Method in class org.neo4j.graphalgo.core.write.RelationshipExporter
 
write(String, String) - Method in class org.neo4j.graphalgo.core.write.RelationshipExporter
 
write(String, Optional<String>) - Method in class org.neo4j.graphalgo.core.write.RelationshipExporter
 
write(String, Optional<String>, RelationshipWithPropertyConsumer) - Method in class org.neo4j.graphalgo.core.write.RelationshipExporter
 
write(String, NodeProperties) - Method in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
write(Collection<NodePropertyExporter.NodeProperty>) - Method in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
write(NodePropertyExporter.NodeProperty) - Method in class org.neo4j.graphalgo.core.write.NodePropertyExporter
 
WRITE - org.neo4j.graphalgo.beta.pregel.annotation.GDSMode
 
WRITE_CONCURRENCY_KEY - Static variable in interface org.neo4j.graphalgo.config.WriteConfig
 
WRITE_PROPERTY_KEY - Static variable in interface org.neo4j.graphalgo.config.WritePropertyConfig
 
writeConcurrency() - Method in interface org.neo4j.graphalgo.beta.pregel.PregelConfig
 
writeConcurrency() - Method in interface org.neo4j.graphalgo.config.WriteConfig
 
writeConcurrency() - Method in interface org.neo4j.graphalgo.core.utils.export.GraphStoreExportConfig
 
WriteConfig - Interface in org.neo4j.graphalgo.config
 
writeInt(int) - Method in interface org.neo4j.graphalgo.core.loading.AdjacencyListPageSlice
Write a single int at the current AdjacencyListPageSlice.offset().
writeProperty() - Method in interface org.neo4j.graphalgo.beta.pregel.PregelConfig
 
writeProperty() - Method in interface org.neo4j.graphalgo.config.WritePropertyConfig
 
WritePropertyConfig - Interface in org.neo4j.graphalgo.config
 
WriteRelationshipConfig - Interface in org.neo4j.graphalgo.config
 
writeRelationshipType() - Method in interface org.neo4j.graphalgo.config.WriteRelationshipConfig
 

Y

YES - org.neo4j.graphalgo.config.RandomGraphGeneratorConfig.AllowSelfLoops
 

Z

zigZag(long) - Static method in class org.neo4j.graphalgo.core.loading.VarLongEncoding
 
A B C D E F G H I J K L M N O P R S T U V W Y Z 
All Classes All Packages