Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abs(Half) - Static method in class com.apple.foundationdb.half.HalfMath
-
Returns the absolute
Halfobject of ahalfinstance. - AbstractChangeSet<S extends NodeSlot,
N extends com.apple.foundationdb.async.rtree.AbstractNode<S, N>> - Class in com.apple.foundationdb.async.rtree -
Abstract base implementations for all
Node.ChangeSets. - AbstractRealVector - Class in com.apple.foundationdb.linear
-
An abstract base class representing a mathematical vector.
- AbstractRealVector(double[]) - Constructor for class com.apple.foundationdb.linear.AbstractRealVector
-
Constructs a new RealVector with the given data.
- accept(FDBClientLogEvents.Event) - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEvents.EventRunner
- accept(KeyValue) - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventDeserializer
-
Process next key-value pair by calling callback or appending to pending buffer.
- accept(Transaction, FDBClientLogEvents.Event) - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEventCounter
-
Update the count tree with keys — and optional storage server IP addresses — in an event.
- accept(Transaction, FDBClientLogEvents.Event) - Method in interface com.apple.foundationdb.clientlog.DatabaseClientLogEvents.EventConsumer
- accept(T) - Method in interface com.apple.foundationdb.clientlog.FDBClientLogEvents.AsyncConsumer
- ACCESSED_UNREADABLE - Enum constant in enum com.apple.foundationdb.FDBError
- add(byte[]) - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
-
Add encoded tuple bytes to the tree.
- add(double) - Method in interface com.apple.foundationdb.linear.RealVector
- add(RealVector) - Method in interface com.apple.foundationdb.linear.RealVector
- add(Transformed<? extends RealVector>) - Method in class com.apple.foundationdb.linear.Transformed
- add(TransactionContext, byte[]) - Method in class com.apple.foundationdb.async.RankedSet
-
Add a key to the set.
- add(Tuple) - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
-
Add the given tuple to the tree.
- addCommit(Transaction, FDBClientLogEvents.CommitRequest) - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEventCounter
- addIncrementLevelKey(Transaction, byte[], int, boolean) - Method in class com.apple.foundationdb.async.RankedSet
- addInsertLevelKey(Transaction, byte[], int) - Method in class com.apple.foundationdb.async.RankedSet
- addKey(Transaction, byte[]) - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEventCounter
- addKeyAddresses(Transaction, byte[]) - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEventCounter
- addLevelZeroKey(Transaction, byte[], int, boolean) - Method in class com.apple.foundationdb.async.RankedSet
- addLogInfo(Object...) - Method in exception com.apple.foundationdb.map.BunchedMapException
- addLogInfo(Object...) - Method in exception com.apple.foundationdb.util.LoggableException
-
Add a list of key/value pairs to the log information.
- addLogInfo(Object...) - Method in interface com.apple.foundationdb.util.LoggableKeysAndValues
-
Add a list of key/value pairs to the log information.
- addLogInfo(Object...) - Method in class com.apple.foundationdb.util.LoggableKeysAndValuesImpl
-
Add a list of key/value pairs to the log information.
- addLogInfo(String, Object) - Method in exception com.apple.foundationdb.map.BunchedMapException
- addLogInfo(String, Object) - Method in exception com.apple.foundationdb.util.LoggableException
-
Add a key/value pair to the log information.
- addLogInfo(String, Object) - Method in interface com.apple.foundationdb.util.LoggableKeysAndValues
-
Add a key/value pair to the log information.
- addLogInfo(String, Object) - Method in class com.apple.foundationdb.util.LoggableKeysAndValuesImpl
-
Add a key/value pair to the log information.
- addPrefixChild(Object) - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
-
Add a non-tuple object to the root of the tree.
- addRange(Transaction, Range) - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEventCounter
- ADDRESS_IN_USE - Enum constant in enum com.apple.foundationdb.FDBError
- AffineOperator - Class in com.apple.foundationdb.linear
-
Vector operator that applies/unapplies a linear operator and an addition to a vector.
- AffineOperator(LinearOperator, RealVector) - Constructor for class com.apple.foundationdb.linear.AffineOperator
- afterTask() - Method in class com.apple.foundationdb.async.TaskNotifyingExecutor
-
Called in the context of an executor thread, immediately after a task has completed execution (either successfully or with error).
- alreadyCancelled() - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
- AlwaysTrue() - Constructor for class com.apple.foundationdb.async.MoreAsyncUtil.AlwaysTrue
- AND_V2 - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Mutation
- API_VERSION_ALREADY_SET - Enum constant in enum com.apple.foundationdb.FDBError
- API_VERSION_INVALID - Enum constant in enum com.apple.foundationdb.FDBError
- API_VERSION_NOT_SUPPORTED - Enum constant in enum com.apple.foundationdb.FDBError
- API_VERSION_UNSET - Enum constant in enum com.apple.foundationdb.FDBError
- apply(RealVector) - Method in class com.apple.foundationdb.linear.AffineOperator
- apply(RealVector) - Method in class com.apple.foundationdb.linear.FhtKacRotator
- apply(RealVector) - Method in interface com.apple.foundationdb.linear.RealMatrix
- apply(RealVector) - Method in interface com.apple.foundationdb.linear.VectorOperator
-
Apply this operator to the vector passed in.
- apply(Transaction) - Method in class com.apple.foundationdb.async.rtree.AbstractChangeSet
- apply(Transaction) - Method in interface com.apple.foundationdb.async.rtree.Node.ChangeSet
-
Apply all mutations for the change set.
- apply(T) - Method in class com.apple.foundationdb.async.MoreAsyncUtil.AlwaysTrue
- area() - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- ASC_NULLS_FIRST - Enum constant in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
- ASC_NULLS_LAST - Enum constant in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
- asNodeReferenceWithVector() - Method in class com.apple.foundationdb.async.hnsw.NodeReference
-
Casts this object to a
NodeReferenceWithVector. - asNodeReferenceWithVector() - Method in class com.apple.foundationdb.async.hnsw.NodeReferenceWithVector
-
Returns this instance cast as a
NodeReferenceWithVector. - AsyncPeekCallbackIterator<T> - Interface in com.apple.foundationdb.async
-
An
AsyncPeekCallbackIteratoris an extension of theAsyncPeekIteratorinterface that can be given a callback to call after each time it advances. - AsyncPeekIterator<T> - Interface in com.apple.foundationdb.async
-
A
AsyncPeekIteratoris an extension of theAsyncIteratorinterface that adds peek semantics, i.e., viewing the next element of the iterator without advancing it forward. - ATTRIBUTE_NOT_FOUND - Enum constant in enum com.apple.foundationdb.FDBError
B
- beforeTask() - Method in class com.apple.foundationdb.async.TaskNotifyingExecutor
-
Called in the context of an executor thread, immediately prior to actually executing a task.
- BIND_FAILED - Enum constant in enum com.apple.foundationdb.FDBError
- build() - Method in class com.apple.foundationdb.async.RankedSet.ConfigBuilder
- build() - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- build(int) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- BunchedMap<K,
V> - Class in com.apple.foundationdb.map -
An implementation of a FoundationDB-backed map that bunches close keys together to minimize the overhead of storing keys with a common prefix.
- BunchedMap(BunchedMap<K, V>) - Constructor for class com.apple.foundationdb.map.BunchedMap
-
Copy constructor for
BunchedMaps. - BunchedMap(BunchedSerializer<K, V>, Comparator<K>, int) - Constructor for class com.apple.foundationdb.map.BunchedMap
-
Create a bunched map with the given serializer, key comparator, and bunch size.
- BunchedMapException - Exception in com.apple.foundationdb.map
-
Exception class that can be thrown by a
BunchedMap. - BunchedMapException(String) - Constructor for exception com.apple.foundationdb.map.BunchedMapException
-
Create a new exception with a static message.
- BunchedMapException(String, Throwable) - Constructor for exception com.apple.foundationdb.map.BunchedMapException
-
Create a new exception with a static message and cause.
- BunchedMapIterator<K,
V> - Class in com.apple.foundationdb.map -
An iterator implementation that will iterate over the keys of a
BunchedMap. - BunchedMapMultiIterator<K,
V, T> - Class in com.apple.foundationdb.map -
An iterator that will return
BunchedMapScanEntryobjects while scanning over multipleBunchedMaps. - BunchedMapScanEntry<K,
V, T> - Class in com.apple.foundationdb.map -
Struct containing the results of scanning one or more
BunchedMaps using thescanMulti()function. - BunchedSerializationException - Exception in com.apple.foundationdb.map
-
Exception that can be thrown from a
BunchedSerializerwhile serializing or deserializing an element. - BunchedSerializationException(String) - Constructor for exception com.apple.foundationdb.map.BunchedSerializationException
-
Create a new exception with a static message.
- BunchedSerializationException(String, Throwable) - Constructor for exception com.apple.foundationdb.map.BunchedSerializationException
-
Create a new exception with a static message and cause.
- BunchedSerializer<K,
V> - Interface in com.apple.foundationdb.map -
A class to serialize and deserialize entries of a
BunchedMap. - BunchedTupleSerializer - Class in com.apple.foundationdb.map
-
A
BunchedSerializerthat usesTuples as both the expected key and value type. - BY_NODE - Enum constant in enum com.apple.foundationdb.async.rtree.RTree.Storage
-
Every node with all its slots is serialized as one key/value pair.
- BY_SLOT - Enum constant in enum com.apple.foundationdb.async.rtree.RTree.Storage
-
Every node slot is serialized as a key/value pair in FDB.
- ByteArrayUtil2 - Class in com.apple.foundationdb.tuple
-
Helper methods in the spirit of
ByteArrayUtil. - BYTES - Static variable in class com.apple.foundationdb.half.Half
-
The number of bytes used to represent a
Halfvalue. - byteValue() - Method in class com.apple.foundationdb.half.Half
-
Returns the value of the specified number as a
byte.
C
- canAppend() - Method in interface com.apple.foundationdb.map.BunchedSerializer
-
Whether the output from
serializeEntrycan be appended to an existing serialized entry list to produce a new bunched value. - canAppend() - Method in class com.apple.foundationdb.map.BunchedTupleSerializer
-
Returns
true. - cancel() - Method in class com.apple.foundationdb.async.rtree.RTree.ItemSlotIterator
- cancel() - Method in class com.apple.foundationdb.map.BunchedMapIterator
- cancel() - Method in class com.apple.foundationdb.map.BunchedMapMultiIterator
- checkActiveSessionExists(Transaction, Subspace) - Static method in class com.apple.foundationdb.synchronizedsession.SynchronizedSession
-
Check if there is any active session on the given lock subspace, so that a new session would not able to be initialized.
- checkConsistency(ReadTransactionContext) - Method in class com.apple.foundationdb.async.RankedSet
- checkLockAsync(Transaction) - Method in class com.apple.foundationdb.synchronizedsession.SynchronizedSession
-
Check if the session still holds the lock.
- ChildSlot - Class in com.apple.foundationdb.async.rtree
-
A child slot that is used by
IntermediateNodes. - clear(Transaction) - Method in class com.apple.foundationdb.async.RangeSet
-
Clears the subspace used by this RangeSet instance.
- clear(TransactionContext) - Method in class com.apple.foundationdb.async.RangeSet
-
Clears the subspace used by this RangeSet instance.
- clear(TransactionContext) - Method in class com.apple.foundationdb.async.RankedSet
-
Clears the entire set.
- CLEAR_RANGE - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Mutation
- CLIENT_INVALID_OPERATION - Enum constant in enum com.apple.foundationdb.FDBError
- CLIENT_LOG_KEY_PREFIX - Static variable in class com.apple.foundationdb.system.SystemKeyspace
- CloseableUtils - Class in com.apple.foundationdb.util
-
Utility methods to help interact with
AutoCloseableclasses. - closeAll(AutoCloseable...) - Static method in class com.apple.foundationdb.util.CloseableUtils
-
A utility to close multiple
AutoCloseableobjects, preserving all the caught exceptions. - CloseException - Exception in com.apple.foundationdb.util
-
Exception thrown when the
CloseableUtils.closeAll(java.lang.AutoCloseable...)method catches an exception. - CloseException(Throwable) - Constructor for exception com.apple.foundationdb.util.CloseException
- closeIterator(Iterator<?>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Close the given iterator, or at least cancel it.
- CLUSTER_FILE_PATH_KEY - Static variable in class com.apple.foundationdb.system.SystemKeyspace
- CLUSTER_VERSION_CHANGED - Enum constant in enum com.apple.foundationdb.FDBError
- code() - Method in enum com.apple.foundationdb.FDBError
- ColumnMajorRealMatrix - Class in com.apple.foundationdb.linear
- ColumnMajorRealMatrix(double[][]) - Constructor for class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- com.apple.foundationdb - package com.apple.foundationdb
-
FDB client code that might conceivably be in the standard Java binding someday.
- com.apple.foundationdb.async - package com.apple.foundationdb.async
-
Utility functions for use within an asynchronous environment.
- com.apple.foundationdb.async.hnsw - package com.apple.foundationdb.async.hnsw
-
Classes and interfaces related to the HNSW implementation as used for vector indexes.
- com.apple.foundationdb.async.rtree - package com.apple.foundationdb.async.rtree
-
Classes and interfaces related to the Hilbert R-tree implementation.
- com.apple.foundationdb.clientlog - package com.apple.foundationdb.clientlog
-
Utilities for interpreting events written to system keyspace.
- com.apple.foundationdb.half - package com.apple.foundationdb.half
-
Package that implements a half precision datatype.
- com.apple.foundationdb.linear - package com.apple.foundationdb.linear
-
Package that implements basic mathematical objects such as vectors and matrices as well as operations on these objects.
- com.apple.foundationdb.map - package com.apple.foundationdb.map
-
A sorted durable associative array with pluggable serialization.
- com.apple.foundationdb.rabitq - package com.apple.foundationdb.rabitq
-
RaBitQ implementation.
- com.apple.foundationdb.synchronizedsession - package com.apple.foundationdb.synchronizedsession
-
Basic classes to support running operations in synchronized sessions.
- com.apple.foundationdb.system - package com.apple.foundationdb.system
-
Utilities for interacting with the system keyspace.
- com.apple.foundationdb.tuple - package com.apple.foundationdb.tuple
-
Utility functions for handling tuples and byte arrays.
- com.apple.foundationdb.util - package com.apple.foundationdb.util
-
Utilities for logging and exception handling.
- combineAndFailFast(CompletableFuture<T>, CompletableFuture<U>, BiFunction<T, U, R>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Combine the results of two futures, but fail fast if either future fails.
- COMMIT_LATENCY - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- COMMIT_READ_INCOMPLETE - Enum constant in enum com.apple.foundationdb.FDBError
- COMMIT_UNKNOWN_RESULT - Enum constant in enum com.apple.foundationdb.FDBError
- CommitRequest(Range[], Range[], FDBClientLogEvents.Mutation[], long, boolean, boolean, FDBClientLogEvents.SpanContext) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.CommitRequest
- compact(TransactionContext, Subspace, int, byte[]) - Method in class com.apple.foundationdb.map.BunchedMap
-
Compact the values within the map into as few keys as possible.
- COMPACT - Enum constant in enum com.apple.foundationdb.async.hnsw.NodeKind
-
Compact node.
- compare(Half, Half) - Static method in class com.apple.foundationdb.half.Half
-
Compares the two specified
Halfobjects. - compare(Tuple, Tuple) - Static method in class com.apple.foundationdb.tuple.TupleHelpers
-
Compare two tuples lexicographically, that is, the same way they would sort when used as keys.
- compareHilbertValueAndKey(BigInteger, Tuple) - Method in class com.apple.foundationdb.async.rtree.ItemSlot
-
Compare this node slot's
(hilbertValue, key)pair with another(hilbertValue, key)pair. - compareHilbertValueKeyPair(BigInteger, Tuple, BigInteger, Tuple) - Static method in interface com.apple.foundationdb.async.rtree.NodeSlot
- compareLargestHilbertValueAndKey(BigInteger, Tuple) - Method in interface com.apple.foundationdb.async.rtree.NodeSlot
-
Compare this node slot's largest
(hilbertValue, key)pair with another(hilbertValue, key)pair. - compareSmallestHilbertValueAndKey(BigInteger, Tuple) - Method in interface com.apple.foundationdb.async.rtree.NodeSlot
-
Compare this node slot's smallest
(hilbertValue, key)pair with another(hilbertValue, key)pair. - compareTo(Half) - Method in class com.apple.foundationdb.half.Half
- composeWhenComplete(CompletableFuture<V>, BiFunction<V, Throwable, CompletableFuture<Void>>, Function<Throwable, RuntimeException>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
This is supposed to replicate the semantics of
CompletionStage.whenComplete(BiConsumer)but to handle the case where the completion handler might itself contain async work. - composeWhenCompleteAndHandle(CompletableFuture<V>, BiFunction<V, Throwable, ? extends CompletableFuture<T>>, Function<Throwable, RuntimeException>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Compose a handler bi-function to the result of a future.
- computeData(int) - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- computeHalfRealVector() - Method in class com.apple.foundationdb.linear.DoubleRealVector
- computeHalfRealVector() - Method in class com.apple.foundationdb.linear.FloatRealVector
- computeHashCode() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- computeNext() - Method in class com.apple.foundationdb.linear.StoredVecsIterator
- computeP() - Method in class com.apple.foundationdb.linear.FhtKacRotator
-
Build dense P as double[n][n] (row-major).
- computeRawData() - Method in class com.apple.foundationdb.linear.AbstractRealVector
-
Computes the raw byte data representation of this object.
- computeRawData() - Method in class com.apple.foundationdb.linear.DoubleRealVector
-
Converts this
RealVectorofdoubleprecision floating-point numbers into a byte array. - computeRawData() - Method in class com.apple.foundationdb.linear.FloatRealVector
-
Converts this
RealVectorof single precision floating-point numbers into a byte array. - computeRawData() - Method in class com.apple.foundationdb.linear.HalfRealVector
-
Converts this
RealVectorofHalfprecision floating-point numbers into a byte array. - computeRawData(int) - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- concatIterables(AsyncIterable<T>...) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Create a new iterable that has the contents of all the parameters in order.
- concatIterables(Executor, AsyncIterable<T>...) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
- config - Variable in class com.apple.foundationdb.async.RankedSet
- Config - Class in com.apple.foundationdb.async.hnsw
-
Configuration settings for a
HNSW. - Config() - Constructor for class com.apple.foundationdb.async.RankedSet.Config
- Config() - Constructor for class com.apple.foundationdb.async.rtree.RTree.Config
- Config(boolean, int, int, int, RTree.Storage, boolean) - Constructor for class com.apple.foundationdb.async.rtree.RTree.Config
- Config(RankedSet.HashFunction, int, boolean) - Constructor for class com.apple.foundationdb.async.RankedSet.Config
- Config.ConfigBuilder - Class in com.apple.foundationdb.async.hnsw
-
Builder for
Config. - ConfigBuilder() - Constructor for class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- ConfigBuilder() - Constructor for class com.apple.foundationdb.async.RankedSet.ConfigBuilder
- ConfigBuilder() - Constructor for class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- ConfigBuilder(boolean, int, int, int, RTree.Storage, boolean) - Constructor for class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- ConfigBuilder(long, Metric, boolean, int, int, int, int, boolean, boolean, double, double, int, boolean, int, int, int) - Constructor for class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- ConfigBuilder(RankedSet.HashFunction, int, boolean) - Constructor for class com.apple.foundationdb.async.RankedSet.ConfigBuilder
- CONNECTION_STR_KEY - Static variable in class com.apple.foundationdb.system.SystemKeyspace
- CONNECTION_STRING_INVALID - Enum constant in enum com.apple.foundationdb.FDBError
- Consistency() - Constructor for class com.apple.foundationdb.async.RankedSet.Consistency
- Consistency(int, long, long, String) - Constructor for class com.apple.foundationdb.async.RankedSet.Consistency
- contains(RTree.Point) - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- contains(ReadTransactionContext, byte[]) - Method in class com.apple.foundationdb.async.RankedSet
-
Checks for the presence of a key in the set.
- contains(TransactionContext, byte[]) - Method in class com.apple.foundationdb.async.RangeSet
-
Determines if a single key is contained within the range set.
- containsIgnoreCase(String, String) - Static method in class com.apple.foundationdb.util.StringUtils
-
Returns whether some substring of
sourcecontainssearchStr, ignoring case. - containsKey(TransactionContext, Subspace, K) - Method in class com.apple.foundationdb.map.BunchedMap
-
Determines whether a key is contained within the map.
- COSINE_METRIC - Enum constant in enum com.apple.foundationdb.linear.Metric
-
Represents the Cosine distance metric, implemented by
MetricDefinition.CosineMetric. - count(ReadTransactionContext, byte[]) - Method in class com.apple.foundationdb.async.RankedSet
-
Count the number of occurrences of a key in the set.
- CRC_HASH - Static variable in class com.apple.foundationdb.async.RankedSet
-
Hash using 32-bit CRC.
D
- DATABASE_LOCKED - Enum constant in enum com.apple.foundationdb.FDBError
- DatabaseClientLogEventCounter - Class in com.apple.foundationdb.clientlog
-
Count tuple-encoded keys into
TupleKeyCountTree. - DatabaseClientLogEventCounter(TupleKeyCountTree, boolean, boolean, boolean, boolean, boolean) - Constructor for class com.apple.foundationdb.clientlog.DatabaseClientLogEventCounter
- DatabaseClientLogEvents - Class in com.apple.foundationdb.clientlog
-
Parse client latency events from system keyspace.
- DatabaseClientLogEvents.EventConsumer - Interface in com.apple.foundationdb.clientlog
-
A callback with the current transaction.
- DatabaseClientLogEvents.EventRunner - Class in com.apple.foundationdb.clientlog
- dcId - Variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Event
- decomposeMatrix(RealMatrix) - Static method in class com.apple.foundationdb.linear.QRDecomposition
-
Decomposes a square matrix A into an orthogonal matrix Q and an upper triangular matrix R, such that A = QR.
- dedupIterable(AsyncIterable<T>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Remove adjacent duplicates form iterable.
- dedupIterable(Executor, AsyncIterable<T>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
- DEFAULT_CONFIG - Static variable in class com.apple.foundationdb.async.RankedSet
- DEFAULT_CONFIG - Static variable in class com.apple.foundationdb.async.rtree.RTree
- DEFAULT_EF_CONSTRUCTION - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_EXTEND_CANDIDATES - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_HASH_FUNCTION - Static variable in class com.apple.foundationdb.async.RankedSet
-
The default hash function to use.
- DEFAULT_KEEP_PRUNED_CONNECTIONS - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_LEVELS - Static variable in class com.apple.foundationdb.async.RankedSet
- DEFAULT_M - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_M_MAX - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_M_MAX_0 - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_MAINTAIN_STATS_PROBABILITY - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_MAX_M - Static variable in class com.apple.foundationdb.async.rtree.RTree
-
The maximum number of slots a node has.
- DEFAULT_MAX_NUM_CONCURRENT_NEIGHBOR_FETCHES - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_MAX_NUM_CONCURRENT_NODE_FETCHES - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_METRIC - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_MIN_M - Static variable in class com.apple.foundationdb.async.rtree.RTree
-
The minimum number of slots a node has (if not the root node).
- DEFAULT_RABITQ_NUM_EX_BITS - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_RANDOM_SEED - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_S - Static variable in class com.apple.foundationdb.async.rtree.RTree
-
The magic split number.
- DEFAULT_SAMPLE_VECTOR_STATS_PROBABILITY - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_STATS_THRESHOLD - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_STORAGE - Static variable in class com.apple.foundationdb.async.rtree.RTree
-
Default storage layout.
- DEFAULT_STORE_HILBERT_VALUES - Static variable in class com.apple.foundationdb.async.rtree.RTree
-
Indicator if Hilbert values should be stored or not with the data (in leaf nodes).
- DEFAULT_USE_INLINING - Static variable in class com.apple.foundationdb.async.hnsw.Config
- DEFAULT_USE_NODE_SLOT_INDEX - Static variable in class com.apple.foundationdb.async.rtree.RTree
-
Indicator if we should maintain a secondary node index consisting of hilbet value and key to speed up update/deletes.
- DEFAULT_USE_RABITQ - Static variable in class com.apple.foundationdb.async.hnsw.Config
- defaultConfig(int) - Static method in class com.apple.foundationdb.async.hnsw.HNSW
-
Returns a default
Config. - delayedFuture(long, TimeUnit) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Creates a future that will be ready after the given delay.
- delayedFuture(long, TimeUnit, ScheduledExecutorService) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Creates a future that will be ready after the given delay.
- delegate - Variable in class com.apple.foundationdb.async.TaskNotifyingExecutor
- delete(TransactionContext, RTree.Point, Tuple) - Method in class com.apple.foundationdb.async.rtree.RTree
-
Method to delete from the R-tree.
- deleteAllSlots(StorageAdapter, int) - Method in interface com.apple.foundationdb.async.rtree.Node
-
Delete all slots from the node.
- deleteSlot(StorageAdapter, int, int) - Method in interface com.apple.foundationdb.async.rtree.Node
-
Delete a slot from the node.
- depth(TransactionContext) - Method in class com.apple.foundationdb.async.rtree.RTree
-
Method to compute the depth of this R-tree.
- DESC_NULLS_FIRST - Enum constant in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
- DESC_NULLS_LAST - Enum constant in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
- deserializeByteArray(ByteBuffer) - Static method in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- deserializeCommit(long, ByteBuffer) - Static method in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- deserializeEntries(Tuple, byte[]) - Method in class com.apple.foundationdb.map.BunchedTupleSerializer
- deserializeEntries(K, byte[]) - Method in interface com.apple.foundationdb.map.BunchedSerializer
-
Deserialize raw data to a list of entries.
- deserializeEvents(ByteBuffer, FDBClientLogEvents.AsyncConsumer<FDBClientLogEvents.Event>) - Static method in class com.apple.foundationdb.clientlog.FDBClientLogEvents
-
Apply a callback to parsed events.
- deserializeKey(byte[]) - Method in interface com.apple.foundationdb.map.BunchedSerializer
-
Deserialize a byte array into a key.
- deserializeKey(byte[], int) - Method in interface com.apple.foundationdb.map.BunchedSerializer
-
Deserialize a slice of a byte array into a key.
- deserializeKey(byte[], int, int) - Method in interface com.apple.foundationdb.map.BunchedSerializer
-
Deserialize a slice of a byte array into a key.
- deserializeKey(byte[], int, int) - Method in class com.apple.foundationdb.map.BunchedTupleSerializer
- deserializeKeys(K, byte[]) - Method in interface com.apple.foundationdb.map.BunchedSerializer
-
Deserialize raw data to a list of keys.
- deserializeMutation(ByteBuffer) - Static method in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- deserializeMutationArray(ByteBuffer) - Static method in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- deserializeRange(ByteBuffer) - Static method in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- deserializeRangeArray(ByteBuffer) - Static method in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- distance(double[], double[]) - Method in enum com.apple.foundationdb.linear.Metric
- distance(RealVector, RealVector) - Method in interface com.apple.foundationdb.linear.Estimator
-
Calculates the distance between a pre-rotated and translated query vector and a stored vector.
- distance(RealVector, RealVector) - Method in enum com.apple.foundationdb.linear.Metric
-
Calculates a distance between two n-dimensional vectors.
- distance(RealVector, RealVector) - Method in class com.apple.foundationdb.rabitq.RaBitEstimator
- distance(Transformed<? extends RealVector>, Transformed<? extends RealVector>) - Method in interface com.apple.foundationdb.linear.Estimator
- dot(RealVector) - Method in interface com.apple.foundationdb.linear.RealVector
- DOT_PRODUCT_METRIC - Enum constant in enum com.apple.foundationdb.linear.Metric
-
Dot product similarity, implemented by
MetricDefinition.DotProductMetric - DOUBLE - Enum constant in enum com.apple.foundationdb.linear.VectorType
- DoubleRealVector - Class in com.apple.foundationdb.linear
-
A vector class encoding a vector over double components.
- DoubleRealVector(double[]) - Constructor for class com.apple.foundationdb.linear.DoubleRealVector
- DoubleRealVector(int[]) - Constructor for class com.apple.foundationdb.linear.DoubleRealVector
- DoubleRealVector(long[]) - Constructor for class com.apple.foundationdb.linear.DoubleRealVector
- DoubleRealVector(Double[]) - Constructor for class com.apple.foundationdb.linear.DoubleRealVector
- doubleValue() - Method in class com.apple.foundationdb.half.Half
E
- EMPTY - Static variable in class com.apple.foundationdb.tuple.TupleHelpers
- encode(RealVector) - Method in interface com.apple.foundationdb.linear.Quantizer
-
Encodes the given data vector into another vector representation.
- encode(RealVector) - Method in class com.apple.foundationdb.rabitq.RaBitQuantizer
-
Encodes a given
RealVectorinto its corresponding encoded representation. - encode(Transformed<RealVector>) - Method in interface com.apple.foundationdb.linear.Quantizer
- EncodedRealVector - Class in com.apple.foundationdb.rabitq
- EncodedRealVector(int, int[], double, double, double) - Constructor for class com.apple.foundationdb.rabitq.EncodedRealVector
- encodedVector - Variable in class com.apple.foundationdb.rabitq.RaBitQuantizer.Result
- endAnySession(Transaction) - Method in class com.apple.foundationdb.synchronizedsession.SynchronizedSession
-
End any active session on the lock subspace by releasing the lock no matter whether this session holds the lock or not.
- endAnySession(Transaction, Subspace) - Static method in class com.apple.foundationdb.synchronizedsession.SynchronizedSession
-
End any active session on the given lock subspace by releasing the lock.
- ENVIRONMENT_VARIABLE_NETWORK_OPTION_FAILED - Enum constant in enum com.apple.foundationdb.FDBError
- equals(Tuple, Tuple) - Static method in class com.apple.foundationdb.tuple.TupleHelpers
-
Determine if two
Tuples have the same contents. - equals(Object) - Method in class com.apple.foundationdb.async.hnsw.Config
- equals(Object) - Method in class com.apple.foundationdb.async.hnsw.NodeReference
-
Compares this
NodeReferenceto the specified object for equality. - equals(Object) - Method in class com.apple.foundationdb.async.hnsw.NodeReferenceWithDistance
-
Compares this object against the specified object for equality.
- equals(Object) - Method in class com.apple.foundationdb.async.hnsw.NodeReferenceWithVector
-
Compares this
NodeReferenceWithVectorto the specified object for equality. - equals(Object) - Method in class com.apple.foundationdb.async.hnsw.ResultEntry
- equals(Object) - Method in class com.apple.foundationdb.async.rtree.RTree.Point
- equals(Object) - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- equals(Object) - Method in class com.apple.foundationdb.half.Half
- equals(Object) - Method in class com.apple.foundationdb.linear.AbstractRealVector
-
Compares this vector to the specified object for equality.
- equals(Object) - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- equals(Object) - Method in class com.apple.foundationdb.linear.FhtKacRotator
- equals(Object) - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- equals(Object) - Method in class com.apple.foundationdb.linear.Transformed
- equals(Object) - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- ERROR_COMMIT - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- ERROR_GET - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- ERROR_GET_RANGE - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- estimateDistanceAndErrorBound(RealVector, EncodedRealVector) - Method in class com.apple.foundationdb.rabitq.RaBitEstimator
- estimator() - Method in interface com.apple.foundationdb.linear.Quantizer
-
Returns the
Estimatorinstance associated with this object. - estimator() - Method in class com.apple.foundationdb.rabitq.RaBitQuantizer
-
Creates and returns a new
RaBitEstimatorinstance. - Estimator - Interface in com.apple.foundationdb.linear
-
Interface of an estimator used for calculating the distance between vectors.
- EUCLIDEAN_METRIC - Enum constant in enum com.apple.foundationdb.linear.Metric
-
Represents the Euclidean distance metric, implemented by
MetricDefinition.EuclideanMetric. - EUCLIDEAN_SQUARE_METRIC - Enum constant in enum com.apple.foundationdb.linear.Metric
-
Represents the squared Euclidean distance metric, implemented by
MetricDefinition.EuclideanSquareMetric. - Event(double, String, String) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.Event
- EVENT_KEY_CHUNK_INDEX - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- EVENT_KEY_ID_END_INDEX - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- EVENT_KEY_ID_START_INDEX - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- EVENT_KEY_VERSION_END_INDEX - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- EventCommit(double, String, String, double, int, int, long, FDBClientLogEvents.CommitRequest) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommit
- EventCommitError(double, String, String, int, FDBClientLogEvents.CommitRequest) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommitError
- EventDeserializer(FDBClientLogEvents.AsyncConsumer<FDBClientLogEvents.Event>) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventDeserializer
- EventGet(double, String, String, double, int, byte[]) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGet
- EventGetError(double, String, String, int, byte[]) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetError
- EventGetRange(double, String, String, double, int, Range) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetRange
- EventGetRangeError(double, String, String, int, Range) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetRangeError
- EventGetVersion(double, String, String, double, int, long) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetVersion
- eventKeyForVersion(long) - Static method in class com.apple.foundationdb.clientlog.FDBClientLogEvents
-
Get the key at which a particular commit version would be recorded.
- EventRunner(Database, Executor, DatabaseClientLogEvents.EventConsumer, DatabaseClientLogEvents, int, long) - Constructor for class com.apple.foundationdb.clientlog.DatabaseClientLogEvents.EventRunner
- EventRunner(Database, Executor, DatabaseClientLogEvents.EventConsumer, Function<ReadTransaction, CompletableFuture<Long[]>>, int, long) - Constructor for class com.apple.foundationdb.clientlog.DatabaseClientLogEvents.EventRunner
- EXACT_MODE_WITHOUT_LIMITS - Enum constant in enum com.apple.foundationdb.FDBError
- execute(Runnable) - Method in class com.apple.foundationdb.async.TaskNotifyingExecutor
- executor - Variable in class com.apple.foundationdb.async.RankedSet
- EXISTING_SESSION - Enum constant in enum com.apple.foundationdb.util.LogMessageKeys
- EXISTING_SESSION_EXPIRE_TIME - Enum constant in enum com.apple.foundationdb.util.LogMessageKeys
- EXP_BIAS - Static variable in class com.apple.foundationdb.half.HalfConstants
-
Bias used in representing a
halfexponent. - EXP_BIT_MASK - Static variable in class com.apple.foundationdb.half.HalfConstants
-
Bit mask to isolate the exponent field of a
half. - exportLogInfo() - Method in exception com.apple.foundationdb.util.LoggableException
-
Export the log information to a flattened array.
- exportLogInfo() - Method in interface com.apple.foundationdb.util.LoggableKeysAndValues
-
Export the log information to a flattened array.
- exportLogInfo() - Method in class com.apple.foundationdb.util.LoggableKeysAndValuesImpl
-
Export the log information to a flattened array.
- EXTERNAL_CLIENT_ALREADY_LOADED - Enum constant in enum com.apple.foundationdb.FDBError
F
- FDBClientLogEvents - Class in com.apple.foundationdb.clientlog
-
Parse client latency events from system keyspace.
- FDBClientLogEvents.AsyncConsumer<T> - Interface in com.apple.foundationdb.clientlog
-
Asynchronous callback.
- FDBClientLogEvents.CommitRequest - Class in com.apple.foundationdb.clientlog
-
Information about a commit, successful or not, in an event.
- FDBClientLogEvents.Event - Class in com.apple.foundationdb.clientlog
-
Base class for parsed events.
- FDBClientLogEvents.EventCommit - Class in com.apple.foundationdb.clientlog
-
A commit latency event.
- FDBClientLogEvents.EventCommitError - Class in com.apple.foundationdb.clientlog
-
A failing commit event.
- FDBClientLogEvents.EventConsumer - Interface in com.apple.foundationdb.clientlog
-
Event callback.
- FDBClientLogEvents.EventDeserializer - Class in com.apple.foundationdb.clientlog
- FDBClientLogEvents.EventGet - Class in com.apple.foundationdb.clientlog
-
A single key get latency event.
- FDBClientLogEvents.EventGetError - Class in com.apple.foundationdb.clientlog
-
A failing single key get event.
- FDBClientLogEvents.EventGetRange - Class in com.apple.foundationdb.clientlog
-
A range get latency event.
- FDBClientLogEvents.EventGetRangeError - Class in com.apple.foundationdb.clientlog
-
A failing range get event.
- FDBClientLogEvents.EventGetVersion - Class in com.apple.foundationdb.clientlog
-
A GRV latency event.
- FDBClientLogEvents.Mutation - Class in com.apple.foundationdb.clientlog
-
A single mutation in a
FDBClientLogEvents.CommitRequest. - FDBClientLogEvents.SpanContext - Class in com.apple.foundationdb.clientlog
- FDBClientLogEvents.Uid - Class in com.apple.foundationdb.clientlog
- FDBError - Enum in com.apple.foundationdb
-
FDB error codes (from https://apple.github.io/foundationdb/api-error-codes.html) and handy methods to interpret them.
- FhtKacRotator - Class in com.apple.foundationdb.linear
-
FhtKac-like random orthogonal rotator which implements
LinearOperator. - FhtKacRotator(long, int, int) - Constructor for class com.apple.foundationdb.linear.FhtKacRotator
- FIELD_NAME - Enum constant in enum com.apple.foundationdb.util.LogMessageKeys
- FILE_NOT_FOUND - Enum constant in enum com.apple.foundationdb.FDBError
- FILE_NOT_READABLE - Enum constant in enum com.apple.foundationdb.FDBError
- FILE_NOT_WRITABLE - Enum constant in enum com.apple.foundationdb.FDBError
- FILE_TOO_LARGE - Enum constant in enum com.apple.foundationdb.FDBError
- filterIterable(AsyncIterable<T>, Function<T, Boolean>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Filter items from an async iterable.
- filterIterable(Executor, AsyncIterable<T>, Function<T, Boolean>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
- filterIterablePipelined(AsyncIterable<T>, Function<T, CompletableFuture<Boolean>>, int) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Filter an iterable, pipelining the asynchronous filter functions.
- filterIterablePipelined(Executor, AsyncIterable<T>, Function<T, CompletableFuture<Boolean>>, int) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
- flipMajor() - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- flipMajor() - Method in interface com.apple.foundationdb.linear.RealMatrix
- flipMajor() - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- FloatRealVector - Class in com.apple.foundationdb.linear
-
A vector class encoding a vector over float components.
- FloatRealVector(double[]) - Constructor for class com.apple.foundationdb.linear.FloatRealVector
- FloatRealVector(float[]) - Constructor for class com.apple.foundationdb.linear.FloatRealVector
- FloatRealVector(int[]) - Constructor for class com.apple.foundationdb.linear.FloatRealVector
- FloatRealVector(long[]) - Constructor for class com.apple.foundationdb.linear.FloatRealVector
- FloatRealVector(Float[]) - Constructor for class com.apple.foundationdb.linear.FloatRealVector
- floatToHalfShortBits(float) - Static method in class com.apple.foundationdb.half.Half
- floatToShortBitsCollapseNaN(float) - Static method in class com.apple.foundationdb.half.Half
-
Returns a representation of the specified floating-point value according to the IEEE 754 floating-point "single format" bit layout.
- floatValue() - Method in class com.apple.foundationdb.half.Half
- forEach(Iterable<T>, Function<T, CompletableFuture<U>>, int, Executor) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Method to iterate over some items, for each of which a body is executed asynchronously.
- forEachEvent(AsyncIterable<KeyValue>, FDBClientLogEvents.EventConsumer) - Static method in class com.apple.foundationdb.clientlog.FDBClientLogEvents
-
Invoke a callback on each event in a range of the key-value store.
- forEachEvent(Database, Executor, DatabaseClientLogEvents.EventConsumer, Function<ReadTransaction, CompletableFuture<Long[]>>, int, long) - Static method in class com.apple.foundationdb.clientlog.DatabaseClientLogEvents
- forEachEventBetweenTimestamps(Database, Executor, DatabaseClientLogEvents.EventConsumer, Instant, Instant, int, long) - Static method in class com.apple.foundationdb.clientlog.DatabaseClientLogEvents
-
Apply a callback to client latency events recorded in the given database between two commit versions.
- forEachEventBetweenVersions(Database, Executor, DatabaseClientLogEvents.EventConsumer, Long, Long, int, long) - Static method in class com.apple.foundationdb.clientlog.DatabaseClientLogEvents
-
Apply a callback to client latency events recorded in the given database between two commit versions.
- forEachEventContinued(Database, Executor, DatabaseClientLogEvents.EventConsumer, int, long) - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEvents
-
Apply a callback to client latency events following an early return due to reaching a limit.
- forLoop(int, U, IntPredicate, IntUnaryOperator, BiFunction<Integer, U, CompletableFuture<U>>, Executor) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Method that provides the functionality of a for loop, however, in an asynchronous way.
- fromBytes(byte[]) - Static method in class com.apple.foundationdb.linear.DoubleRealVector
-
Creates a
DoubleRealVectorfrom a byte array. - fromBytes(byte[]) - Static method in class com.apple.foundationdb.linear.FloatRealVector
-
Creates a
FloatRealVectorfrom a byte array. - fromBytes(byte[]) - Static method in class com.apple.foundationdb.linear.HalfRealVector
-
Creates a
HalfRealVectorfrom a byte array. - fromBytes(byte[], int, int) - Static method in class com.apple.foundationdb.rabitq.EncodedRealVector
- fromCode(int) - Static method in enum com.apple.foundationdb.FDBError
- fromInts(int[]) - Static method in class com.apple.foundationdb.linear.AbstractRealVector
- fromLongs(long[]) - Static method in class com.apple.foundationdb.linear.AbstractRealVector
- fromPoint(RTree.Point) - Static method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- FUTURE_NOT_ERROR - Enum constant in enum com.apple.foundationdb.FDBError
- FUTURE_NOT_SET - Enum constant in enum com.apple.foundationdb.FDBError
- FUTURE_RELEASED - Enum constant in enum com.apple.foundationdb.FDBError
- FUTURE_VERSION - Enum constant in enum com.apple.foundationdb.FDBError
G
- get(TransactionContext, Subspace, K) - Method in class com.apple.foundationdb.map.BunchedMap
-
Retrieves the value associated with a key from the map.
- GET_LATENCY - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- GET_RANGE_LATENCY - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- GET_VERSION_LATENCY - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- getAddEx() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- getArrowIndicator() - Method in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
-
Returns a string that symbolizes the meaning of this enum constant.
- getBunchSize() - Method in class com.apple.foundationdb.map.BunchedMap
-
Get the maximum number of map entries to encode in a single database key.
- getBytes() - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- getCallback() - Method in interface com.apple.foundationdb.async.AsyncPeekCallbackIterator
-
Return the callback that this iterator calls before a new result is returned by
AsyncIterator.next(). - getChangeSet() - Method in interface com.apple.foundationdb.async.rtree.Node
-
Returns the change set that need to be applied in order to correctly persist the node.
- getChildId() - Method in class com.apple.foundationdb.async.rtree.ChildSlot
- getChildren() - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- getColumn(int) - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- getColumnMajorData() - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- getColumnMajorData() - Method in interface com.apple.foundationdb.linear.RealMatrix
- getColumnMajorData() - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- getCommitBytes() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommit
- getCommitRequest() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommit
- getCommitRequest() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommitError
- getComponent(int) - Method in class com.apple.foundationdb.linear.AbstractRealVector
-
Gets the component of this object at the specified dimension.
- getComponent(int) - Method in interface com.apple.foundationdb.linear.RealVector
-
Gets the component of this object at the specified dimension.
- getComponent(int) - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- getConfig() - Method in class com.apple.foundationdb.async.hnsw.HNSW
-
Get this hnsw's configuration.
- getConfig() - Method in class com.apple.foundationdb.async.RankedSet
-
Get this ranked set's configuration.
- getConfig() - Method in class com.apple.foundationdb.async.rtree.RTree
-
Get this r-tree's configuration.
- getContinuation() - Method in class com.apple.foundationdb.map.BunchedMapIterator
-
Returns a continuation that can be passed to future calls of
BunchedMap.scan(). - getContinuation() - Method in class com.apple.foundationdb.map.BunchedMapMultiIterator
-
Returns a continuation that can be passed to future calls of
BunchedMap.scanMulti(). - getCoordinate(int) - Method in class com.apple.foundationdb.async.rtree.RTree.Point
- getCoordinateAsNumber(int) - Method in class com.apple.foundationdb.async.rtree.RTree.Point
- getCoordinates() - Method in class com.apple.foundationdb.async.rtree.RTree.Point
- getCount() - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- getData() - Method in class com.apple.foundationdb.linear.AbstractRealVector
-
Returns the underlying data array.
- getData() - Method in interface com.apple.foundationdb.linear.RealVector
-
Returns the underlying data array.
- getData() - Method in exception com.apple.foundationdb.map.BunchedSerializationException
-
Return the raw bytes that triggered this exception.
- getData() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- getDcId() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Event
- getDefaultScheduledExecutor() - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Get the default scheduled executor service.
- getDistance() - Method in class com.apple.foundationdb.async.hnsw.NodeReferenceWithDistance
-
Gets the distance.
- getDistance() - Method in class com.apple.foundationdb.async.hnsw.ResultEntry
- getDistance() - Method in class com.apple.foundationdb.rabitq.RaBitEstimator.Result
- getEarliestTimestamp() - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEvents
- getEfConstruction() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getEfConstruction() - Method in class com.apple.foundationdb.async.hnsw.Config
- getEncodedComponent(int) - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- getEncodedData() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- getEncodedVector() - Method in class com.apple.foundationdb.rabitq.RaBitQuantizer.Result
- getEntry(int, int) - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- getEntry(int, int) - Method in interface com.apple.foundationdb.linear.RealMatrix
- getEntry(int, int) - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- getErr() - Method in class com.apple.foundationdb.rabitq.RaBitEstimator.Result
- getErrorCode() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommitError
- getErrorCode() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetError
- getErrorCode() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetRangeError
- getErrorEx() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- getEventCount() - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEvents
- getExecutor() - Method in class com.apple.foundationdb.async.hnsw.HNSW
-
Get the executor used by this hnsw.
- getExecutor() - Method in class com.apple.foundationdb.async.RankedSet
-
Get executed used by this ranked set.
- getExecutor() - Method in class com.apple.foundationdb.async.rtree.RTree
-
Get the executer used by this r-tree.
- getExponent(Half) - Static method in class com.apple.foundationdb.half.HalfMath
-
Returns the unbiased exponent used in the representation of a
half. - getFlags() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.SpanContext
- getHashFunction() - Method in class com.apple.foundationdb.async.RankedSet.Config
-
Get the hash function to use.
- getHashFunction() - Method in class com.apple.foundationdb.async.RankedSet.ConfigBuilder
- getHigh(int) - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- getHilbertValue() - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- getId() - Method in interface com.apple.foundationdb.async.rtree.Node
-
Return the id of this node.
- getIpNormInv() - Method in class com.apple.foundationdb.rabitq.RaBitQuantizer.Result
- getKey() - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- getKey() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGet
- getKey() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetError
- getKey() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Mutation
- getKey() - Method in class com.apple.foundationdb.map.BunchedMapScanEntry
-
Returns the key from this entry.
- getKeyComparator() - Method in class com.apple.foundationdb.map.BunchedMap
-
Get the comparator used to order keys of the map.
- getKeyHash(byte[]) - Method in class com.apple.foundationdb.async.RankedSet
- getKeySuffix() - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- getKind() - Method in interface com.apple.foundationdb.async.hnsw.Node
-
Return the kind of the node, i.e.
- getKind() - Method in interface com.apple.foundationdb.async.rtree.Node
-
Return the kind of the node, i.e.
- getLargestHilbertValue() - Method in class com.apple.foundationdb.async.rtree.ChildSlot
- getLargestHilbertValue() - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- getLargestHilbertValue() - Method in interface com.apple.foundationdb.async.rtree.NodeSlot
- getLargestKey() - Method in class com.apple.foundationdb.async.rtree.ChildSlot
- getLargestKey() - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- getLargestKey() - Method in interface com.apple.foundationdb.async.rtree.NodeSlot
- getLargestKeySuffix() - Method in interface com.apple.foundationdb.async.rtree.NodeSlot
- getLastProcessedKey() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventDeserializer
-
Get the last key fully processed.
- getLatency() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommit
- getLatency() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGet
- getLatency() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetRange
- getLatency() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetVersion
- getLatestTimestamp() - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEvents
- getLevel() - Method in class com.apple.foundationdb.async.rtree.AbstractChangeSet
-
The level we should use when maintaining the node slot index.
- getLimit() - Method in class com.apple.foundationdb.map.BunchedMapIterator
-
Get the limit from the iterator.
- getLimit() - Method in class com.apple.foundationdb.map.BunchedMapMultiIterator
-
Returns the maximum number of entries that this iterator will return.
- getLogInfo() - Method in exception com.apple.foundationdb.util.LoggableException
-
Get the log information associated with this exception as a map.
- getLogInfo() - Method in interface com.apple.foundationdb.util.LoggableKeysAndValues
-
Get the log information associated with object as a map.
- getLogInfo() - Method in class com.apple.foundationdb.util.LoggableKeysAndValuesImpl
-
Get the log information associated with this exception as a map.
- getLow(int) - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- getM() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getM() - Method in class com.apple.foundationdb.async.hnsw.Config
- getMaintainStatsProbability() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getMaintainStatsProbability() - Method in class com.apple.foundationdb.async.hnsw.Config
- getMaxM() - Method in class com.apple.foundationdb.async.rtree.RTree.Config
- getMaxM() - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- getMaxNumConcurrentNeighborhoodFetches() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getMaxNumConcurrentNeighborhoodFetches() - Method in class com.apple.foundationdb.async.hnsw.Config
- getMaxNumConcurrentNodeFetches() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getMaxNumConcurrentNodeFetches() - Method in class com.apple.foundationdb.async.hnsw.Config
- getMbr() - Method in class com.apple.foundationdb.async.rtree.ChildSlot
- getMetric() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getMetric() - Method in class com.apple.foundationdb.async.hnsw.Config
- getMetric() - Method in class com.apple.foundationdb.rabitq.RaBitEstimator
- getMinM() - Method in class com.apple.foundationdb.async.rtree.RTree.Config
- getMinM() - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- getMMax() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getMMax() - Method in class com.apple.foundationdb.async.hnsw.Config
- getMMax0() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getMMax0() - Method in class com.apple.foundationdb.async.hnsw.Config
- getMutations() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.CommitRequest
- getNeighbors() - Method in interface com.apple.foundationdb.async.hnsw.Node
-
Gets the list of neighboring nodes.
- getNLevels() - Method in class com.apple.foundationdb.async.RankedSet.Config
-
Get the number of levels to use.
- getNLevels() - Method in class com.apple.foundationdb.async.RankedSet.ConfigBuilder
- getNode() - Method in class com.apple.foundationdb.async.rtree.AbstractChangeSet
-
The node this change set applies to.
- getNth(ReadTransactionContext, long) - Method in class com.apple.foundationdb.async.RankedSet
-
Return the Nth item in the set.
- getNumColumnDimensions() - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- getNumColumnDimensions() - Method in class com.apple.foundationdb.linear.FhtKacRotator
- getNumColumnDimensions() - Method in interface com.apple.foundationdb.linear.LinearOperator
- getNumColumnDimensions() - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- getNumDimensions() - Method in class com.apple.foundationdb.async.hnsw.Config
- getNumDimensions() - Method in class com.apple.foundationdb.async.rtree.RTree.Point
- getNumDimensions() - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- getNumDimensions() - Method in class com.apple.foundationdb.linear.AbstractRealVector
-
Returns the number of elements in the vector.
- getNumDimensions() - Method in class com.apple.foundationdb.linear.AffineOperator
- getNumDimensions() - Method in interface com.apple.foundationdb.linear.LinearOperator
- getNumDimensions() - Method in interface com.apple.foundationdb.linear.RealVector
-
Returns the number of elements in the vector, i.e.
- getNumDimensions() - Method in interface com.apple.foundationdb.linear.VectorOperator
-
Returns the numbers of dimensions a vector must have to be able to be applied or apply-inverted.
- getNumDimensions() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- getNumExBits() - Method in class com.apple.foundationdb.rabitq.RaBitEstimator
- getNumMutations() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommit
- getNumRowDimensions() - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- getNumRowDimensions() - Method in class com.apple.foundationdb.linear.FhtKacRotator
- getNumRowDimensions() - Method in interface com.apple.foundationdb.linear.LinearOperator
- getNumRowDimensions() - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- getObject() - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- getOnReadListener() - Method in class com.apple.foundationdb.async.hnsw.HNSW
-
Get the on-read listener.
- getOnReadListener() - Method in class com.apple.foundationdb.async.rtree.RTree
-
Get the on-read listener.
- getOnWriteListener() - Method in class com.apple.foundationdb.async.hnsw.HNSW
-
Get the on-write listener.
- getOnWriteListener() - Method in class com.apple.foundationdb.async.rtree.RTree
-
Get the on-write listener.
- getParam() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Mutation
- getParent() - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- getParentNode() - Method in interface com.apple.foundationdb.async.rtree.Node
-
Return the parent of this node.
- getPosition() - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- getPreviousChangeSet() - Method in class com.apple.foundationdb.async.rtree.AbstractChangeSet
-
Previous change set in the chain of change sets.
- getPrimaryKey() - Method in interface com.apple.foundationdb.async.hnsw.Node
-
Gets the primary key for this object.
- getPrimaryKey() - Method in class com.apple.foundationdb.async.hnsw.NodeReference
-
Gets the primary key for this object.
- getPrimaryKey() - Method in class com.apple.foundationdb.async.hnsw.ResultEntry
- getPriority() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetVersion
- getRaBitQNumExBits() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getRaBitQNumExBits() - Method in class com.apple.foundationdb.async.hnsw.Config
- getRandomSeed() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getRandomSeed() - Method in class com.apple.foundationdb.async.hnsw.Config
- getRange() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetRange
- getRange() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetRangeError
- getRange(ReadTransaction, byte[], byte[]) - Method in class com.apple.foundationdb.async.RankedSet
- getRangeList(ReadTransactionContext, byte[], byte[]) - Method in class com.apple.foundationdb.async.RankedSet
-
Returns the ordered set of keys in a given range.
- getRanges() - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- getRankOrRowNumber() - Method in class com.apple.foundationdb.async.hnsw.ResultEntry
- getRawData() - Method in class com.apple.foundationdb.linear.AbstractRealVector
-
Gets the raw byte data representation of this object.
- getRawData() - Method in interface com.apple.foundationdb.linear.RealVector
-
Gets the raw byte data representation of this object.
- getRawData() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- getReadConflictRanges() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.CommitRequest
- getReadVersion() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetVersion
- getRescaleEx() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- getRow(int) - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- getRowMajorData() - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- getRowMajorData() - Method in interface com.apple.foundationdb.linear.RealMatrix
- getRowMajorData() - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- getSampleVectorStatsProbability() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getSampleVectorStatsProbability() - Method in class com.apple.foundationdb.async.hnsw.Config
- getSelfReference(Transformed<RealVector>) - Method in interface com.apple.foundationdb.async.hnsw.Node
-
Returns a self-reference to this object, enabling fluent method chaining.
- getSerialized() - Method in enum com.apple.foundationdb.async.hnsw.NodeKind
-
Gets the serialized byte value.
- getSerialized() - Method in enum com.apple.foundationdb.async.rtree.NodeKind
- getSerializer() - Method in class com.apple.foundationdb.map.BunchedMap
-
Get the serializer used to encode keys and values.
- getSessionId() - Method in class com.apple.foundationdb.synchronizedsession.SynchronizedSession
-
Get session ID.
- getSize() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGet
- getSize() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetRange
- getSlot(int) - Method in interface com.apple.foundationdb.async.rtree.Node
-
Return the
NodeSlotat the position indicated byindex. - getSlotIndexInParent() - Method in interface com.apple.foundationdb.async.rtree.Node
- getSlotInParent() - Method in interface com.apple.foundationdb.async.rtree.Node
-
Return the
ChildSlotof this node in this node's parent node. - getSlotKey(boolean) - Method in class com.apple.foundationdb.async.rtree.ChildSlot
- getSlotKey(boolean) - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- getSlotKey(boolean) - Method in interface com.apple.foundationdb.async.rtree.NodeSlot
-
Create a tuple for the key part of this slot.
- getSlots() - Method in interface com.apple.foundationdb.async.rtree.Node
-
Return an iterable of all node slots.
- getSlots(int, int) - Method in interface com.apple.foundationdb.async.rtree.Node
-
Return an iterable of a sub range of node slots.
- getSlotValue() - Method in class com.apple.foundationdb.async.rtree.ChildSlot
- getSlotValue() - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- getSlotValue() - Method in interface com.apple.foundationdb.async.rtree.NodeSlot
-
Create a tuple for the value part of this slot.
- getSmallestHilbertValue() - Method in class com.apple.foundationdb.async.rtree.ChildSlot
- getSmallestHilbertValue() - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- getSmallestHilbertValue() - Method in interface com.apple.foundationdb.async.rtree.NodeSlot
- getSmallestKey() - Method in class com.apple.foundationdb.async.rtree.ChildSlot
- getSmallestKey() - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- getSmallestKey() - Method in interface com.apple.foundationdb.async.rtree.NodeSlot
- getSmallestKeySuffix() - Method in interface com.apple.foundationdb.async.rtree.NodeSlot
- getSnapshotVersion() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.CommitRequest
- getSpanContext() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.CommitRequest
- getSpanID() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.SpanContext
- getSplitS() - Method in class com.apple.foundationdb.async.rtree.RTree.Config
- getSplitS() - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- getStartTimestamp() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Event
- getStartTimestampDouble() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Event
- getStartTimestampString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Event
-
Get start timestamp formatted for the local time zone.
- getStatsThreshold() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- getStatsThreshold() - Method in class com.apple.foundationdb.async.hnsw.Config
- getStorage() - Method in class com.apple.foundationdb.async.rtree.RTree.Config
- getStorage() - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- getSubspace() - Method in class com.apple.foundationdb.async.hnsw.HNSW
-
Gets the subspace associated with this object.
- getSubspace() - Method in class com.apple.foundationdb.async.RankedSet
-
Get the subspace used to store this ranked set.
- getSubspace() - Method in class com.apple.foundationdb.map.BunchedMapScanEntry
-
Returns the subspace containing this entry.
- getSubspaceTag() - Method in class com.apple.foundationdb.map.BunchedMapScanEntry
-
Returns the tag associated with the subspace containing this entry.
- getT() - Method in class com.apple.foundationdb.rabitq.RaBitQuantizer.Result
- getTenant() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Event
- getTraceID() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.SpanContext
- getType() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Event
- getType() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommit
- getType() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommitError
- getType() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGet
- getType() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetError
- getType() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetRange
- getType() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetRangeError
- getType() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetVersion
- getType() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Mutation
- getUnderlyingVector() - Method in class com.apple.foundationdb.linear.Transformed
- getValue() - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- getValue() - Method in class com.apple.foundationdb.map.BunchedMapScanEntry
-
Returns the value from this entry.
- getValue() - Method in exception com.apple.foundationdb.map.BunchedSerializationException
-
Return the value that triggered this exception if set.
- getVector() - Method in class com.apple.foundationdb.async.hnsw.NodeReferenceWithVector
-
Gets the vector of
Halfobjects. - getVector() - Method in class com.apple.foundationdb.async.hnsw.ResultEntry
- getWithDeadline(long, Supplier<CompletableFuture<T>>, ScheduledExecutorService) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Get a completable future that will either complete within the specified deadline time or complete exceptionally with
MoreAsyncUtil.DeadlineExceededException. - getWriteConflictRanges() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.CommitRequest
H
- Half - Class in com.apple.foundationdb.half
-
The
Halfclass implements half precision (FP16) float-point number according to IEEE 754 standard. - HALF - Enum constant in enum com.apple.foundationdb.linear.VectorType
- HalfConstants - Class in com.apple.foundationdb.half
-
This class contains additional constants documenting limits of
Half. - HalfMath - Class in com.apple.foundationdb.half
-
The class
HalfMathcontains methods for performing basic numeric operations on or usingHalfobjects. - HalfRealVector - Class in com.apple.foundationdb.linear
-
A vector class encoding a vector over half components.
- HalfRealVector(double[]) - Constructor for class com.apple.foundationdb.linear.HalfRealVector
- HalfRealVector(int[]) - Constructor for class com.apple.foundationdb.linear.HalfRealVector
- HalfRealVector(long[]) - Constructor for class com.apple.foundationdb.linear.HalfRealVector
- HalfRealVector(Half[]) - Constructor for class com.apple.foundationdb.linear.HalfRealVector
- halfShortToFloat(short) - Static method in class com.apple.foundationdb.half.Half
- halfToRawShortBits(Half) - Static method in class com.apple.foundationdb.half.Half
-
Returns a representation of the specified floating-point value according to the IEEE 754 floating-point "single format" bit layout, preserving Not-a-Number (NaN) values.
- halfToShortBits(Half) - Static method in class com.apple.foundationdb.half.Half
-
Returns a representation of the specified floating-point value according to the IEEE 754 floating-point "single format" bit layout.
- handleOnException(Supplier<CompletableFuture<V>>, Function<Throwable, CompletableFuture<V>>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Handle when
futureSupplierencounters an exception when supplying a future, or the future is completed exceptionally. - hasCommonPrefix(byte[], byte[], int) - Static method in class com.apple.foundationdb.tuple.ByteArrayUtil2
-
Return whether
bytes1andbytes2each begin with a common prefix with a size of at leastprefixSize. - hash(byte[]) - Method in interface com.apple.foundationdb.async.RankedSet.HashFunction
- hashCode() - Method in class com.apple.foundationdb.async.hnsw.Config
- hashCode() - Method in class com.apple.foundationdb.async.hnsw.NodeReference
-
Generates a hash code for this object based on the primary key.
- hashCode() - Method in class com.apple.foundationdb.async.hnsw.NodeReferenceWithDistance
-
Generates a hash code for this object.
- hashCode() - Method in class com.apple.foundationdb.async.hnsw.NodeReferenceWithVector
-
Computes the hash code for this object.
- hashCode() - Method in class com.apple.foundationdb.async.hnsw.ResultEntry
- hashCode() - Method in class com.apple.foundationdb.async.rtree.RTree.Point
- hashCode() - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- hashCode() - Method in class com.apple.foundationdb.half.Half
-
Returns a hash code for this
Halfobject. - hashCode() - Method in class com.apple.foundationdb.linear.AbstractRealVector
-
Returns a hash code value for this object.
- hashCode() - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- hashCode() - Method in class com.apple.foundationdb.linear.FhtKacRotator
- hashCode() - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- hashCode() - Method in class com.apple.foundationdb.linear.Transformed
- hashCode() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- hashCode(Half) - Static method in class com.apple.foundationdb.half.Half
-
Returns a hash code for a
Half; compatible withHalf.hashCode(). - hashCodeSupplier - Variable in class com.apple.foundationdb.linear.AbstractRealVector
- hasMore() - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEvents
- hasNext() - Method in class com.apple.foundationdb.async.rtree.RTree.ItemSlotIterator
- hasNext() - Method in class com.apple.foundationdb.map.BunchedMapIterator
- hasNext() - Method in class com.apple.foundationdb.map.BunchedMapMultiIterator
- hasObject() - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- hideLessThanFraction(double) - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
-
Hide tree nodes that do not have counts at least as great as the given fraction of their parent node.
- hilbertValue(RTree.Point) - Static method in class com.apple.foundationdb.async.rtree.RTreeHilbertCurveHelpers
- HNSW - Class in com.apple.foundationdb.async.hnsw
-
An implementation of the Hierarchical Navigable Small World (HNSW) algorithm for efficient approximate nearest neighbor (ANN) search.
- HNSW(Subspace, Executor, Config, OnWriteListener, OnReadListener) - Constructor for class com.apple.foundationdb.async.hnsw.HNSW
-
Constructs a new HNSW graph instance.
- Holder(T) - Constructor for class com.apple.foundationdb.async.MoreAsyncUtil.Holder
I
- identity() - Static method in class com.apple.foundationdb.linear.AffineOperator
- INCOMPATIBLE_PROTOCOL_VERSION - Enum constant in enum com.apple.foundationdb.FDBError
- INDEX_FIELDS - Enum constant in enum com.apple.foundationdb.util.LogMessageKeys
- init(TransactionContext) - Method in class com.apple.foundationdb.async.RankedSet
- initializeSessionAsync(Transaction) - Method in class com.apple.foundationdb.synchronizedsession.SynchronizedSession
-
Initialize the session by acquiring the lock.
- initNeeded(ReadTransactionContext) - Method in class com.apple.foundationdb.async.RankedSet
-
Determine whether
RankedSet.init(com.apple.foundationdb.TransactionContext)needs to be called. - INLINING - Enum constant in enum com.apple.foundationdb.async.hnsw.NodeKind
-
Inlining node.
- insert(Transaction, Tuple, RealVector) - Method in class com.apple.foundationdb.async.hnsw.HNSW
-
Inserts a new vector with its associated primary key into the HNSW graph.
- insertOrUpdate(TransactionContext, RTree.Point, Tuple, Tuple) - Method in class com.apple.foundationdb.async.rtree.RTree
-
Method to insert an object/item into the R-tree.
- insertRange(TransactionContext, byte[], byte[]) - Method in class com.apple.foundationdb.async.RangeSet
-
Inserts a range into the set.
- insertRange(TransactionContext, byte[], byte[], boolean) - Method in class com.apple.foundationdb.async.RangeSet
-
Inserts a range into the set.
- insertRange(TransactionContext, Range) - Method in class com.apple.foundationdb.async.RangeSet
-
Inserts a range into the set.
- insertRange(TransactionContext, Range, boolean) - Method in class com.apple.foundationdb.async.RangeSet
-
Inserts a range into the set.
- insertSlot(StorageAdapter, int, int, NodeSlot) - Method in interface com.apple.foundationdb.async.rtree.Node
-
Insert a new slot into the node.
- instance() - Static method in class com.apple.foundationdb.map.BunchedTupleSerializer
-
Get the serializer singleton.
- instrumentDelete(byte[], byte[]) - Method in class com.apple.foundationdb.map.BunchedMap
-
Instrument a delete.
- instrumentRangeRead(CompletableFuture<List<KeyValue>>) - Method in class com.apple.foundationdb.map.BunchedMap
-
Instrument a range read.
- instrumentWrite(byte[], byte[], byte[]) - Method in class com.apple.foundationdb.map.BunchedMap
-
Instrument a write.
- INTERMEDIATE - Enum constant in enum com.apple.foundationdb.async.rtree.NodeKind
- INTERNAL_ERROR - Enum constant in enum com.apple.foundationdb.FDBError
- intValue() - Method in class com.apple.foundationdb.half.Half
- INVALID_DATABASE_NAME - Enum constant in enum com.apple.foundationdb.FDBError
- INVALID_LOCAL_ADDRESS - Enum constant in enum com.apple.foundationdb.FDBError
- INVALID_MUTATION_TYPE - Enum constant in enum com.apple.foundationdb.FDBError
- INVALID_OPTION - Enum constant in enum com.apple.foundationdb.FDBError
- INVALID_OPTION_VALUE - Enum constant in enum com.apple.foundationdb.FDBError
- INVERTED_RANGE - Enum constant in enum com.apple.foundationdb.FDBError
- invertedApply(RealVector) - Method in class com.apple.foundationdb.linear.AffineOperator
- invertedApply(RealVector) - Method in interface com.apple.foundationdb.linear.LinearOperator
- invertedApply(RealVector) - Method in interface com.apple.foundationdb.linear.VectorOperator
-
Apply the inverted operator to the vector passed in.
- IO_ERROR - Enum constant in enum com.apple.foundationdb.FDBError
- ipNormInv - Variable in class com.apple.foundationdb.rabitq.RaBitQuantizer.Result
- isAscending() - Method in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
-
Get whether values are ordered ascending.
- isCompletedNormally(CompletableFuture<?>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Returns whether the given
CompletableFuturehas completed normally, i.e., not exceptionally. - isConsistent() - Method in class com.apple.foundationdb.async.RankedSet.Consistency
- isCountDuplicates() - Method in class com.apple.foundationdb.async.RankedSet.Config
-
Get whether duplicate entries increase ranks below them.
- isCountDuplicates() - Method in class com.apple.foundationdb.async.RankedSet.ConfigBuilder
- isCounterflowNulls() - Method in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
-
Get whether
nullvalues sort at the opposite end as in the defaultTuplepacking. - isDescending() - Method in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
-
Get whether values are ordered descending.
- isEmpty() - Method in interface com.apple.foundationdb.async.rtree.Node
-
Return if this node does not hold any slots.
- isEmpty(ReadTransaction) - Method in class com.apple.foundationdb.async.RangeSet
-
Determine whether this range set is empty.
- isEmpty(ReadTransactionContext) - Method in class com.apple.foundationdb.async.RangeSet
-
Determine whether this range set is empty.
- isExtendCandidates() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- isExtendCandidates() - Method in class com.apple.foundationdb.async.hnsw.Config
- isFinalKey(byte[]) - Static method in class com.apple.foundationdb.async.RangeSet
- isFinite() - Method in class com.apple.foundationdb.half.Half
-
Returns
trueif the argument is a finite floating-point value; returnsfalseotherwise (for NaN and infinity arguments). - isFinite(Half) - Static method in class com.apple.foundationdb.half.Half
-
Returns
trueif the argument is a finite floating-point value; returnsfalseotherwise (for NaN and infinity arguments). - isFirstKey(byte[]) - Static method in class com.apple.foundationdb.async.RangeSet
- isInfinite() - Method in class com.apple.foundationdb.half.Half
-
Returns
trueif thisHalfvalue is infinitely large in magnitude,falseotherwise. - isInfinite(Half) - Static method in class com.apple.foundationdb.half.Half
-
Returns
trueif the specifiedHalfis infinitely large in magnitude,falseotherwise. - isInverted() - Method in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
-
Get whether the byte ordering is inverted, that is, the opposite of the default unordered byte comparison of packed
Tuples. - isKeepPrunedConnections() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- isKeepPrunedConnections() - Method in class com.apple.foundationdb.async.hnsw.Config
- isLockAware() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.CommitRequest
- isNaN() - Method in class com.apple.foundationdb.half.Half
-
Returns
trueif thisHalfvalue is a Not-a-Number (NaN),falseotherwise. - isNaN(Half) - Static method in class com.apple.foundationdb.half.Half
-
Returns
trueif the specified number is a Not-a-Number (NaN) value,falseotherwise. - isNullsFirst() - Method in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
-
Get whether null values come earlier.
- isNullsLast() - Method in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
-
Get whether null values come later.
- isNumeric(String) - Static method in class com.apple.foundationdb.util.StringUtils
-
Whether the string is a non-empty string containing only numeric characters.
- isNumeric(String, int) - Static method in class com.apple.foundationdb.util.StringUtils
-
Whether the substring beginning at
beginIndexis non-empty and contains only numeric characters. - isNumeric(String, int, int) - Static method in class com.apple.foundationdb.util.StringUtils
-
Whether the substring from
beginIndextoendIndexis non-empty and contains only numeric characters. - isOverlapping(RTree.Rectangle) - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- isPrefix(Tuple, Tuple) - Static method in class com.apple.foundationdb.tuple.TupleHelpers
-
Get whether one tuple is a prefix of another.
- isReportConflictingKeys() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.CommitRequest
- isReverse() - Method in class com.apple.foundationdb.map.BunchedMapIterator
-
Returns whether this iterator returns keys in reverse order.
- isReverse() - Method in class com.apple.foundationdb.map.BunchedMapMultiIterator
-
Returns whether this iterator returns keys in reverse order.
- isRoot() - Method in interface com.apple.foundationdb.async.rtree.Node
-
Returns if this node is the root node.
- isSquare() - Method in interface com.apple.foundationdb.linear.LinearOperator
- isStoreHilbertValues() - Method in class com.apple.foundationdb.async.rtree.RTree.Config
- isStoreHilbertValues() - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- isTransposable() - Method in class com.apple.foundationdb.linear.FhtKacRotator
- isTransposable() - Method in interface com.apple.foundationdb.linear.LinearOperator
- isTransposable() - Method in interface com.apple.foundationdb.linear.RealMatrix
- isTrueMetric() - Method in enum com.apple.foundationdb.linear.Metric
-
Convenience method that returns if all properties of a metric required to be a true metric are satisfied.
- isUpdateNodeSlotIndex() - Method in class com.apple.foundationdb.async.rtree.AbstractChangeSet
-
Returns whether this change set needs to also update the node slot index.
- isUseInlining() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- isUseInlining() - Method in class com.apple.foundationdb.async.hnsw.Config
- isUseNodeSlotIndex() - Method in class com.apple.foundationdb.async.rtree.RTree.Config
- isUseNodeSlotIndex() - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- isUseRaBitQ() - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- isUseRaBitQ() - Method in class com.apple.foundationdb.async.hnsw.Config
- isVisible() - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- ItemSlot - Class in com.apple.foundationdb.async.rtree
-
An item slot that is used by
LeafNodes. - ItemSlot(BigInteger, RTree.Point, Tuple, Tuple) - Constructor for class com.apple.foundationdb.async.rtree.ItemSlot
J
- JDK_ARRAY_HASH - Static variable in class com.apple.foundationdb.async.RankedSet
-
Hash using the JDK's default byte array hash.
K
- KEY_OUTSIDE_LEGAL_RANGE - Enum constant in enum com.apple.foundationdb.FDBError
- KEY_TOO_LARGE - Enum constant in enum com.apple.foundationdb.FDBError
- kNearestNeighborsSearch(ReadTransaction, int, int, boolean, RealVector) - Method in class com.apple.foundationdb.async.hnsw.HNSW
-
Performs a k-nearest neighbors (k-NN) search for a given query vector.
L
- l2Norm() - Method in interface com.apple.foundationdb.linear.RealVector
- LARGE_ALLOC_FAILED - Enum constant in enum com.apple.foundationdb.FDBError
- lastVersionBefore(ReadTransaction, Instant) - Static method in class com.apple.foundationdb.clientlog.VersionFromTimestamp
-
Get the last version from the timekeeper at or before the given timestamp.
- LEAF - Enum constant in enum com.apple.foundationdb.async.rtree.NodeKind
- limitIterable(AsyncIterable<T>, int) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
- LinearOperator - Interface in com.apple.foundationdb.linear
- linkToParent(IntermediateNode, int) - Method in interface com.apple.foundationdb.async.rtree.Node
-
Link this node to its parent node.
- loggable(byte[]) - Static method in class com.apple.foundationdb.tuple.ByteArrayUtil2
-
Creates a human-readable representation of
bytesfor logging purposes. - LoggableException - Exception in com.apple.foundationdb.util
-
Exception type with support for adding keys and values to its log info.
- LoggableException(String) - Constructor for exception com.apple.foundationdb.util.LoggableException
- LoggableException(String, Object...) - Constructor for exception com.apple.foundationdb.util.LoggableException
-
Create an exception with the given message a the sequence of key-value pairs.
- LoggableException(String, Throwable) - Constructor for exception com.apple.foundationdb.util.LoggableException
- LoggableException(String, Throwable, boolean, boolean) - Constructor for exception com.apple.foundationdb.util.LoggableException
- LoggableException(Throwable) - Constructor for exception com.apple.foundationdb.util.LoggableException
- LoggableKeysAndValues<T extends LoggableKeysAndValues<T>> - Interface in com.apple.foundationdb.util
-
Associates loggable information with an object as a map.
- LoggableKeysAndValuesImpl - Class in com.apple.foundationdb.util
-
Provides a default implementation of
LoggableKeysAndValues. - LoggableKeysAndValuesImpl(Object...) - Constructor for class com.apple.foundationdb.util.LoggableKeysAndValuesImpl
-
Create an instance with the given message and a sequence of key-value pairs.
- LogMessageKeys - Enum in com.apple.foundationdb.util
-
Common
LoggableExceptionkeys logged by the FoundationDB extensions library. - longValue() - Method in class com.apple.foundationdb.half.Half
- lookupIterator(AsyncIterable<T>) - Method in class com.apple.foundationdb.async.RankedSet
M
- MANHATTAN_METRIC - Enum constant in enum com.apple.foundationdb.linear.Metric
-
Represents the Manhattan distance metric, implemented by
MetricDefinition.ManhattanMetric. - mapConcatIterable(AsyncIterable<T1>, Function<T1, AsyncIterable<T2>>, int) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Maps each value in an iterable to a new iterable and returns the concatenated results.
- mapConcatIterable(Executor, AsyncIterable<T1>, Function<T1, AsyncIterable<T2>>, int) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
- mapIterablePipelined(AsyncIterable<T1>, Function<T1, CompletableFuture<T2>>, int) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Maps an AsyncIterable using an asynchronous mapping function.
- MatrixHelpers - Class in com.apple.foundationdb.linear
- max(Half, Half) - Static method in class com.apple.foundationdb.half.Half
-
Returns the greater of two
Halfobjects.
Determined usingaFloatValue = a.floatValue()andbFloatValue = b.floatValue()then callingFloat.max(aFloatValue, bFloatValue). - MAX_CONCURRENT_READS - Static variable in class com.apple.foundationdb.async.rtree.RTree
- MAX_EXPONENT - Static variable in class com.apple.foundationdb.half.Half
-
Maximum exponent a finite
Halfvariable may have. - MAX_LEVELS - Static variable in class com.apple.foundationdb.async.RankedSet
- MAX_VALUE - Static variable in class com.apple.foundationdb.half.Half
-
A constant holding the largest positive finite value of type
Half, (2-2-10)·215. - METADATA_VERSION_KEY - Static variable in class com.apple.foundationdb.system.SystemKeyspace
- Metric - Enum in com.apple.foundationdb.linear
-
Represents various distance calculation strategies (metrics) for vectors.
- min(Half, Half) - Static method in class com.apple.foundationdb.half.Half
-
Returns the smaller of two
Halfobjects.
Determined usingaFloatValue = a.floatValue()andbFloatValue = b.floatValue()then callingFloat.min(aFloatValue, bFloatValue). - MIN_EXPONENT - Static variable in class com.apple.foundationdb.half.Half
-
Minimum exponent a normalized
Halfvariable may have. - MIN_NORMAL - Static variable in class com.apple.foundationdb.half.Half
-
A constant holding the smallest positive normal value of type
Half, 2-14. - MIN_SUB_EXPONENT - Static variable in class com.apple.foundationdb.half.HalfConstants
-
The exponent the smallest positive
halfsubnormal value would have if it could be normalized. - MIN_V2 - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Mutation
- MIN_VALUE - Static variable in class com.apple.foundationdb.half.Half
-
A constant holding the smallest positive nonzero value of type
Half, 2-24. - missingRanges(ReadTransaction) - Method in class com.apple.foundationdb.async.RangeSet
-
Returns all of the ranges that are missing within this set.
- missingRanges(ReadTransactionContext) - Method in class com.apple.foundationdb.async.RangeSet
-
Returns all of the ranges that are missing within this set as list.
- missingRanges(ReadTransactionContext, byte[], byte[]) - Method in class com.apple.foundationdb.async.RangeSet
-
Returns all of the ranges that are missing within a given set of bounds as a list.
- missingRanges(ReadTransactionContext, byte[], byte[], int) - Method in class com.apple.foundationdb.async.RangeSet
-
Returns all of the ranges that are missing within a given set of bounds as a list.
- missingRanges(ReadTransactionContext, Range) - Method in class com.apple.foundationdb.async.RangeSet
-
Returns all of the ranges that are missing within a given range as a list.
- missingRanges(ReadTransaction, byte[], byte[]) - Method in class com.apple.foundationdb.async.RangeSet
-
Returns all of the ranges that are missing within a given set of bounds as a list.
- missingRanges(ReadTransaction, byte[], byte[], int) - Method in class com.apple.foundationdb.async.RangeSet
-
Returns all of the ranges that are missing within a given set of bounds.
- missingRanges(ReadTransaction, Range) - Method in class com.apple.foundationdb.async.RangeSet
-
Returns all of the ranges that are missing within a given range.
- more() - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEvents.EventRunner
- more() - Method in interface com.apple.foundationdb.clientlog.FDBClientLogEvents.EventConsumer
-
Determine whether to continue processing events.
- MoreAsyncUtil - Class in com.apple.foundationdb.async
-
More helpers in the spirit of
AsyncUtil. - MoreAsyncUtil.AlwaysTrue<T> - Class in com.apple.foundationdb.async
-
A
Booleanfunction that is always true. - MoreAsyncUtil.DeadlineExceededException - Exception in com.apple.foundationdb.async
-
Exception that will be thrown when the
supplierinMoreAsyncUtil.getWithDeadline(long, Supplier, ScheduledExecutorService)fails to complete within the specified deadline time. - MoreAsyncUtil.Holder<T> - Class in com.apple.foundationdb.async
-
A holder for a (mutable) value.
- moveInSlots(StorageAdapter, Iterable<? extends NodeSlot>) - Method in interface com.apple.foundationdb.async.rtree.Node
-
Move slots into this node that were previously part of another node (of the same kind).
- moveOutAllSlots(StorageAdapter) - Method in interface com.apple.foundationdb.async.rtree.Node
-
Move all slots out of this node.
- multiply(double) - Method in interface com.apple.foundationdb.linear.RealVector
- multiply(double) - Method in class com.apple.foundationdb.linear.Transformed
- multiply(RealMatrix) - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- multiply(RealMatrix) - Method in interface com.apple.foundationdb.linear.RealMatrix
- multiply(RealMatrix) - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- Mutation(int, byte[], byte[]) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.Mutation
N
- NaN - Static variable in class com.apple.foundationdb.half.Half
-
A constant holding a Not-a-Number (NaN) value of type
Half. - negate(Number) - Static method in class com.apple.foundationdb.tuple.TupleHelpers
-
Negate a number used as an element of a
Tuple. - NEGATIVE_INFINITY - Static variable in class com.apple.foundationdb.half.Half
-
A constant holding the negative infinity of type
Half. - NEGATIVE_MAX_VALUE - Static variable in class com.apple.foundationdb.half.Half
-
A constant holding the largest positive finite value of type
Half, (2-2-10)·215. - NEGATIVE_ZERO - Static variable in class com.apple.foundationdb.half.Half
-
A constant holding the negative zero of type
Half. - NETWORK_ALREADY_SETUP - Enum constant in enum com.apple.foundationdb.FDBError
- NETWORK_NOT_SETUP - Enum constant in enum com.apple.foundationdb.FDBError
- newChild(byte[], Object) - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- newComponentArray(int) - Method in class com.apple.foundationdb.linear.StoredVecsIterator
- newComponentArray(int) - Method in class com.apple.foundationdb.linear.StoredVecsIterator.StoredFVecsIterator
- newComponentArray(int) - Method in class com.apple.foundationdb.linear.StoredVecsIterator.StoredIVecsIterator
- newConfigBuilder() - Static method in class com.apple.foundationdb.async.hnsw.HNSW
-
Start building a
Config. - newConfigBuilder() - Static method in class com.apple.foundationdb.async.RankedSet
-
Start building a
RankedSet.Config. - newConfigBuilder() - Static method in class com.apple.foundationdb.async.rtree.RTree
-
Start building a
RTree.Config. - newOfSameKind(byte[]) - Method in interface com.apple.foundationdb.async.rtree.Node
-
Create a new node that is of the same
NodeKindas this node. - newPrefixChild(byte[], Object) - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- newRandomNodeId() - Static method in class com.apple.foundationdb.async.rtree.NodeHelpers
-
Method to create a new node identifier.
- next() - Method in class com.apple.foundationdb.async.rtree.RTree.ItemSlotIterator
- next() - Method in class com.apple.foundationdb.map.BunchedMapIterator
- next() - Method in class com.apple.foundationdb.map.BunchedMapMultiIterator
- next(ReadTransaction) - Method in interface com.apple.foundationdb.async.RankedSet.Lookup
- nextLookup(RankedSet.Lookup, ReadTransaction) - Method in class com.apple.foundationdb.async.RankedSet
- nextLookupKey(long, boolean, boolean, int, boolean) - Method in class com.apple.foundationdb.async.RankedSet
- nextVersionAfter(ReadTransaction, Instant) - Static method in class com.apple.foundationdb.clientlog.VersionFromTimestamp
-
Get the first version from the timekeeper at or after the given timestamp.
- NO_CLUSTER_FILE_FOUND - Enum constant in enum com.apple.foundationdb.FDBError
- NO_COMMIT_VERSION - Enum constant in enum com.apple.foundationdb.FDBError
- Node<N extends NodeReference> - Interface in com.apple.foundationdb.async.hnsw
-
Represents a node within an HNSW (Hierarchical Navigable Small World) structure.
- Node - Interface in com.apple.foundationdb.async.rtree
-
Interface to capture the common aspects of nodes being either
LeafNodes orIntermediateNodes. - Node.ChangeSet - Interface in com.apple.foundationdb.async.rtree
-
A change set for slots.
- NodeHelpers - Class in com.apple.foundationdb.async.rtree
-
Some helper methods for
Nodes. - NodeKind - Enum in com.apple.foundationdb.async.hnsw
-
Represents the different kinds of nodes, each associated with a unique byte value for serialization and deserialization.
- NodeKind - Enum in com.apple.foundationdb.async.rtree
-
Enum to capture the kind of node.
- NodeReference - Class in com.apple.foundationdb.async.hnsw
-
Represents a reference to a node, uniquely identified by its primary key.
- NodeReference(Tuple) - Constructor for class com.apple.foundationdb.async.hnsw.NodeReference
-
Constructs a new
NodeReferencewith the specified primary key. - NodeReferenceWithDistance - Class in com.apple.foundationdb.async.hnsw
-
Represents a reference to a node that includes its vector and its distance from a query vector.
- NodeReferenceWithDistance(Tuple, Transformed<RealVector>, double) - Constructor for class com.apple.foundationdb.async.hnsw.NodeReferenceWithDistance
-
Constructs a new instance of
NodeReferenceWithDistance. - NodeReferenceWithVector - Class in com.apple.foundationdb.async.hnsw
-
Represents a reference to a node that includes an associated vector.
- NodeReferenceWithVector(Tuple, Transformed<RealVector>) - Constructor for class com.apple.foundationdb.async.hnsw.NodeReferenceWithVector
-
Constructs a new
NodeReferenceWithVectorwith a specified primary key and vector. - NodeSlot - Interface in com.apple.foundationdb.async.rtree
-
Abstract base class for all node slots.
- NOOP - Static variable in interface com.apple.foundationdb.async.hnsw.OnReadListener
- NOOP - Static variable in interface com.apple.foundationdb.async.hnsw.OnWriteListener
- NOOP - Static variable in interface com.apple.foundationdb.async.rtree.OnReadListener
- NOOP - Static variable in interface com.apple.foundationdb.async.rtree.OnWriteListener
- noOpQuantizer(Metric) - Static method in interface com.apple.foundationdb.linear.Quantizer
-
Creates a no-op
Quantizerthat does not perform any data transformation. - normalize() - Method in interface com.apple.foundationdb.linear.RealVector
- NOT_COMMITTED - Enum constant in enum com.apple.foundationdb.FDBError
O
- onAsyncRead(CompletableFuture<T>) - Method in interface com.apple.foundationdb.async.hnsw.OnReadListener
-
A callback method that can be overridden to intercept the result of an asynchronous node read.
- onAsyncRead(CompletableFuture<T>) - Method in interface com.apple.foundationdb.async.rtree.OnReadListener
- onAsyncReadForWrite(CompletableFuture<T>) - Method in interface com.apple.foundationdb.async.rtree.OnWriteListener
- onChildNodeDiscard(ChildSlot) - Method in interface com.apple.foundationdb.async.rtree.OnReadListener
- onHasNext() - Method in class com.apple.foundationdb.async.rtree.RTree.ItemSlotIterator
- onHasNext() - Method in class com.apple.foundationdb.map.BunchedMapIterator
- onHasNext() - Method in class com.apple.foundationdb.map.BunchedMapMultiIterator
- onKeyCleared(Node, byte[]) - Method in interface com.apple.foundationdb.async.rtree.OnWriteListener
- onKeyValueRead(int, byte[], byte[]) - Method in interface com.apple.foundationdb.async.hnsw.OnReadListener
-
Callback invoked when a key-value pair is read from a specific layer.
- onKeyValueRead(Node, byte[], byte[]) - Method in interface com.apple.foundationdb.async.rtree.OnReadListener
- onKeyValueWritten(int, byte[], byte[]) - Method in interface com.apple.foundationdb.async.hnsw.OnWriteListener
- onKeyValueWritten(Node, byte[], byte[]) - Method in interface com.apple.foundationdb.async.rtree.OnWriteListener
- onNeighborDeleted(int, Node<? extends NodeReference>, Tuple) - Method in interface com.apple.foundationdb.async.hnsw.OnWriteListener
-
Callback method invoked when a neighbor of a specific node is deleted.
- onNeighborWritten(int, Node<? extends NodeReference>, NodeReference) - Method in interface com.apple.foundationdb.async.hnsw.OnWriteListener
-
Callback method invoked when a neighbor is written for a specific node.
- onNodeCleared(Node) - Method in interface com.apple.foundationdb.async.rtree.OnWriteListener
- onNodeRead(int, Node<? extends NodeReference>) - Method in interface com.apple.foundationdb.async.hnsw.OnReadListener
-
Callback method invoked when a node is read during a traversal process.
- onNodeRead(Node) - Method in interface com.apple.foundationdb.async.rtree.OnReadListener
- onNodeWritten(int, Node<? extends NodeReference>) - Method in interface com.apple.foundationdb.async.hnsw.OnWriteListener
-
Callback method invoked after a node has been successfully written to a specific layer.
- onNodeWritten(Node) - Method in interface com.apple.foundationdb.async.rtree.OnWriteListener
- OnReadListener - Interface in com.apple.foundationdb.async.hnsw
-
Interface for call backs whenever we read node data from the database.
- OnReadListener - Interface in com.apple.foundationdb.async.rtree
-
Function interface for a call back whenever we read the slots for a node.
- onSlotIndexEntryCleared(byte[]) - Method in interface com.apple.foundationdb.async.rtree.OnWriteListener
- onSlotIndexEntryRead(byte[]) - Method in interface com.apple.foundationdb.async.rtree.OnReadListener
- onSlotIndexEntryWritten(byte[]) - Method in interface com.apple.foundationdb.async.rtree.OnWriteListener
- OnWriteListener - Interface in com.apple.foundationdb.async.hnsw
-
Interface for call backs whenever we write data to the database.
- OnWriteListener - Interface in com.apple.foundationdb.async.rtree
-
Function interface for a call back whenever we read the slots for a node.
- OPERATION_CANCELLED - Enum constant in enum com.apple.foundationdb.FDBError
- OPERATION_FAILED - Enum constant in enum com.apple.foundationdb.FDBError
P
- pack(Tuple, TupleOrdering.Direction) - Static method in class com.apple.foundationdb.tuple.TupleOrdering
-
Encode the given tuple in a way that unordered byte comparison respects the given direction.
- packedSizeAsTupleItem(Object) - Static method in class com.apple.foundationdb.tuple.TupleHelpers
-
Get the number of bytes that an object would occupy as an element of an encoded
Tuple. - peek() - Method in interface com.apple.foundationdb.async.AsyncPeekIterator
-
Get the next item of the scan without advancing it.
- peek() - Method in class com.apple.foundationdb.map.BunchedMapIterator
- peek() - Method in class com.apple.foundationdb.map.BunchedMapMultiIterator
- PERFORMANCE_COUNTER_ERROR - Enum constant in enum com.apple.foundationdb.FDBError
- PLATFORM_ERROR - Enum constant in enum com.apple.foundationdb.FDBError
- Point(Tuple) - Constructor for class com.apple.foundationdb.async.rtree.RTree.Point
- POSITIVE_INFINITY - Static variable in class com.apple.foundationdb.half.Half
-
A constant holding the positive infinity of type
Half. - POSITIVE_ZERO - Static variable in class com.apple.foundationdb.half.Half
-
A constant holding the positive zero of type
Half. - prefixLengthOfSize(byte[], int) - Static method in class com.apple.foundationdb.tuple.TupleHelpers
-
Get the index of a prefix of an encoded tuple that decodes as a sub-tuple of the given size.
- preloadForLookup(ReadTransaction) - Method in class com.apple.foundationdb.async.RankedSet
-
Read the deeper, likely empty, levels to get them into the RYW cache, since individual lookups may only add pieces, requiring additional requests as keys increase.
- PRIMARY_DATACENTER_KEY - Static variable in class com.apple.foundationdb.system.SystemKeyspace
- primaryKeys(Iterable<? extends NodeReference>) - Static method in class com.apple.foundationdb.async.hnsw.NodeReference
-
Helper to extract the primary keys from a given collection of node references.
- print(int, List<TupleKeyCountTree>) - Method in interface com.apple.foundationdb.clientlog.TupleKeyCountTree.Printer
- printTree(int, int, TupleKeyCountTree.Printer, String) - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- printTree(TupleKeyCountTree.Printer, String) - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
-
Print this tree to the given printer.
- PROCESS_BEHIND - Enum constant in enum com.apple.foundationdb.FDBError
- PROTOCOL_VERSION_5_2 - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- PROTOCOL_VERSION_6_0 - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- PROTOCOL_VERSION_6_1 - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- PROTOCOL_VERSION_6_2 - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- PROTOCOL_VERSION_6_3 - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- PROTOCOL_VERSION_7_0 - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- PROTOCOL_VERSION_7_1 - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- PROTOCOL_VERSION_7_2 - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- PROTOCOL_VERSION_7_3 - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents
- PROXY_MEMORY_LIMIT_EXCEEDED - Enum constant in enum com.apple.foundationdb.FDBError
- put(TransactionContext, Subspace, K, V) - Method in class com.apple.foundationdb.map.BunchedMap
-
Inserts or updates a key into a map with a new value.
Q
- QRDecomposition - Class in com.apple.foundationdb.linear
-
Provides a static method to compute the QR decomposition of a matrix.
- QRDecomposition.Result - Class in com.apple.foundationdb.linear
- quantizeFloat(float) - Static method in class com.apple.foundationdb.half.Half
- Quantizer - Interface in com.apple.foundationdb.linear
-
Defines the contract for a quantizer, a component responsible for encoding data vectors into a different, ideally a more compact, representation.
- quickTranspose() - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- quickTranspose() - Method in interface com.apple.foundationdb.linear.RealMatrix
- quickTranspose() - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
R
- RaBitEstimator - Class in com.apple.foundationdb.rabitq
- RaBitEstimator(Metric, int) - Constructor for class com.apple.foundationdb.rabitq.RaBitEstimator
- RaBitEstimator.Result - Class in com.apple.foundationdb.rabitq
- RABITQ - Enum constant in enum com.apple.foundationdb.linear.VectorType
- RaBitQuantizer - Class in com.apple.foundationdb.rabitq
-
Implements the RaBit quantization scheme, a technique for compressing high-dimensional vectors into a compact integer-based representation.
- RaBitQuantizer(Metric, int) - Constructor for class com.apple.foundationdb.rabitq.RaBitQuantizer
-
Constructs a new
RaBitQuantizerinstance. - RaBitQuantizer.Result - Class in com.apple.foundationdb.rabitq
- RANDOM_HASH - Static variable in class com.apple.foundationdb.async.RankedSet
-
Hash using a random number.
- randomGaussianMatrix(Random, int, int) - Static method in class com.apple.foundationdb.linear.MatrixHelpers
- randomOrthogonalMatrix(Random, int) - Static method in class com.apple.foundationdb.linear.MatrixHelpers
- RANGE_LIMITS_INVALID - Enum constant in enum com.apple.foundationdb.FDBError
- RangeSet - Class in com.apple.foundationdb.async
-
RangeSet supports efficient adding of ranges of keys into the database to support marking work done elsewhere as completed as well as checking if specific keys are already completed.
- RangeSet(Subspace) - Constructor for class com.apple.foundationdb.async.RangeSet
-
Creates a new RangeSet that will write its data to the given subspace provided.
- rank(ReadTransactionContext, byte[]) - Method in class com.apple.foundationdb.async.RankedSet
-
Return the index of a key within the set.
- rank(ReadTransactionContext, byte[], boolean) - Method in class com.apple.foundationdb.async.RankedSet
-
Return the index of a key within the set.
- RankedSet - Class in com.apple.foundationdb.async
-
RankedSetsupports the efficient retrieval of elements by their rank as defined by lexicographic order. - RankedSet(Subspace, Executor) - Constructor for class com.apple.foundationdb.async.RankedSet
-
Initialize a new ranked set with the default configuration.
- RankedSet(Subspace, Executor, int) - Constructor for class com.apple.foundationdb.async.RankedSet
-
Initialize a new ranked set.
- RankedSet(Subspace, Executor, RankedSet.Config) - Constructor for class com.apple.foundationdb.async.RankedSet
-
Initialize a new ranked set.
- RankedSet(Subspace, Executor, RankedSet.HashFunction, int) - Constructor for class com.apple.foundationdb.async.RankedSet
-
Initialize a new ranked set.
- RankedSet.Config - Class in com.apple.foundationdb.async
-
Configuration settings for a
RankedSet. - RankedSet.ConfigBuilder - Class in com.apple.foundationdb.async
-
Builder for
RankedSet.Config. - RankedSet.Consistency - Class in com.apple.foundationdb.async
- RankedSet.HashFunction - Interface in com.apple.foundationdb.async
-
Function to compute the hash used to determine which levels a key value splits on.
- RankedSet.Lookup - Interface in com.apple.foundationdb.async
- READ_VERSION_ALREADY_SET - Enum constant in enum com.apple.foundationdb.FDBError
- RealMatrix - Interface in com.apple.foundationdb.linear
- RealVector - Interface in com.apple.foundationdb.linear
-
An abstract base class representing a mathematical vector.
- Rectangle(Tuple) - Constructor for class com.apple.foundationdb.async.rtree.RTree.Rectangle
- reduce(AsyncIterator<T>, U, BiFunction<U, ? super T, U>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Reduce contents of iterator to single value.
- reduce(Executor, AsyncIterator<T>, U, BiFunction<U, ? super T, U>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
- releaseLock(Transaction) - Method in class com.apple.foundationdb.synchronizedsession.SynchronizedSession
-
End the session by releasing the lock if it still holds the lock.
- remove(TransactionContext, byte[]) - Method in class com.apple.foundationdb.async.RankedSet
-
Removes a key from the set.
- remove(TransactionContext, Subspace, K) - Method in class com.apple.foundationdb.map.BunchedMap
-
Removes a key from the map.
- rep(ReadTransactionContext) - Method in class com.apple.foundationdb.async.RangeSet
- repeat(char, int) - Static method in class com.apple.foundationdb.util.StringUtils
- replaceEach(String, Map<String, String>) - Static method in class com.apple.foundationdb.util.StringUtils
-
Replace all occurrences of the keys of the
replaceMapin thesourcestring with their corresponding value in the map. - Result(double, double) - Constructor for class com.apple.foundationdb.rabitq.RaBitEstimator.Result
- Result(EncodedRealVector, double, double) - Constructor for class com.apple.foundationdb.rabitq.RaBitQuantizer.Result
- Result(Supplier<RealMatrix>, Supplier<RealMatrix>) - Constructor for class com.apple.foundationdb.linear.QRDecomposition.Result
- ResultEntry - Class in com.apple.foundationdb.async.hnsw
-
Record-like class to wrap the results of a kNN-search.
- ResultEntry(Tuple, RealVector, double, int) - Constructor for class com.apple.foundationdb.async.hnsw.ResultEntry
- reverseDirection() - Method in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
- RowMajorRealMatrix - Class in com.apple.foundationdb.linear
- RowMajorRealMatrix(double[][]) - Constructor for class com.apple.foundationdb.linear.RowMajorRealMatrix
- RTree - Class in com.apple.foundationdb.async.rtree
-
An implementation of an R-tree.
- RTree(Subspace, Subspace, Executor, RTree.Config, Function<RTree.Point, BigInteger>, Supplier<byte[]>, OnWriteListener, OnReadListener) - Constructor for class com.apple.foundationdb.async.rtree.RTree
-
Initialize a new R-tree.
- RTree(Subspace, Subspace, Executor, Function<RTree.Point, BigInteger>) - Constructor for class com.apple.foundationdb.async.rtree.RTree
-
Initialize a new R-tree with the default configuration.
- RTree.Config - Class in com.apple.foundationdb.async.rtree
-
Configuration settings for a
RTree. - RTree.ConfigBuilder - Class in com.apple.foundationdb.async.rtree
-
Builder for
RTree.Config. - RTree.ItemSlotIterator - Class in com.apple.foundationdb.async.rtree
-
Iterator for iterating the items contained in the leaf nodes produced by an underlying
RTree.LeafIterator. - RTree.Point - Class in com.apple.foundationdb.async.rtree
-
Class to capture an N-dimensional point.
- RTree.Rectangle - Class in com.apple.foundationdb.async.rtree
-
Class to capture an N-dimensional rectangle/cube/hypercube.
- RTree.Storage - Enum in com.apple.foundationdb.async.rtree
-
Different kinds of storage layouts.
- RTreeHilbertCurveHelpers - Class in com.apple.foundationdb.async.rtree
-
Utility class to compute the Hilbert value from n-dimensional points.
- run() - Method in class com.apple.foundationdb.clientlog.DatabaseClientLogEvents.EventRunner
S
- satisfiesPositivity() - Method in enum com.apple.foundationdb.linear.Metric
- satisfiesSymmetry() - Method in enum com.apple.foundationdb.linear.Metric
- satisfiesTriangleInequality() - Method in enum com.apple.foundationdb.linear.Metric
- satisfiesZeroSelfDistance() - Method in enum com.apple.foundationdb.linear.Metric
- scan(ReadTransaction, Subspace) - Method in class com.apple.foundationdb.map.BunchedMap
-
Scans the map and returns an iterator over all entries.
- scan(ReadTransaction, Subspace, byte[]) - Method in class com.apple.foundationdb.map.BunchedMap
-
Scans the maps and returns an iterator over all entries.
- scan(ReadTransaction, Subspace, byte[], int, boolean) - Method in class com.apple.foundationdb.map.BunchedMap
-
Scans the map and returns an iterator over all entries.
- scan(ReadTransaction, BigInteger, Tuple, Predicate<RTree.Rectangle>, BiPredicate<Tuple, Tuple>) - Method in class com.apple.foundationdb.async.rtree.RTree
-
Perform a scan over the tree within the transaction passed in using a predicate that is also passed in to eliminate subtrees from the scan.
- scan(ReadTransaction, Predicate<RTree.Rectangle>, BiPredicate<Tuple, Tuple>) - Method in class com.apple.foundationdb.async.rtree.RTree
-
Perform a scan over the tree within the transaction passed in using a predicate that is also passed in to eliminate subtrees from the scan.
- scanMulti(ReadTransaction, Subspace, SubspaceSplitter<T>) - Method in class com.apple.foundationdb.map.BunchedMap
-
Scans multiple maps and returns an iterator over all of them.
- scanMulti(ReadTransaction, Subspace, SubspaceSplitter<T>, byte[], byte[], byte[], int, boolean) - Method in class com.apple.foundationdb.map.BunchedMap
-
Scans multiple maps and returns an iterator over all of them.
- scanMulti(ReadTransaction, Subspace, SubspaceSplitter<T>, byte[], byte[], byte[], int, Consumer<KeyValue>, boolean) - Method in class com.apple.foundationdb.map.BunchedMap
-
Overload of
scanMulti()that provides a callback to run after each key is read. - scanMulti(ReadTransaction, Subspace, SubspaceSplitter<T>, byte[], int, boolean) - Method in class com.apple.foundationdb.map.BunchedMap
-
Scans multiple maps and returns an iterator over all of them.
- serializeEntries(List<Map.Entry<Tuple, Tuple>>) - Method in class com.apple.foundationdb.map.BunchedTupleSerializer
-
Serialize an entry list to bytes.
- serializeEntries(List<Map.Entry<K, V>>) - Method in interface com.apple.foundationdb.map.BunchedSerializer
-
Serialize a list of entries.
- serializeEntry(Tuple, Tuple) - Method in class com.apple.foundationdb.map.BunchedTupleSerializer
-
Serialize a pair of
Tuples to bytes. - serializeEntry(Map.Entry<K, V>) - Method in interface com.apple.foundationdb.map.BunchedSerializer
-
Serialize a single entry to bytes.
- serializeEntry(K, V) - Method in interface com.apple.foundationdb.map.BunchedSerializer
-
Serialize a single entry to bytes.
- serializeKey(Tuple) - Method in class com.apple.foundationdb.map.BunchedTupleSerializer
-
Serialize a
Tupleto bytes. - serializeKey(K) - Method in interface com.apple.foundationdb.map.BunchedSerializer
-
Serialize a key to bytes.
- SESSION_ID - Enum constant in enum com.apple.foundationdb.util.LogMessageKeys
- set(Tuple, int, Object) - Static method in class com.apple.foundationdb.tuple.TupleHelpers
- SET_VALUE - Static variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Mutation
- setCallback(Consumer<T>) - Method in interface com.apple.foundationdb.async.AsyncPeekCallbackIterator
-
Set the callback to the provided
Consumer. - setCountDuplicates(boolean) - Method in class com.apple.foundationdb.async.RankedSet.ConfigBuilder
-
Set whether to count duplicate keys separately.
- setData(byte[]) - Method in exception com.apple.foundationdb.map.BunchedSerializationException
-
Set the data array that triggered this exception.
- setEfConstruction(int) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setExtendCandidates(boolean) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setHashFunction(RankedSet.HashFunction) - Method in class com.apple.foundationdb.async.RankedSet.ConfigBuilder
-
Set the hash function to use.
- setKeepPrunedConnections(boolean) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setM(int) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setMaintainStatsProbability(double) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setMaxM(int) - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- setMaxNumConcurrentNeighborhoodFetches(int) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setMaxNumConcurrentNodeFetches(int) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setMetric(Metric) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setMinM(int) - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- setMMax(int) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setMMax0(int) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setNLevels(int) - Method in class com.apple.foundationdb.async.RankedSet.ConfigBuilder
-
Set the hash function to use.
- setRaBitQNumExBits(int) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setRandomSeed(long) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setSampleVectorStatsProbability(double) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setSplitS(int) - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- setStatsThreshold(int) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setStorage(RTree.Storage) - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- setStoreHilbertValues(boolean) - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- setUseInlining(boolean) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setUseNodeSlotIndex(boolean) - Method in class com.apple.foundationdb.async.rtree.RTree.ConfigBuilder
- setUseRaBitQ(boolean) - Method in class com.apple.foundationdb.async.hnsw.Config.ConfigBuilder
- setValue(Object) - Method in exception com.apple.foundationdb.map.BunchedSerializationException
-
Set the value that triggered this exception.
- setVisible(boolean) - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- shortBitsToHalf(short) - Static method in class com.apple.foundationdb.half.Half
-
Returns the
Halfobject corresponding to a given bit representation. - shortValue() - Method in class com.apple.foundationdb.half.Half
-
Returns the value of the specified number as a
short. - SIGN_BIT_MASK - Static variable in class com.apple.foundationdb.half.HalfConstants
-
Bit mask to isolate the sign bit of a
half. - SIGNIF_BIT_MASK - Static variable in class com.apple.foundationdb.half.HalfConstants
-
Bit mask to isolate the significand field of a
half. - SIGNIFICAND_WIDTH - Static variable in class com.apple.foundationdb.half.HalfConstants
-
The number of logical bits in the significand of a
halfnumber, including the implicit bit. - SINGLE - Enum constant in enum com.apple.foundationdb.linear.VectorType
- size() - Method in interface com.apple.foundationdb.async.rtree.Node
-
Return the number of used slots of this node.
- size(ReadTransactionContext) - Method in class com.apple.foundationdb.async.RankedSet
-
Count the items in the set.
- SIZE - Static variable in class com.apple.foundationdb.half.Half
-
The number of bits used to represent a
Halfvalue. - SLOT_KEY_TUPLE_SIZE - Static variable in class com.apple.foundationdb.async.rtree.ItemSlot
- SLOT_VALUE_TUPLE_SIZE - Static variable in class com.apple.foundationdb.async.rtree.ItemSlot
- slotsStream() - Method in interface com.apple.foundationdb.async.rtree.Node
-
Return a stream of node slots.
- SpanContext(FDBClientLogEvents.Uid, long, byte) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.SpanContext
- startTimestamp - Variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Event
- StoredFVecsIterator(FileChannel) - Constructor for class com.apple.foundationdb.linear.StoredVecsIterator.StoredFVecsIterator
- StoredIVecsIterator(FileChannel) - Constructor for class com.apple.foundationdb.linear.StoredVecsIterator.StoredIVecsIterator
- StoredVecsIterator<N extends Number,
T> - Class in com.apple.foundationdb.linear -
Abstract iterator implementation to read the IVecs/FVecs data format that is used by publicly available embedding datasets.
- StoredVecsIterator(FileChannel) - Constructor for class com.apple.foundationdb.linear.StoredVecsIterator
- StoredVecsIterator.StoredFVecsIterator - Class in com.apple.foundationdb.linear
-
Iterator to read floating point vectors from a
FileChannelproviding an iterator ofDoubleRealVectors. - StoredVecsIterator.StoredIVecsIterator - Class in com.apple.foundationdb.linear
-
Iterator to read vectors from a
FileChannelinto a list of integers. - StringUtils - Class in com.apple.foundationdb.util
-
Utility methods for operating with
Strings. - StringUtils() - Constructor for class com.apple.foundationdb.util.StringUtils
- subMatrix(int, int, int, int) - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- subMatrix(int, int, int, int) - Method in interface com.apple.foundationdb.linear.RealMatrix
- subMatrix(int, int, int, int) - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- subspace - Variable in class com.apple.foundationdb.async.RankedSet
- SUBSPACE - Enum constant in enum com.apple.foundationdb.util.LogMessageKeys
- subspaceOf(byte[]) - Method in interface com.apple.foundationdb.map.SubspaceSplitter
-
Determine a
Subspacethat the given key is contained within. - SubspaceSplitter<T> - Interface in com.apple.foundationdb.map
-
An interface to split a raw FoundationDB key into a subspace and (possibly) a "tag".
- subspaceTag(Subspace) - Method in interface com.apple.foundationdb.map.SubspaceSplitter
-
Compute and return some application-specific "tag" for a given subspace.
- subtract(double) - Method in interface com.apple.foundationdb.linear.RealVector
- subtract(RealVector) - Method in interface com.apple.foundationdb.linear.RealVector
- subTuple(Tuple, int, int) - Static method in class com.apple.foundationdb.tuple.TupleHelpers
- SUCCESS - Enum constant in enum com.apple.foundationdb.FDBError
- suffixPredicateCanBeApplied() - Method in class com.apple.foundationdb.async.rtree.ChildSlot
-
Method to determine if (during a scan a suffix predicate can be applied).
- sum(Half, Half) - Static method in class com.apple.foundationdb.half.Half
-
Adds two
Halfvalues together as per the + operator. - swallowException(CompletableFuture<Void>, Predicate<Throwable>) - Static method in class com.apple.foundationdb.async.MoreAsyncUtil
-
Swallows exceptions matching a given predicate from a future.
- SynchronizedSession - Class in com.apple.foundationdb.synchronizedsession
-
A
SynchronizedSessionis a concept introduced to avoid multiple attempts at performing the same operation (with each attempt opening multiple transactions running concurrently and/or consecutively) from running concurrently and contending for resources. - SynchronizedSession(Subspace, UUID, long) - Constructor for class com.apple.foundationdb.synchronizedsession.SynchronizedSession
-
Construct a session.
- SynchronizedSessionLockedException - Exception in com.apple.foundationdb.synchronizedsession
-
This exception means that the synchronized session is not valid anymore, probably because another synchronized session on the same lock is running.
- SynchronizedSessionLockedException(String, Object...) - Constructor for exception com.apple.foundationdb.synchronizedsession.SynchronizedSessionLockedException
- SystemKeyspace - Class in com.apple.foundationdb.system
-
Keys living in the FDB system and special keyspace.
T
- t - Variable in class com.apple.foundationdb.rabitq.RaBitQuantizer.Result
- TaskNotifyingExecutor - Class in com.apple.foundationdb.async
-
An executor that can perform pre- and post- work in the context of the thread executing a task.
- TaskNotifyingExecutor(Executor) - Constructor for class com.apple.foundationdb.async.TaskNotifyingExecutor
- tenant - Variable in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Event
- TEST_SPECIFICATION_INVALID - Enum constant in enum com.apple.foundationdb.FDBError
- TIMED_OUT - Enum constant in enum com.apple.foundationdb.FDBError
- TIMEKEEPER_KEY_PREFIX - Static variable in class com.apple.foundationdb.system.SystemKeyspace
- TLS_ERROR - Enum constant in enum com.apple.foundationdb.FDBError
- toBuilder() - Method in class com.apple.foundationdb.async.hnsw.Config
- toBuilder() - Method in class com.apple.foundationdb.async.RankedSet.Config
- toBuilder() - Method in class com.apple.foundationdb.async.rtree.RTree.Config
- toColumnMajor() - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- toColumnMajor() - Method in interface com.apple.foundationdb.linear.RealMatrix
- toColumnMajor() - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- toComponent(ByteBuffer) - Method in class com.apple.foundationdb.linear.StoredVecsIterator.StoredFVecsIterator
- toComponent(ByteBuffer) - Method in class com.apple.foundationdb.linear.StoredVecsIterator.StoredIVecsIterator
- toComponent(ByteBuffer) - Method in class com.apple.foundationdb.linear.StoredVecsIterator
- toDebugString(ReadTransactionContext) - Method in class com.apple.foundationdb.async.RankedSet
- toDoubleRealVector() - Method in class com.apple.foundationdb.linear.DoubleRealVector
- toDoubleRealVector() - Method in class com.apple.foundationdb.linear.FloatRealVector
- toDoubleRealVector() - Method in class com.apple.foundationdb.linear.HalfRealVector
- toDoubleRealVector() - Method in interface com.apple.foundationdb.linear.RealVector
-
Converts this vector into a
DoubleRealVector. - toDoubleRealVector() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- toFloatRealVector() - Method in class com.apple.foundationdb.linear.DoubleRealVector
- toFloatRealVector() - Method in class com.apple.foundationdb.linear.FloatRealVector
- toFloatRealVector() - Method in class com.apple.foundationdb.linear.HalfRealVector
- toFloatRealVector() - Method in interface com.apple.foundationdb.linear.RealVector
-
Converts this object into a
RealVectorof single precision floating-point numbers. - toFloatRealVector() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- toHalfRealVector() - Method in class com.apple.foundationdb.linear.DoubleRealVector
- toHalfRealVector() - Method in class com.apple.foundationdb.linear.FloatRealVector
- toHalfRealVector() - Method in class com.apple.foundationdb.linear.HalfRealVector
- toHalfRealVector() - Method in interface com.apple.foundationdb.linear.RealVector
-
Converts this object into a
RealVectorofHalfprecision floating-point numbers. - toHalfRealVector() - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- toHexString(byte[]) - Static method in class com.apple.foundationdb.tuple.ByteArrayUtil2
-
Create a base-16 representation of the give byte array.
- toHexString(Half) - Static method in class com.apple.foundationdb.half.Half
-
Returns a hexadecimal string representation of the
halfargument. - TOO_MANY_WATCHES - Enum constant in enum com.apple.foundationdb.FDBError
- toPlotString() - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- toRowMajor() - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- toRowMajor() - Method in interface com.apple.foundationdb.linear.RealMatrix
- toRowMajor() - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- toString() - Method in class com.apple.foundationdb.async.hnsw.Config
- toString() - Method in class com.apple.foundationdb.async.hnsw.NodeReference
-
Returns a string representation of the object.
- toString() - Method in class com.apple.foundationdb.async.hnsw.NodeReferenceWithVector
-
Returns a string representation of this object.
- toString() - Method in class com.apple.foundationdb.async.hnsw.ResultEntry
- toString() - Method in class com.apple.foundationdb.async.RankedSet.Consistency
- toString() - Method in class com.apple.foundationdb.async.rtree.ChildSlot
- toString() - Method in class com.apple.foundationdb.async.rtree.ItemSlot
- toString() - Method in class com.apple.foundationdb.async.rtree.RTree.Config
- toString() - Method in class com.apple.foundationdb.async.rtree.RTree.Point
- toString() - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- toString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.CommitRequest
- toString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommit
- toString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventCommitError
- toString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGet
- toString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetError
- toString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetRange
- toString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetRangeError
- toString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.EventGetVersion
- toString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Mutation
- toString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.SpanContext
- toString() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Uid
- toString() - Method in class com.apple.foundationdb.clientlog.TupleKeyCountTree
- toString() - Method in class com.apple.foundationdb.half.Half
- toString() - Method in class com.apple.foundationdb.linear.AbstractRealVector
-
Returns a string representation of the object.
- toString() - Method in enum com.apple.foundationdb.linear.Metric
- toString() - Method in class com.apple.foundationdb.linear.Transformed
- toString() - Method in class com.apple.foundationdb.rabitq.RaBitEstimator.Result
- toString() - Method in enum com.apple.foundationdb.util.LogMessageKeys
- toString(int) - Static method in enum com.apple.foundationdb.FDBError
- toString(int) - Method in class com.apple.foundationdb.linear.AbstractRealVector
-
Generates a string representation of the data array, with an option to limit the number of dimensions shown.
- toString(Half) - Static method in class com.apple.foundationdb.half.Half
-
Returns a string representation of the
halfargument. - toStringBase() - Method in class com.apple.foundationdb.clientlog.FDBClientLogEvents.Event
- toTarget(Double[]) - Method in class com.apple.foundationdb.linear.StoredVecsIterator.StoredFVecsIterator
- toTarget(Integer[]) - Method in class com.apple.foundationdb.linear.StoredVecsIterator.StoredIVecsIterator
- toTarget(N[]) - Method in class com.apple.foundationdb.linear.StoredVecsIterator
- TRANSACTION_CANCELLED - Enum constant in enum com.apple.foundationdb.FDBError
- TRANSACTION_CONFLICTING_KEYS_PREFIX - Static variable in class com.apple.foundationdb.system.SystemKeyspace
- TRANSACTION_INVALID_VERSION - Enum constant in enum com.apple.foundationdb.FDBError
- TRANSACTION_READ_ONLY - Enum constant in enum com.apple.foundationdb.FDBError
- TRANSACTION_TIMED_OUT - Enum constant in enum com.apple.foundationdb.FDBError
- TRANSACTION_TOO_LARGE - Enum constant in enum com.apple.foundationdb.FDBError
- TRANSACTION_TOO_OLD - Enum constant in enum com.apple.foundationdb.FDBError
- transform(RealVector) - Method in interface com.apple.foundationdb.linear.VectorOperator
-
Applies the operator to the vector that is passed in and creates a `Transformed` wrapper wrapping the result.
- Transformed<V extends RealVector> - Class in com.apple.foundationdb.linear
-
This class aims to reduce potential logic problems with respect to coordinate transformations by soliciting help from Java's type system.
- transpose() - Method in class com.apple.foundationdb.linear.ColumnMajorRealMatrix
- transpose() - Method in interface com.apple.foundationdb.linear.RealMatrix
- transpose() - Method in class com.apple.foundationdb.linear.RowMajorRealMatrix
- transposedApply(RealVector) - Method in class com.apple.foundationdb.linear.FhtKacRotator
- transposedApply(RealVector) - Method in interface com.apple.foundationdb.linear.LinearOperator
- transposedApply(RealVector) - Method in interface com.apple.foundationdb.linear.RealMatrix
- TupleHelpers - Class in com.apple.foundationdb.tuple
-
Helper methods for working with
Tuples. - TupleKeyCountTree - Class in com.apple.foundationdb.clientlog
-
A tree of occurrence counts tuple-encoded keys.
- TupleKeyCountTree() - Constructor for class com.apple.foundationdb.clientlog.TupleKeyCountTree
- TupleKeyCountTree(TupleKeyCountTree, byte[], Object) - Constructor for class com.apple.foundationdb.clientlog.TupleKeyCountTree
- TupleKeyCountTree.Printer - Interface in com.apple.foundationdb.clientlog
- TupleOrdering - Class in com.apple.foundationdb.tuple
-
Helper methods for encoding
Tuples in ways that implement SQL-like ordering. - TupleOrdering.Direction - Enum in com.apple.foundationdb.tuple
-
Direction of ordering.
U
- Uid(long, long) - Constructor for class com.apple.foundationdb.clientlog.FDBClientLogEvents.Uid
- ulp(Half) - Static method in class com.apple.foundationdb.half.HalfMath
-
Returns the size of an ulp of the argument.
- unionWith(RTree.Point) - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- unionWith(RTree.Rectangle) - Method in class com.apple.foundationdb.async.rtree.RTree.Rectangle
- UNKNOWN_ERROR - Enum constant in enum com.apple.foundationdb.FDBError
- UNLIMITED - Static variable in class com.apple.foundationdb.async.RangeSet
-
Value indicating that there should be no limit.
- unpack(byte[], TupleOrdering.Direction) - Static method in class com.apple.foundationdb.tuple.TupleOrdering
-
Decode the result of
TupleOrdering.pack(com.apple.foundationdb.tuple.Tuple, com.apple.foundationdb.tuple.TupleOrdering.Direction), recovering the original tuple. - unprint(String) - Static method in class com.apple.foundationdb.tuple.ByteArrayUtil2
-
Construct a byte array from a human-readable representation returned by
ByteArrayUtil.printable(byte[])orByteArrayUtil2.loggable(byte[]). - UNRECOGNIZED - Enum constant in enum com.apple.foundationdb.FDBError
- UNSUPPORTED_OPERATION - Enum constant in enum com.apple.foundationdb.FDBError
- untransform(Transformed<RealVector>) - Method in interface com.apple.foundationdb.linear.VectorOperator
-
Inverted-applies the operator to a transformed vector that is passed in and returns a naked (unwrapped)
RealVector. - updateLockSessionLeaseEndTime(Transaction) - Method in class com.apple.foundationdb.synchronizedsession.SynchronizedSession
-
Update the lease's end time.
- updateSlot(StorageAdapter, int, int, NodeSlot) - Method in interface com.apple.foundationdb.async.rtree.Node
-
Update an existing slot of this node.
- USED_DURING_COMMIT - Enum constant in enum com.apple.foundationdb.FDBError
V
- validate() - Method in interface com.apple.foundationdb.async.rtree.Node
-
Method to validate the invariants of this node.
- validate(Database) - Method in class com.apple.foundationdb.async.rtree.RTree
-
Method to validate the Hilbert R-tree.
- validate(Database, int) - Method in class com.apple.foundationdb.async.rtree.RTree
-
Method to validate the Hilbert R-tree.
- validateParentNode(IntermediateNode, ChildSlot) - Method in interface com.apple.foundationdb.async.rtree.Node
-
Method to validate the invariants of the relationships of this node and this node's parent's
ChildSlotcorresponding to this node. - value - Variable in class com.apple.foundationdb.async.MoreAsyncUtil.Holder
- VALUE_TOO_LARGE - Enum constant in enum com.apple.foundationdb.FDBError
- valueBasedHashCode() - Method in interface com.apple.foundationdb.linear.RealMatrix
- valueEquals(Object) - Method in interface com.apple.foundationdb.linear.RealMatrix
- valueOf(double) - Static method in class com.apple.foundationdb.half.Half
-
Returns a
Halfinstance representing the specifieddoublevalue. - valueOf(float) - Static method in class com.apple.foundationdb.half.Half
-
Returns a
Halfinstance representing the specifiedfloatvalue. - valueOf(Half) - Static method in class com.apple.foundationdb.half.Half
-
Returns a new
Halfinstance identical to the specifiedhalf. - valueOf(Double) - Static method in class com.apple.foundationdb.half.Half
-
Returns a
Halfinstance representing the specifiedDoublevalue. - valueOf(Float) - Static method in class com.apple.foundationdb.half.Half
-
Returns a
Halfinstance representing the specifiedFloatvalue. - valueOf(String) - Static method in enum com.apple.foundationdb.async.hnsw.NodeKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.async.rtree.NodeKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.async.rtree.RTree.Storage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.FDBError
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in class com.apple.foundationdb.half.Half
-
Returns a
Halfobject represented by the argument strings. - valueOf(String) - Static method in enum com.apple.foundationdb.linear.Metric
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.linear.VectorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.util.LogMessageKeys
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.apple.foundationdb.async.hnsw.NodeKind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.async.rtree.NodeKind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.async.rtree.RTree.Storage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.FDBError
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.linear.Metric
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.linear.VectorType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.tuple.TupleOrdering.Direction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.util.LogMessageKeys
-
Returns an array containing the constants of this enum type, in the order they are declared.
- VectorOperator - Interface in com.apple.foundationdb.linear
-
Interface that represents the root of all linear and affine operators including matrices.
- VectorType - Enum in com.apple.foundationdb.linear
- verifyIntegrity(TransactionContext, Subspace) - Method in class com.apple.foundationdb.map.BunchedMap
-
Verify the integrity of the bunched map.
- VERSION_INVALID - Enum constant in enum com.apple.foundationdb.FDBError
- VersionFromTimestamp - Class in com.apple.foundationdb.clientlog
-
Map from wall-clock time to transaction time.
W
- WATCHES_DISABLED - Enum constant in enum com.apple.foundationdb.FDBError
- withData(double[]) - Method in class com.apple.foundationdb.linear.DoubleRealVector
- withData(double[]) - Method in class com.apple.foundationdb.linear.FloatRealVector
- withData(double[]) - Method in class com.apple.foundationdb.linear.HalfRealVector
- withData(double[]) - Method in interface com.apple.foundationdb.linear.RealVector
- withData(double[]) - Method in class com.apple.foundationdb.rabitq.EncodedRealVector
- wrap(AsyncIterator<T>) - Static method in interface com.apple.foundationdb.async.AsyncPeekIterator
-
Wrap an
AsyncIteratorwith anAsyncPeekIterator. - wrap(AsyncIterator<T>, Consumer<T>) - Static method in interface com.apple.foundationdb.async.AsyncPeekCallbackIterator
-
Wrap an
AsyncIteratorwith anAsyncPeekCallbackIterator.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form