A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- AbstractEdge(String, Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractEdge
- AbstractEdge(Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractEdge
- AbstractNode(Object, String) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractNode
- AbstractNode(Object, String, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractNode
- 
Overloaded constructor.
- AbstractPlannerGraph<N extends AbstractPlannerGraph.AbstractNode,E extends AbstractPlannerGraph.AbstractEdge> - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
The planner graph class.
- AbstractPlannerGraph(N, Network<N, E>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph
- 
Protected constructor.
- AbstractPlannerGraph.AbstractEdge - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Edge class.
- AbstractPlannerGraph.AbstractNode - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Node class functioning as parent for all nodes in the network.
- AbstractPlannerGraph.PlannerGraphBuilder<N extends AbstractPlannerGraph.AbstractNode,E extends AbstractPlannerGraph.AbstractEdge,B extends AbstractPlannerGraph<N,E>> - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Builder class for planner graph.
- accept(RecordQueryPlannerSubstitutionVisitor) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.AutoContinuingCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.ChainedCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.ConcatCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.EmptyCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.FilterCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.FlatMapPipelinedCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.FutureCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.LazyCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.ListCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.MapCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.MapWhileCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.OrElseCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.RowLimitedCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.SkipCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- accept(RecordCursorVisitor) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Accept a visit from hierarchical visitor, which implementsRecordCursorVisitor.
- acceptPropertyVisitor(PlannerProperty<U>) - Method in interface com.apple.foundationdb.record.query.plan.temp.ExpressionRef
- acceptPropertyVisitor(PlannerProperty<U>) - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- acceptPropertyVisitor(PlannerProperty<U>) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- acceptPropertyVisitor(PlannerProperty<U>) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- 
Allow the computation ofPlannerPropertys across the quantifiers in the data flow graph.
- acceptPropertyVisitor(PlannerProperty<U>) - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpression
- 
Apply the given property visitor to this planner expression and its children.
- ACTUAL_COLUMN_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
- ACTUAL_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- add(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- add(KeyValue) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- add(StoreTimer.Counter) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer.Counter
- 
Add the value of one counter into another counter.
- add(FDBStoredSizes) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- add(String) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Adds the constant value for subdirectorydirNameto the directory path.
- add(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- add(String, Object) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Adds avaluefor a specific subdirectorydirNameto the directory path.
- add(String, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- add(T) - Method in class com.apple.foundationdb.record.query.plan.temp.RelationalExpressionPointerSet
- addAfterCommit(FDBRecordContext.AfterCommit) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Adds code to be executed immediately following a successful commit.
- addAll(ScanComparisons) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons.Builder
- addAll(RelationalExpressionPointerSet<T>) - Method in class com.apple.foundationdb.record.query.plan.temp.RelationalExpressionPointerSet
- addCommitCheck(FDBRecordContext.CommitCheckAsync) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Add aFDBRecordContext.CommitCheckAsyncto be performed beforeFDBRecordContext.commit()finishes.
- addCommitCheck(CompletableFuture<Void>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Add a check to be completed beforeFDBRecordContext.commit()finishes.
- addComparandToList(List<Object>, Comparisons.Comparison, FDBRecordStoreBase<?>, EvaluationContext) - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- addComparisonRange(ComparisonRange) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons.Builder
- addConflictForSubspace(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- addConstituent(C) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- 
Add a new constituent.
- addConstituent(RecordTypeBuilder) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- 
Add a new constituent with a correlation name that is the same as the record type name.
- addConstituent(String) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- 
Add a new constituent with a correlation name that is the same as the record type name.
- addConstituent(String, RecordTypeBuilder) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- 
Add a new constituent by name.
- addConstituent(String, RecordTypeBuilder, boolean) - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder
- 
Add a new constituent by name.
- addConstituent(String, String) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- 
Add a new constituent by name.
- addCoveringField(KeyExpression, AvailableFields.FieldData, IndexKeyValueToPartialRecord.Builder) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields
- addDefaultUnionIfMissing(Descriptors.FileDescriptor) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
- 
Add a default union to the given records descriptor if missing.
- addDefaultUnionIfMissing(Descriptors.FileDescriptor, Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
- 
Creates a default union descriptor for the given file descriptor if missing.
- addDependencies(Descriptors.FileDescriptor[]) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Adds dependencies to be used for loading theRecordMetaDatafrom a meta-data proto.
- addDependency(Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Adds a dependency to the list of dependencies.
- addDependentSource(Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.Source
- addEdge(N, N, E) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.PlannerGraphBuilder
- addedRangeWithKey(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- addedRangeWithKey(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- addedRangeWithKey(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Whether this key has been added to some range within theRangeSetassociated with this index.
- addEqualityComparison(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons.Builder
- addField(RecordMetaDataProto.MetaData.Builder, String, DescriptorProtos.FieldDescriptorProto) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
- 
Add a field to a record type.
- addField(String, IndexKeyValueToPartialRecord.TupleSource, int) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
- addFormerIndex(FormerIndex) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- addGraph(AbstractPlannerGraph<N, E>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.PlannerGraphBuilder
- addIncrementLevelKey(Transaction, byte[], int, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.InstrumentedRankedSet
- addIndex(RecordTypeIndexesBuilder, Index) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Adds a new index.
- addIndex(String, Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Add a new index to the record meta-data.
- addIndex(String, Index) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Adds a new index.
- addIndex(String, String) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Adds a new index on a single field.
- addIndex(String, String, KeyExpression) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Add a new index to the record meta-data.
- addIndex(String, String, KeyExpression) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Adds a new index.
- addIndex(String, String, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Add a new index to the record meta-data.
- addIndex(String, String, String) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Adds a new index.
- addIndexAsync(String, Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Add a new index to the record meta-data asynchronously.
- addIndexAsync(String, String, KeyExpression) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Add a new index to the record meta-data asynchronously.
- addIndexAsync(String, String, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Add a new index to the record meta-data asynchronously.
- addInequalityComparison(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons.Builder
- addInsertLevelKey(Transaction, byte[], int) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.InstrumentedRankedSet
- addJoin(String, KeyExpression, String, KeyExpression) - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder
- 
Add a new join.
- addJoin(String, String, String, String) - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder
- 
Add a new join.
- addJoinedRecordType(String) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Add a new joined record type.
- addKeyAndValue(Object, Object) - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- addKeysAndValues(List<Object>) - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- addKeysAndValues(Map<?, ?>) - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- addLeaderboard(int, long, long, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- addLeaderboard(TimeWindowLeaderboard) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- addLevelZeroKey(Transaction, byte[], int, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.InstrumentedRankedSet
- addLogInfo(Object...) - Method in exception com.apple.foundationdb.record.LoggableTimeoutException
- addLogInfo(Object...) - Method in exception com.apple.foundationdb.record.RecordCoreException
- addLogInfo(String, Object) - Method in exception com.apple.foundationdb.record.LoggableTimeoutException
- addLogInfo(String, Object) - Method in exception com.apple.foundationdb.record.provider.common.RecordSerializationException
- addLogInfo(String, Object) - Method in exception com.apple.foundationdb.record.RecordCoreException
- addMultiTypeIndex(List<? extends RecordTypeIndexesBuilder>, Index) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Adds a new index that contains multiple record types.
- addMultiTypeIndex(List<String>, Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Add a new index to the record meta-data that contains multiple record types.
- addMultiTypeIndexAsync(List<String>, Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Add a new index to the record meta-data that contains multiple record types asynchronously.
- addNestedRecordType(RecordMetaDataProto.MetaData.Builder, DescriptorProtos.DescriptorProto) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
- 
Add a newNESTEDrecord type to the meta-data.
- addNode(N) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.PlannerGraphBuilder
- addOtherChild(B, C) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorContinuation
- 
Fill in the Protobuf builder with the information for a child other than the first or second child.
- addPostCommit(FDBRecordContext.PostCommit) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Install an anonymous post-commit hook.
- addPostCommit(String, FDBRecordContext.PostCommit) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Adds a new post-commit hook.
- addReadConflictKey(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- addReadConflictRange(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- addRebuildRecordCountsJob(List<CompletableFuture<Void>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- addRecordReadConflict(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- addRecordReadConflict(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Add a read conflict as if one had read the record with the given primary key.
- addRecordReadConflict(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- addRecordType(RecordMetaDataProto.MetaData.Builder, DescriptorProtos.DescriptorProto, KeyExpression) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
- 
Add a new record type to the meta-data.
- addRecordType(String) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpression.Builder
- addRecordWriteConflict(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- addRecordWriteConflict(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Add a write conflict as if one had modified the record with the given primary key.
- addRecordWriteConflict(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- addRequiredMessageFields() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
- addSelectElement(Element) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpression.Builder
- addSizeLogInfo(KeyValueLogMessage) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBStoredSizes
- 
Add logging information about size information to a log message.
- addSourceValue(Source, Object) - Method in class com.apple.foundationdb.record.query.plan.temp.view.SourceEntry
- addSubdirectory(KeySpaceDirectory) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Adds a subdirectory within the directory.
- addSubDirectory(TimeWindowLeaderboardSubDirectory) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- addTupleElement(Element) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpression.Builder
- addUniquenessViolation(Tuple, Tuple, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Add a uniqueness violation within the database.
- addUniversalIndex(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Add a new index on all record types.
- addUniversalIndex(Index) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Adds a new index on all record types.
- addUniversalIndexAsync(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Add a new index on all record types.
- addVersionMutation(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Deprecated.use #addVersionMutation(MutationType, byte[], byte[]) instead
- addVersionMutation(MutationType, byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Add aSET_VERSIONSTAMPED_KEYorSET_VERSIONTSTAMPED_VALUEmutation to be run at commit time.
- addWriteConflictKey(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- addWriteConflictRange(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- adjustOrdering(PlanOrderingKey) - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
- adjustRange(EvaluationContext, TupleRange) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- adjustRange(EvaluationContext, TupleRange) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowAggregateFunction
- AFTER - com.apple.foundationdb.record.cursors.MapWhileCursor.StopContinuation
- 
Return the continuation following the record that stopped the cursor.
- AGE_SECONDS - com.apple.foundationdb.record.logging.LogMessageKeys
- AGENT - com.apple.foundationdb.record.logging.TestLogMessageKeys
- AGENTS - com.apple.foundationdb.record.logging.TestLogMessageKeys
- AGGREGATE_FUNCTION_NAME - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainer
- AggregateFunctionNotSupportedException - Exception in com.apple.foundationdb.record
- 
Exception thrown when an aggregate function is not supported.
- AggregateFunctionNotSupportedException(String, Object...) - Constructor for exception com.apple.foundationdb.record.AggregateFunctionNotSupportedException
- alias - Variable in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Builder
- AliasMap - Class in com.apple.foundationdb.record.query.plan.temp
- 
This class encapsulates mappings betweenCorrelationIdentifiers and helpers to create and maintain these mappings.
- AliasMap.Builder - Class in com.apple.foundationdb.record.query.plan.temp
- 
Builder class for theAliasMap.
- AliasMap.MatchingIdPredicate - Interface in com.apple.foundationdb.record.query.plan.temp
- 
An predicate that tests for a match between quantifiers also taking into account an equivalence maps betweenCorrelationIdentifiers.
- ALL - com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter.IndexValues
- ALL - Static variable in class com.apple.foundationdb.record.query.plan.temp.PlannerRuleSet
- ALL - Static variable in class com.apple.foundationdb.record.TupleRange
- ALL - Static variable in class com.apple.foundationdb.record.ValueRange
- ALL_AGGREGATES - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer
- ALL_FIELDS - Static variable in class com.apple.foundationdb.record.query.plan.AvailableFields
- ALL_TIME_LEADERBOARD_TYPE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- ALL_TYPES - Static variable in class com.apple.foundationdb.record.query.RecordQuery
- AllChildrenMatcher - Class in com.apple.foundationdb.record.query.plan.temp.matchers
- 
An expression children matcher that tries to match all children to a singleExpressionMatcher.
- allIndexesReadable() - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Determines whether all of the indexes in the store are currently readable.
- allMatching(ExpressionMatcher<? extends Bindable>) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.AllChildrenMatcher
- 
Get a matcher that tries to match all children with the givenExpressionMatcher.
- allocate(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
- allOf(Tuple) - Static method in class com.apple.foundationdb.record.TupleRange
- 
Create aTupleRangeover all keys beginning with a givenTuple.
- ALLOWED_FOR_QUERY_OPTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
If"false", the index is not considered for use in queries, even if enabled, unless requested explicitly.
- allowsIndexRebuilds() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Whether this validator allows new meta-data that require existing indexes to be rebuilt.
- allowsIndexRebuilds() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Whether the validator will allow changes to indexes that require rebuilds.
- allowsMissingFormerIndexNames() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Whether this validator allows former indexes to drop the name of the index they replace.
- allowsMissingFormerIndexNames() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Whether the validator will allow former indexes to drop the name of the index they replace.
- allowsNegative() - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation
- 
Determine whether this type allows negative values.
- allowsNegative() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- allowsNoSinceVersion() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Whether this validator allows new record types to not declare a "since version".
- allowsNoSinceVersion() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Whether the validator will allow new record types to not declare a "since version".
- allowsNoVersionChange() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Whether this validator allows the evolved meta-data to have the same version as the old meta-data.
- allowsNoVersionChange() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Whether the validator will allow the evolved meta-data to have same version as the old meta-data.
- allowsOlderFormerIndexAddedVersions() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Whether this validator allows former indexes to set their added version to something that is older than necessary.
- allowsOlderFormerIndexAddedVersions() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Whether the validator will allow former indexes to set their added version to something that is older than necessary.
- allowsUnsplitToSplit() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Whether this validator allows the meta-data to begin to split long records.
- allowsUnsplitToSplit() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Get whether the validator will allow the meta-data to begin to split long records.
- allSatisfied() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Determine if the whole filter has been satisfied.
- ALWAYS - com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.Rebuild
- and(QueryComponent, QueryComponent, QueryComponent...) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
Check that a set of components all evaluate to true for a given record.
- and(List<? extends QueryComponent>) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
Check that a set of components all evaluate to true for a given record.
- AndComponent - Class in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentthat is satisfied when all of its child components are satisfied.
- AndComponent(List<QueryComponent>) - Constructor for class com.apple.foundationdb.record.query.expressions.AndComponent
- AndOrComponent - Class in com.apple.foundationdb.record.query.expressions
- 
The common base class for BooleanAndandOrquery components.
- AndOrComponent(List<QueryComponent>) - Constructor for class com.apple.foundationdb.record.query.expressions.AndOrComponent
- AndOrPredicate - Class in com.apple.foundationdb.record.query.predicates
- 
Common base class for predicates with many children, such asAndPredicateandOrPredicate.
- AndOrPredicate(List<QueryPredicate>) - Constructor for class com.apple.foundationdb.record.query.predicates.AndOrPredicate
- AndPredicate - Class in com.apple.foundationdb.record.query.predicates
- 
AQueryPredicatethat is satisfied when all of its child components are; For tri-valued logic: If all children aretrue, thentrue. If any child isfalse, thenfalse. Elsenull.
- AndPredicate(List<QueryPredicate>) - Constructor for class com.apple.foundationdb.record.query.predicates.AndPredicate
- andThen(Function<? super R, ? extends W>) - Method in interface com.apple.foundationdb.record.util.TriFunction
- 
Returns a composed function that first applies this function to its input, and then applies theafterfunction to the result.
- ANY - Static variable in class com.apple.foundationdb.record.query.plan.temp.matchers.AnyChildrenMatcher
- ANY_VALUE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
The value of a directory that may contain any value of the type specified for the directory (as opposed to a directory that is restricted to a specific constant value).
- AnyChildMatcher - Class in com.apple.foundationdb.record.query.plan.temp.matchers
- 
An expression children matcher that tries to match any child to the givenExpressionMatcher, producing a stream of bindings that is the concatenation of the (possibly empty) streams of bindings from attempting to match each child to the given matcher.
- AnyChildrenMatcher - Class in com.apple.foundationdb.record.query.plan.temp.matchers
- 
A children matcher that matches any set of children.
- AnyChildWithRestMatcher - Class in com.apple.foundationdb.record.query.plan.temp.matchers
- 
An expression matcher that tries to match any child to the givenExpressionMatcherwhile providing aReferenceMatcherbinding to all other children.
- anyMatching(ExpressionMatcher<? extends Bindable>) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.AnyChildMatcher
- 
Get a matcher that tries to match any child with the givenExpressionMatcher.
- anyMatchingWithRest(ExpressionMatcher<? extends QueryPredicate>, ExpressionMatcher<QueryPredicate>) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.AnyChildWithRestMatcher
- anyRef() - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.ReferenceMatcher
- 
Return a newReferenceMatcherinstance.
- anyTopologicalOrderPermutation(Set<T>, Function<T, Set<T>>) - Static method in class com.apple.foundationdb.record.query.plan.temp.TopologicalSort
- 
Create a correct topological ordering based on a set and a function describing the depends-on relationships between items in the given set.
- append(KeyValue) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SingleKeyUnsplitter
- append(Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
Creates a new key by appending another key to this one.
- append(ScanComparisons) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- append(RecordCursorResult<KeyValue>) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- appendScanDetails(StringBuilder) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- appendValue(StringBuilder, Object) - Static method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- apply(Throwable, StoreTimer.Event) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabase.ExceptionMapper
- apply(T, U, V) - Method in interface com.apple.foundationdb.record.util.TriFunction
- 
Applies this function to the given arguments.
- applyVisitors(RecordQueryPlan, RecordMetaData, PlannableIndexTypes, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.visitor.RecordQueryPlannerSubstitutionVisitor
- areAssertionsEnabled() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Returns whether or not internal correctness assertions are enabled.
- areAssertionsEnabled() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Return whether or not correctness assertions will enabled for the context.
- areEqual(Object, Object) - Static method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- ARGUMENT_INDEX - com.apple.foundationdb.record.logging.LogMessageKeys
- arguments - Variable in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- asBuilder() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Convert this validator into a builder.
- asBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- asBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- asBuilder() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
- asCause(CompletionException) - Static method in class com.apple.foundationdb.record.logging.CompletionExceptionLogHelper
- 
Return the cause of the given exception and also arrange for the original exception to be in the suppressed chain.
- asCause(ExecutionException) - Static method in class com.apple.foundationdb.record.logging.CompletionExceptionLogHelper
- 
Return the cause of the given exception and also arrange for the original exception to be in the suppressed chain.
- asIterator() - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Return a view of this cursor as aRecordCursorIterator.
- asList() - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Return the entire stream of records as an asynchronous list.
- asOr() - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
- asScanProperties(boolean) - Method in class com.apple.foundationdb.record.ExecuteProperties
- assignedFormerPrefixes - Variable in class com.apple.foundationdb.record.metadata.MetaDataValidator
- assignedPrefixes - Variable in class com.apple.foundationdb.record.metadata.MetaDataValidator
- AsyncIteratorCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that returns the elements of anAsyncIterator.
- AsyncIteratorCursor(Executor, AsyncIterator<T>) - Constructor for class com.apple.foundationdb.record.cursors.AsyncIteratorCursor
- AsyncLoadingCache<K,V> - Class in com.apple.foundationdb.record
- 
A cache for retaining the result of some asynchronous operation up until some expiration time.
- AsyncLoadingCache(long) - Constructor for class com.apple.foundationdb.record.AsyncLoadingCache
- AsyncLoadingCache(long, long) - Constructor for class com.apple.foundationdb.record.AsyncLoadingCache
- AsyncLoadingCache(long, long, long) - Constructor for class com.apple.foundationdb.record.AsyncLoadingCache
- asyncToSync(StoreTimer.Wait, CompletableFuture<T>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- asyncToSync(StoreTimer.Wait, CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- asyncToSync(StoreTimer.Wait, CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- asyncToSync(StoreTimer.Wait, CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Wait for an asynchronous task to complete.
- asyncToSync(StoreTimer.Wait, CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- asyncToSync(FDBStoreTimer, StoreTimer.Wait, CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- asyncToSync(CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Deprecated.
- AtomicMutation - Interface in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
The particular operation to be performed by anAtomicMutationIndexMaintainerindex.
- AtomicMutation.Standard - Enum in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
The atomic mutations implemented straightforwardly by the FDB API.
- AtomicMutationIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
An index that maintains an aggregate value in a low-contention way.
- AtomicMutationIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- AtomicMutationIndexMaintainer(IndexMaintainerState, AtomicMutation) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- AtomicMutationIndexMaintainerFactory - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
A factory forAtomicMutationIndexMaintainerindexes.
- AtomicMutationIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainerFactory
- AtomKeyExpression - Interface in com.apple.foundationdb.record.metadata.expressions
- 
An "atom expression" is one that has semantic meaning; that is, it presence is significant to the meaning of the expression.
- Attribute - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Basic interface for all attributes ofAbstractPlannerGraph.AbstractNodeas well asAbstractPlannerGraph.AbstractEdge.
- Attribute.CommonAttribute - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Interface for attributes ofAbstractPlannerGraph.AbstractNodeas well asAbstractPlannerGraph.AbstractEdgethat are used to serialize to GML or to DOT.
- Attribute.DotAttribute - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Interface for attributes ofAbstractPlannerGraph.AbstractNodeas well asAbstractPlannerGraph.AbstractEdgethat are used to serialize to DOT.
- Attribute.GmlAttribute - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Basic interface all attributes ofAbstractPlannerGraph.AbstractNodeas well asAbstractPlannerGraph.AbstractEdgethat are use to serialize to GML.
- Attribute.InvisibleAttribute - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Interface for attributes ofAbstractPlannerGraph.AbstractNodeas well asAbstractPlannerGraph.AbstractEdgethat are used to neither serialize to GML or to DOT.
- AutoContinuingCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that can iterate over a cursor across transactions.
- AutoContinuingCursor(FDBDatabaseRunner, BiFunction<FDBRecordContext, byte[], RecordCursor<T>>) - Constructor for class com.apple.foundationdb.record.cursors.AutoContinuingCursor
- 
Creates a newAutoContinuingCursor.
- AvailableFields - Class in com.apple.foundationdb.record.query.plan
- 
Represents a subset of the fields available in a stream of records, including partial records.
- AvailableFields.FieldData - Class in com.apple.foundationdb.record.query.plan
- 
A pair of a tuple source (key or value) and an index within that tuple source.
- AVG_POSITIONS - com.apple.foundationdb.record.logging.LogMessageKeys
- AVG_TOKEN_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
B
- BAD_INDEX_ENTRY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of times that an index entry does not point to a valid record.
- BASE_DATA - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeIcon
- BASE_DATA - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- BaseCursor<T> - Interface in com.apple.foundationdb.record.cursors
- 
A tag interface for "base" cursors which read records directly from the database.
- BaseField - Class in com.apple.foundationdb.record.query.expressions
- 
An abstract base class for field-likeQueryComponents that involve predicates on one particular record field, as specified by theBaseField.fieldNamemember.
- BaseField(String) - Constructor for class com.apple.foundationdb.record.query.expressions.BaseField
- BaseKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
Base class to provide some common logic shared between most expression implementations.
- BaseKeyExpression() - Constructor for class com.apple.foundationdb.record.metadata.expressions.BaseKeyExpression
- BaseKeyExpression.IllegalSubKeyException - Exception in com.apple.foundationdb.record.metadata.expressions
- 
An exception that is thrown whenBaseKeyExpression.getSubKey(int, int)is used incorrectly.
- BaseKeyExpression.UnsplittableKeyExpressionException - Exception in com.apple.foundationdb.record.metadata.expressions
- 
An exception indicating that the key expression is not splittable.
- BaseNestedField - Class in com.apple.foundationdb.record.query.expressions
- 
An abstract base class for allQueryComponents that represent a query of a nested record type.
- BaseNestedField(String, QueryComponent) - Constructor for class com.apple.foundationdb.record.query.expressions.BaseNestedField
- BATCH - com.apple.foundationdb.record.provider.foundationdb.FDBTransactionPriority
- 
The priority level that should be used for batch operations.
- BATCH_GET_READ_VERSION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken to get a read version for batch priority transactions.
- BATCH_SIZE - com.apple.foundationdb.record.logging.TestLogMessageKeys
- BEFORE - com.apple.foundationdb.record.cursors.MapWhileCursor.StopContinuation
- 
Return the continuation before the record that stopped the cursor.
- BEGIN - com.apple.foundationdb.record.logging.TestLogMessageKeys
- beginRead() - Method in class com.apple.foundationdb.record.MutableRecordStoreState
- 
Begin using this record store state.
- beginRead() - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Begin using this record store state.
- beginWrite() - Method in class com.apple.foundationdb.record.MutableRecordStoreState
- 
Begin modifying this record store state.
- between(Tuple, Tuple) - Static method in class com.apple.foundationdb.record.TupleRange
- 
Create aTupleRangeover all keys between the givenTuples.
- BiFunctionBuilder(String, BiFunction<String, KeyExpression, FunctionKeyExpression>) - Constructor for class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression.BiFunctionBuilder
- Bindable - Interface in com.apple.foundationdb.record.query.plan.temp
- 
A planner type that supports rule binding.
- bindAggregateFunction(FDBRecordStore, IndexAggregateFunction, List<String>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- BindingFunctions - Class in com.apple.foundationdb.record.query.plan.planning
- 
Helper methods for manipulating parameter values passed inBindings.
- bindingName - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- bindingName(String) - Method in enum com.apple.foundationdb.record.Bindings.Internal
- bindings - Variable in class com.apple.foundationdb.record.EvaluationContextBuilder
- Bindings - Class in com.apple.foundationdb.record
- 
A map of bound parameter values passed to query evaluation.
- Bindings() - Constructor for class com.apple.foundationdb.record.Bindings
- Bindings.Builder - Class in com.apple.foundationdb.record
- 
A builder forBindings.
- Bindings.Internal - Enum in com.apple.foundationdb.record
- 
Bindings slots used internally by plan operators.
- bindTo(ExpressionMatcher<? extends Bindable>) - Method in interface com.apple.foundationdb.record.query.plan.temp.Bindable
- 
Attempt to match the matcher to this bindable object.
- bindTo(ExpressionMatcher<? extends Bindable>) - Method in interface com.apple.foundationdb.record.query.plan.temp.ExpressionRef
- 
Try to bind the given matcher to this reference.
- bindTo(ExpressionMatcher<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- bindTo(ExpressionMatcher<? extends Bindable>) - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpression
- 
Matches a matcher expression to an expression tree rooted at this node, adding to some existing bindings.
- bindTo(ExpressionMatcher<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.predicates.AndOrPredicate
- bindTo(ExpressionMatcher<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- bindTo(ExpressionMatcher<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.predicates.NotPredicate
- bindWithin(ExpressionMatcher<? extends Bindable>) - Method in interface com.apple.foundationdb.record.query.plan.temp.ExpressionRef
- 
Try to bind the given matcher to the members of this reference.
- bindWithin(ExpressionMatcher<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- bindWithin(ExpressionMatcher<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- BITMAP_VALUE - Static variable in class com.apple.foundationdb.record.FunctionNames
- BITMAP_VALUE - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
An index storing bitmaps of which records meet a specific condition.
- BITMAP_VALUE_ENTRY_SIZE_OPTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
Size of each position bitmap forIndexTypes.BITMAP_VALUEindexes.
- BitmapValueIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
An index maintainer for storing bitmaps of which records meet a specific condition.
- BitmapValueIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainer
- BitmapValueIndexMaintainerFactory - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
A factory forBitmapValueIndexMaintainer.
- BitmapValueIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainerFactory
- BLOCKING_FOR_FUTURE_MESSAGE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Message that is logged when one joins on a future and expects it to be completed, but it is not yet done.
- BLOCKING_IN_ASYNC_CONTEXT_MESSAGE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Text of message that is logged or exception that is thrown when a blocking API call (asyncToSync(),FDBDatabase.join(CompletableFuture), orFDBDatabase.get(CompletableFuture)) is called from within aCompletableFuturecompletion state.
- BLOCKING_RETURNING_ASYNC_MESSAGE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Message that is logged when it is detected that a blocking call is being made in a method that may be producing a future (specifically a method that ends in "Async").
- BlockingInAsyncDetection - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
Indicates whetherFDBDatabase.asyncToSync(FDBStoreTimer, FDBStoreTimer.Wait, java.util.concurrent.CompletableFuture)orFDBRecordContext.asyncToSync(FDBStoreTimer.Wait, java.util.concurrent.CompletableFuture)should attempt to detect when it is being called from an asynchronous context and, if so, how it should react to this fact.
- BlockingInAsyncException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown whenasyncToSyncdetects that it is being called from within an asynchronous context.
- BlockingInAsyncException(String) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncException
- BlockingInAsyncException(String, Throwable) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncException
- BOOLEAN - com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- BooleanNormalizer - Class in com.apple.foundationdb.record.query.plan.planning
- 
A normalizer of a tree ofQueryComponentpredicates into disjunctive normal form.
- build() - Method in class com.apple.foundationdb.record.Bindings.Builder
- build() - Method in class com.apple.foundationdb.record.EvaluationContextBuilder
- 
Construct anEvaluationContextwith updated bindings.
- build() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- build() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Create aMetaDataEvolutionValidatorusing the options specified through this builder.
- build() - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
- 
Construct aTransformedRecordSerializerfrom the parameters specified by this builder.
- build() - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- 
Construct aTransformedRecordSerializerJCEfrom the parameters specified by this builder.
- build() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Create anFDBRecordContextConfigfrom this builder.
- build() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- build() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Build the record store.
- build() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- build() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- build() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
- build() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Build anOnlineIndexer.
- build() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config.Builder
- 
Build aOnlineIndexer.Config.
- build() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
- build() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
- build() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons.Builder
- build() - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap.Builder
- build() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.PlannerGraphBuilder
- build() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.InternalPlannerGraphBuilder
- build() - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.PlannerBindings.Builder
- build() - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpression.Builder
- build() - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- build() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Build and validate meta-data.
- build(boolean) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Build and validate meta-data with specific index registry.
- build(KeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression.BiFunctionBuilder
- build(KeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression.Builder
- build(ExpressionRef<? extends RecordQueryPlan>) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical.PhysicalBuilder
- build(ExpressionRef<? extends RelationalExpression>) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Existential.ExistentialBuilder
- build(ExpressionRef<? extends RelationalExpression>) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.ForEach.ForEachBuilder
- build(RecordMetaData) - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder.JoinConstituent
- build(RecordMetaData) - Method in class com.apple.foundationdb.record.metadata.RecordTypeBuilder
- build(RecordMetaData) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder.Constituent
- build(RecordMetaDataProto.MetaData) - Static method in class com.apple.foundationdb.record.RecordMetaData
- 
Factory method to deserialize a record meta-data proto.
- build(RecordMetaData, Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder
- build(RecordMetaData, Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- build(Descriptors.FileDescriptor) - Static method in class com.apple.foundationdb.record.RecordMetaData
- build(String, Object...) - Static method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- build(Map<String, JoinedRecordType.JoinConstituent>) - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder.Join
- BUILD_IF_DISABLED - com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
- 
Only build if the index is disabled.
- BUILD_IF_DISABLED_CONTINUE_BUILD_IF_WRITE_ONLY - com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
- 
Build if the index is disabled; Continue build if the index is write-only.
- BUILD_IF_DISABLED_REBUILD_IF_WRITE_ONLY - com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
- 
Build if the index is disabled; Rebuild if the index is write-only.
- buildBaseSource() - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpression.Builder
- buildDescriptor(DescriptorProtos.FileDescriptorProto.Builder) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- buildEndpoints() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Builds (with a retry loop) the endpoints of an index.
- buildEndpoints(FDBRecordStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Builds (transactionally) the endpoints of an index.
- builder() - Static method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
- builder() - Static method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- builder() - Static method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpression
- builder(int) - Static method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- builder(PlannerGraph.Node) - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph
- Builder() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- Builder() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- Builder() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- Builder() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config.Builder
- Builder() - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
- Builder() - Constructor for class com.apple.foundationdb.record.query.plan.ScanComparisons.Builder
- Builder() - Constructor for class com.apple.foundationdb.record.query.plan.temp.matchers.PlannerBindings.Builder
- Builder() - Constructor for class com.apple.foundationdb.record.query.plan.temp.Quantifier.Builder
- Builder() - Constructor for class com.apple.foundationdb.record.query.RecordQuery.Builder
- Builder(RecordSerializer<M>) - Constructor for class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
- Builder(RecordSerializer<M>) - Constructor for class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- Builder(FDBRecordStore) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- Builder(FDBRecordStore.Builder) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- Builder(FDBTypedRecordStore.Builder<M>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- Builder(FDBTypedRecordStore<M>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- Builder(RecordQueryPlannerConfiguration) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
- Builder(RecordQuery) - Constructor for class com.apple.foundationdb.record.query.RecordQuery.Builder
- Builder(String) - Constructor for class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression.Builder
- buildIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Builds an index across multiple transactions.
- buildIndex(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Builds an index across multiple transactions.
- buildIndexAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Builds an index across multiple transactions.
- buildIndexKeyValueToPartialRecord(RecordType) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields
- buildMetaData(RecordMetaDataProto.MetaData, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- buildMetaData(RecordMetaDataProto.MetaData, boolean, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- buildOptions(List<RecordMetaDataProto.Index.Option>, boolean) - Static method in class com.apple.foundationdb.record.metadata.Index
- buildPrimaryKey() - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- buildPrimaryKeyComponentPositions(KeyExpression, KeyExpression) - Static method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- buildRange(Key.Evaluated, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Builds (with a retry loop) the index by adding records with primary keys within the given range.
- buildRange(FDBRecordStore, Key.Evaluated, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Builds (transactionally) the index by adding records with primary keys within the given range.
- buildUnbuiltRange(FDBRecordStore, Key.Evaluated, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Builds (transactionally) the index by adding records with primary keys within the given range.
- BY_GROUP - Static variable in class com.apple.foundationdb.record.IndexScanType
- BY_RANK - Static variable in class com.apple.foundationdb.record.IndexScanType
- BY_TEXT_TOKEN - Static variable in class com.apple.foundationdb.record.IndexScanType
- BY_TIME_WINDOW - Static variable in class com.apple.foundationdb.record.IndexScanType
- BY_VALUE - Static variable in class com.apple.foundationdb.record.IndexScanType
- BYTE_LIMIT_REACHED - com.apple.foundationdb.record.RecordCursor.NoNextReason
- 
The limit on the number of bytes to scan was reached.
- ByteArrayContinuation - Class in com.apple.foundationdb.record
- 
A shim to wrap old-style byte array continuations.
- BYTES - com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- BYTES_DELETED - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.CountAggregates
- 
The number of bytes deleted.
- BYTES_READ - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of bytes read.
- BYTES_WRITTEN - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of bytes written, not including deletes.
- ByteScanLimiter - Interface in com.apple.foundationdb.record
- 
Track the number of bytes scanned up to some limit, after which record scans should not be allowed.
- ByteScanLimiterFactory - Class in com.apple.foundationdb.record
- 
A factory that produces implementations ofByteScanLimiters.
- ByteStringBoundException(byte[]) - Constructor for exception com.apple.foundationdb.record.TupleRange.ByteStringBoundException
C
- CACHEABLE_STATE_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- CACHED_STATE - com.apple.foundationdb.record.logging.LogMessageKeys
- CACHED_VERSION - com.apple.foundationdb.record.logging.LogMessageKeys
- CALLING_CLASS - com.apple.foundationdb.record.logging.LogMessageKeys
- CALLING_LINE - com.apple.foundationdb.record.logging.LogMessageKeys
- CALLING_METHOD - com.apple.foundationdb.record.logging.LogMessageKeys
- canAppend() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexBunchedSerializer
- 
Returntrueas this serialization format supports appending.
- cancel() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- cancel() - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
- cancel() - Method in class com.apple.foundationdb.record.RecordCursorIterator
- canCorrelate() - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpression
- 
Returns if this expression can be the anchor of a correlation.
- canDeleteWhere(IndexMaintainerState, QueryToKeyMatcher.Match, Key.Evaluated) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- canDeleteWhere(QueryToKeyMatcher, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- canDeleteWhere(QueryToKeyMatcher, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- canDeleteWhere(QueryToKeyMatcher, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexMaintainer
- 
Indicates whether the expression allows for this index to perform aFDBRecordStoreBase.deleteRecordsWhere(QueryComponent)operation.
- canDeleteWhere(QueryToKeyMatcher, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Get whether this index scan delete records matching a particular key query.
- canEvaluateAggregateFunction(IndexAggregateFunction) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- canEvaluateAggregateFunction(IndexAggregateFunction) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainer
- canEvaluateAggregateFunction(IndexAggregateFunction) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- canEvaluateAggregateFunction(IndexAggregateFunction) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainer
- canEvaluateAggregateFunction(IndexAggregateFunction) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- canEvaluateAggregateFunction(IndexAggregateFunction) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainer
- canEvaluateAggregateFunction(IndexAggregateFunction) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Get whether this index can be used to evaluate the given aggregate function.
- canEvaluateAggregateFunction(IndexAggregateFunction) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- canEvaluateRecordFunction(IndexRecordFunction<?>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- canEvaluateRecordFunction(IndexRecordFunction<?>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainer
- canEvaluateRecordFunction(IndexRecordFunction<?>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- canEvaluateRecordFunction(IndexRecordFunction<?>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Returntrueif this index be used to evaluate the given record function.
- canEvaluateRecordFunction(IndexRecordFunction<?>) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- CascadesCostModel - Class in com.apple.foundationdb.record.query.plan.temp
- 
A comparator implementing the current heuristic cost model for theCascadesPlanner.
- CascadesCostModel(PlanContext) - Constructor for class com.apple.foundationdb.record.query.plan.temp.CascadesCostModel
- CascadesPlanner - Class in com.apple.foundationdb.record.query.plan.temp
- 
A Cascades-style query planner that converts aRecordQueryto aRecordQueryPlan, possibly using secondary indexes defined in aRecordMetaDatato execute the query efficiently.
- CascadesPlanner(RecordMetaData, RecordStoreState) - Constructor for class com.apple.foundationdb.record.query.plan.temp.CascadesPlanner
- CascadesPlanner(RecordMetaData, RecordStoreState, PlannerRuleSet) - Constructor for class com.apple.foundationdb.record.query.plan.temp.CascadesPlanner
- CascadesRuleCall - Class in com.apple.foundationdb.record.query.plan.temp
- 
A rule call implementation for theCascadesPlanner.
- CascadesRuleCall(PlanContext, PlannerRule<? extends RelationalExpression>, GroupExpressionRef<RelationalExpression>, PlannerBindings) - Constructor for class com.apple.foundationdb.record.query.plan.temp.CascadesRuleCall
- ChainedCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that iterates over a set of data that is dynamically generated a single value at a time.
- ChainedCursor(FDBRecordContext, Function<Optional<T>, CompletableFuture<Optional<T>>>, Function<T, byte[]>, Function<byte[], T>, byte[], ScanProperties) - Constructor for class com.apple.foundationdb.record.cursors.ChainedCursor
- 
Creates aChainedCursor.
- ChainedCursor(Function<Optional<T>, CompletableFuture<Optional<T>>>, Function<T, byte[]>, Function<byte[], T>, byte[], Executor) - Constructor for class com.apple.foundationdb.record.cursors.ChainedCursor
- 
Creates a newChainedCursor.
- check() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext.CommitCheck
- 
Complete the check.
- check(boolean) - Static method in class com.apple.foundationdb.record.cursors.IllegalContinuationAccessChecker
- CHECK_INDEX_UNIQUENESS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent checking an index for duplicate entries to preserve uniqueness.
- CHECK_VERSION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time in thecheckVersioncall.
- checkAsync() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext.CommitCheck
- checkAsync() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext.CommitCheckAsync
- 
Complete the check.
- checkEventNameUniqueness(Stream<StoreTimer.Event>) - Static method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Confirm that there is no naming conflict among the event names that will be used.
- checkKeyValueSizes(FDBIndexableRecord<M>, Tuple, Tuple, byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- checkNextStateTimeout(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- checkOverlappingChanged() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer.UpdateState
- checkPossiblyRebuildRecordCounts(RecordMetaData, RecordMetaDataProto.DataStoreInfo.Builder, List<CompletableFuture<Void>>, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- checkStoreHeader(RecordMetaDataProto.DataStoreInfo, FDBRecordContext, SubspaceProvider, Subspace, FDBRecordStoreBase.StoreExistenceCheck) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- checkUniqueness(FDBIndexableRecord<M>, IndexEntry) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- checkUserVersion(int, int, RecordMetaDataProvider) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.UserVersionChecker
- 
Check the user version.
- checkVersion(FDBRecordStoreBase.UserVersionChecker, FDBRecordStoreBase.StoreExistenceCheck) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Checks the meta-data version key of the record store and compares it to the version of the local meta-data object.
- child - Variable in class com.apple.foundationdb.record.query.predicates.NotPredicate
- CHILD_COUNT - com.apple.foundationdb.record.logging.LogMessageKeys
- CHILD_FILTER - com.apple.foundationdb.record.logging.LogMessageKeys
- childBuilder() - Method in class com.apple.foundationdb.record.Bindings
- childBuilder() - Method in class com.apple.foundationdb.record.EvaluationContext
- 
Construct a builder from this context.
- childComponent - Variable in class com.apple.foundationdb.record.query.expressions.BaseNestedField
- cipherName - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- cipherName - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
- claimLocalVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Claims a local version that is unique within a single transaction.
- clear() - Method in class com.apple.foundationdb.record.AsyncLoadingCache
- clear() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- clear() - Method in interface com.apple.foundationdb.record.provider.foundationdb.storestate.FDBRecordStoreStateCache
- 
Remove all entries from the cache.
- clear() - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCache
- clear() - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.PassThroughRecordStoreStateCache
- clear() - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.ReadVersionRecordStoreStateCache
- clear() - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- clear() - Method in class com.apple.foundationdb.record.query.plan.temp.RelationalExpressionPointerSet
- clear(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- clear(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- clear(Range) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- clearAndMarkIndexWriteOnly(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Prepare an index for rebuilding by clearing any existing data and marking the index as write-only.
- clearAndMarkIndexWriteOnly(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- clearAsyncToSyncTimeout() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- clearCaches() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- clearEncryption() - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- 
Clears a previously specified key and provider that might have been passed to thisBuilder.
- clearForwardDirectoryCache() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- clearHeaderUserField(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Clear the value of a user-settable field in the store header.
- clearHeaderUserFieldAsync(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Clear the value of a user-settable field in the store header.
- clearLatencyInjector() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Removes any previously installed latency injector.
- clearRangeStartsWith(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- 
Deprecated.
- clearReturnedRowLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties
- clearReverseDirectoryCache() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- clearRowAndTimeLimits() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Clear the returned row limit and time limit.
- clearScannedBytesLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- clearScannedRecordsLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- clearSecureRandom() - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- 
Clears a previously set secure random number generator that might have been passed to thisBuilder.
- clearSkipAndAdjustLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Remove any skip count and adjust the limit to include enough rows that we can skip those and then apply the current limit.
- clearSkipAndLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Clear the skip and returned row limit, but no other limits.
- clearState() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- clearState() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Build a newExecutePropertieswith an empty state.
- clearStats() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
Clears all of the statistics gathered.
- cloneWithIndex(String) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- cloneWithIndex(String) - Method in class com.apple.foundationdb.record.metadata.IndexRecordFunction
- cloneWithIndex(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowAggregateFunction
- cloneWithIndex(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowRecordFunction
- cloneWithOperand(GroupingKeyExpression) - Method in class com.apple.foundationdb.record.metadata.IndexRecordFunction
- cloneWithOperand(GroupingKeyExpression) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowRecordFunction
- cloneWithOperand(KeyExpression) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- cloneWithOperand(KeyExpression) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowAggregateFunction
- close() - Method in class com.apple.foundationdb.record.cursors.AutoContinuingCursor
- close() - Method in class com.apple.foundationdb.record.cursors.ChainedCursor
- close() - Method in class com.apple.foundationdb.record.cursors.ConcatCursor
- close() - Method in class com.apple.foundationdb.record.cursors.EmptyCursor
- close() - Method in class com.apple.foundationdb.record.cursors.FilterCursor
- close() - Method in class com.apple.foundationdb.record.cursors.FlatMapPipelinedCursor
- close() - Method in class com.apple.foundationdb.record.cursors.FutureCursor
- close() - Method in class com.apple.foundationdb.record.cursors.LazyCursor
- close() - Method in class com.apple.foundationdb.record.cursors.ListCursor
- close() - Method in class com.apple.foundationdb.record.cursors.MapCursor
- close() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
- close() - Method in class com.apple.foundationdb.record.cursors.MapWhileCursor
- close() - Method in class com.apple.foundationdb.record.cursors.OrElseCursor
- close() - Method in class com.apple.foundationdb.record.cursors.RowLimitedCursor
- close() - Method in class com.apple.foundationdb.record.cursors.SkipCursor
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- close() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Close this runner.
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingDigest
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingReplicator
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- close() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- close() - Method in interface com.apple.foundationdb.record.RecordCursor
- close() - Method in class com.apple.foundationdb.record.RecordCursorIterator
- CLOSE_CONTEXT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of times a record context is closed.
- CLOSE_CONTEXT_OPEN_TOO_LONG - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of times a record context is closed because it has been open for a long time.
- CLUSTER - com.apple.foundationdb.record.logging.LogMessageKeys
- code() - Method in enum com.apple.foundationdb.record.IndexState
- 
Value corresponding to the state.
- CODE - com.apple.foundationdb.record.logging.LogMessageKeys
- CollateFunctionKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
COLLATEfunction.
- CollateFunctionKeyExpression(TextCollatorRegistry, String, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
- CollateFunctionKeyExpressionFactoryJRE - Class in com.apple.foundationdb.record.metadata.expressions
- 
Implemention ofCollateFunctionKeyExpressionusingTextCollatorRegistryJRE.
- CollateFunctionKeyExpressionFactoryJRE() - Constructor for class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpressionFactoryJRE
- CollateFunctionKeyExpressionFactoryJRE.CollateFunctionKeyExpressionJRE - Class in com.apple.foundationdb.record.metadata.expressions
- CollateFunctionKeyExpressionJRE(String, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpressionFactoryJRE.CollateFunctionKeyExpressionJRE
- COLUMN_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
- com.apple.foundationdb.record - package com.apple.foundationdb.record
- 
A record layer for FoundationDB based on Protocol Buffers.
- com.apple.foundationdb.record.cursors - package com.apple.foundationdb.record.cursors
- 
Cursor implementation classes.
- com.apple.foundationdb.record.logging - package com.apple.foundationdb.record.logging
- 
Helper classes for logging.
- com.apple.foundationdb.record.metadata - package com.apple.foundationdb.record.metadata
- 
Record meta-data structures.
- com.apple.foundationdb.record.metadata.expressions - package com.apple.foundationdb.record.metadata.expressions
- 
Record keys used in indexes and the primary storage.
- com.apple.foundationdb.record.provider.common - package com.apple.foundationdb.record.provider.common
- 
Support classes that do not depend on FoundationDB.
- com.apple.foundationdb.record.provider.common.text - package com.apple.foundationdb.record.provider.common.text
- 
Support classes for text indexing.
- com.apple.foundationdb.record.provider.foundationdb - package com.apple.foundationdb.record.provider.foundationdb
- 
Classes for FoundationDB record storage.
- com.apple.foundationdb.record.provider.foundationdb.clientlog - package com.apple.foundationdb.record.provider.foundationdb.clientlog
- 
Classes for interacting with system key client logs in record layer terms.
- com.apple.foundationdb.record.provider.foundationdb.cursors - package com.apple.foundationdb.record.provider.foundationdb.cursors
- 
Record cursors that depend on having access to an actual record store.
- com.apple.foundationdb.record.provider.foundationdb.indexes - package com.apple.foundationdb.record.provider.foundationdb.indexes
- 
Index maintainer classes.
- com.apple.foundationdb.record.provider.foundationdb.keyspace - package com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
A directory-like symbolic layout of keys in FoundationDB.
- com.apple.foundationdb.record.provider.foundationdb.layers.interning - package com.apple.foundationdb.record.provider.foundationdb.layers.interning
- 
A layer for mapping potentially long strings to and from more compact tuple elements.
- com.apple.foundationdb.record.provider.foundationdb.leaderboard - package com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Maintain leaderboard as multiple time-windowed ranked sets (so that old scores fall off).
- com.apple.foundationdb.record.provider.foundationdb.storestate - package com.apple.foundationdb.record.provider.foundationdb.storestate
- 
Classes for cachingRecordStoreStateinformation.
- com.apple.foundationdb.record.provider.foundationdb.synchronizedsession - package com.apple.foundationdb.record.provider.foundationdb.synchronizedsession
- 
Extends thecom.apple.foundationdb.synchronizedsessionpackage to support running operations in synchronized sessions withFDBDatabaseRunners andFDBRecordContexts.
- com.apple.foundationdb.record.query - package com.apple.foundationdb.record.query
- 
Classes for querying records.
- com.apple.foundationdb.record.query.expressions - package com.apple.foundationdb.record.query.expressions
- 
Classes implementing logical query expression.
- com.apple.foundationdb.record.query.plan - package com.apple.foundationdb.record.query.plan
- 
Query planner classes.
- com.apple.foundationdb.record.query.plan.bitmap - package com.apple.foundationdb.record.query.plan.bitmap
- 
Classes relating to bitmap operations overBITMAP_VALUEindex entries.
- com.apple.foundationdb.record.query.plan.planning - package com.apple.foundationdb.record.query.plan.planning
- 
Support classes for query planning.
- com.apple.foundationdb.record.query.plan.plans - package com.apple.foundationdb.record.query.plan.plans
- 
Classes implementing executable query plan elements.
- com.apple.foundationdb.record.query.plan.synthetic - package com.apple.foundationdb.record.query.plan.synthetic
- 
Classes relating to hooking up join index synthetic records to the query planner.
- com.apple.foundationdb.record.query.plan.temp - package com.apple.foundationdb.record.query.plan.temp
- 
This will contain design docs for the Cascades planner at some point.
- com.apple.foundationdb.record.query.plan.temp.explain - package com.apple.foundationdb.record.query.plan.temp.explain
- 
This package implements a visualization of aRelationalExpressionas a graph for both internal debugging purposes and for consumption by end-users.
- com.apple.foundationdb.record.query.plan.temp.expressions - package com.apple.foundationdb.record.query.plan.temp.expressions
- 
A variety of planner-specificRelationalExpressionimplementations which will never be used outside of the planner.
- com.apple.foundationdb.record.query.plan.temp.matchers - package com.apple.foundationdb.record.query.plan.temp.matchers
- 
Classes related to the Cascades matcher system and its implementation.
- com.apple.foundationdb.record.query.plan.temp.properties - package com.apple.foundationdb.record.query.plan.temp.properties
- 
A package for planner properties (in the sense that Cascades uses them).
- com.apple.foundationdb.record.query.plan.temp.rules - package com.apple.foundationdb.record.query.plan.temp.rules
- 
A package containing the rules used by the planner.
- com.apple.foundationdb.record.query.plan.temp.view - package com.apple.foundationdb.record.query.plan.temp.view
- 
Classes related to theViewExpressionabstraction.
- com.apple.foundationdb.record.query.plan.visitor - package com.apple.foundationdb.record.query.plan.visitor
- 
A package of classes in the visitor pattern that perform substitutions on a tree ofRecordQueryPlans.
- com.apple.foundationdb.record.query.predicates - package com.apple.foundationdb.record.query.predicates
- 
Implementations of query predicates
- com.apple.foundationdb.record.util - package com.apple.foundationdb.record.util
- 
Miscellaneous record layer support classes.
- CombineFilterRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A simple rule that combines two nested filter plans and combines them into a single filter plan with a conjunction of the two filters.
- CombineFilterRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.CombineFilterRule
- combineHashes(List<Integer>) - Static method in interface com.apple.foundationdb.record.PlanHashable
- commit() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Commit an open transaction.
- commit() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- COMMIT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken committing transactions successfully.
- COMMIT_ASYNC - com.apple.foundationdb.record.provider.foundationdb.FDBLatencySource
- COMMIT_FAILURE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken committing transactions that did not succeed.
- COMMIT_NAME - com.apple.foundationdb.record.logging.LogMessageKeys
- COMMIT_READ_ONLY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken committing transactions that did not actually have any writes.
- commitAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Async version ofFDBRecordContext.commit().
- COMMITS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
Total number and duration of commits.
- common(Object) - Static method in interface com.apple.foundationdb.record.query.plan.temp.explain.Attribute
- 
Static factory method to create an attribute based on a reference to some object.
- commonKeys(List<IndexEntry>, List<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- commonKeys(List<IndexEntry>, List<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- commonPrimaryKey() - Method in class com.apple.foundationdb.record.RecordMetaData
- 
Determine whether every record type in this meta-data has the same primary key.
- commonPrimaryKey(Collection<RecordType>) - Static method in class com.apple.foundationdb.record.RecordMetaData
- comparand - Variable in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
- compare(RelationalExpression, RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.temp.CascadesCostModel
- compare(Object, Object) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons
- compare(String, String) - Method in interface com.apple.foundationdb.record.provider.common.text.TextCollator
- 
Compare the two strings according to the this collator's collation rules.
- compare(String, String) - Method in class com.apple.foundationdb.record.provider.common.text.TextCollatorRegistryJRE.TextCollatorJRE
- compareTo(FDBRecordVersion) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Compares two different record versions.
- compareTo(TimeWindowLeaderboard) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- COMPARISON_SKIPPED_BINDING - Static variable in class com.apple.foundationdb.record.query.expressions.Comparisons
- COMPARISON_SKIPPED_SCORE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper
- COMPARISON_VALUE - com.apple.foundationdb.record.logging.LogMessageKeys
- ComparisonRange - Class in com.apple.foundationdb.record.query.plan.temp
- 
A set of compatible comparisons on a single field of aKeyExpressionrepresenting a contiguous range of values for that field.
- ComparisonRange.Type - Enum in com.apple.foundationdb.record.query.plan.temp
- 
Comparison ranges can be divided into three types, with distinct planning behaviour: Empty ranges, to which any comparison can be added. Equality ranges, to which only the same (equality) comparison can be added. Inequality ranges, to which any other comparison can be added. This behavior is defined inComparisonRange.tryToAdd(Comparisons.Comparison).
- comparisons - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- Comparisons - Class in com.apple.foundationdb.record.query.expressions
- 
Helper methods for buildingComparisons.Comparisons.
- Comparisons.Comparison - Interface in com.apple.foundationdb.record.query.expressions
- 
A comparison between a value associated with someplace in the record (such as a field) and a value associated with the plan (such as a constant or a bound parameter).
- Comparisons.EvaluationContextRequiredException - Exception in com.apple.foundationdb.record.query.expressions
- 
Exception thrown when comparison evaluation needs the query context, but none was supplied.
- Comparisons.ListComparison - Class in com.apple.foundationdb.record.query.expressions
- 
A comparison with a list of values.
- Comparisons.MultiColumnComparison - Class in com.apple.foundationdb.record.query.expressions
- 
Comparison wrapping another one and answeringtruetoComparisons.MultiColumnComparison.hasMultiColumnComparand().
- Comparisons.NullComparison - Class in com.apple.foundationdb.record.query.expressions
- 
A unary predicate for special nullity checks, such asNULLandNOT NULL.
- Comparisons.ParameterComparison - Class in com.apple.foundationdb.record.query.expressions
- 
A comparison with a bound parameter, as opposed to a literal constant in the query.
- Comparisons.SimpleComparison - Class in com.apple.foundationdb.record.query.expressions
- 
A comparison with a constant value.
- Comparisons.TextComparison - Class in com.apple.foundationdb.record.query.expressions
- 
A text-style comparison, such as containing a given set of tokens.
- Comparisons.TextContainsAllPrefixesComparison - Class in com.apple.foundationdb.record.query.expressions
- 
AComparisons.TextComparisonthat checks for all prefixes.
- Comparisons.TextWithMaxDistanceComparison - Class in com.apple.foundationdb.record.query.expressions
- 
AComparisons.TextComparisonthat must be satisfied within a certain number of text tokens.
- Comparisons.Type - Enum in com.apple.foundationdb.record.query.expressions
- 
The type for aComparisons.Comparisonpredicate.
- compatibleWith(RecordStoreState) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Determines if it is safe to use queries and other operations planned with the passedRecordStoreStatewith a record store that has the current state.
- complete(byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Create aFDBRecordVersionthat is complete and has the given serialized bytes.
- complete(byte[], boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Create aFDBRecordVersionthat is complete and has the given serialized bytes.
- complete(byte[], int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Create aFDBRecordVersionthat is complete and has the given global and local versions.
- CompletionExceptionLogHelper - Class in com.apple.foundationdb.record.logging
- 
Helper class for helping with logging ofCompletionExceptions.
- CompletionExceptionLogHelper.IgnoredSuppressedExceptionCount - Exception in com.apple.foundationdb.record.logging
- 
A special "exception" to record the number of suppressed exceptions that were not recorded due to theCompletionExceptionLogHelper.maxSuppressedCount.
- ComponentWithChildren - Interface in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentthat has child components.
- ComponentWithComparison - Interface in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentthat uses aComparisons.Comparisonon the record.
- ComponentWithNoChildren - Interface in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentthat does not have any child components.
- ComponentWithSingleChild - Interface in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentwith exactly one child component.
- compose(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- 
Compute the composition of twoAliasMaps.
- COMPOSED_BITMAP_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- ComposedBitmapIndexAggregate - Class in com.apple.foundationdb.record.query.plan.bitmap
- 
Transform a tree of Boolean expressions into a tree of bitwise operations on streams of bitmaps.
- ComposedBitmapIndexQueryPlan - Class in com.apple.foundationdb.record.query.plan.bitmap
- 
A query plan implementing a bit-wise merge of two or more covering index scans ofBITMAP_VALUEindexes.
- ComposedBitmapIndexQueryPlan.ComposerBase - Class in com.apple.foundationdb.record.query.plan.bitmap
- 
Plan extension ofComposedBitmapIndexCursor.Composer.
- ComposerBase() - Constructor for class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan.ComposerBase
- compress(TransformedRecordSerializer.TransformState, StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- COMPRESS_SERIALIZED_RECORD - com.apple.foundationdb.record.provider.common.RecordSerializer.Events
- 
The amount of time spent compressing serialized bytes.
- compressed - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.TransformState
- compressionLevel - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
- compressionLevel - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- compressWhenSerializing - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
- compressWhenSerializing - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- COMPUTATION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeIcon
- compute(StoreTimer) - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Aggregate
- 
Compute the value for this aggregate.
- compute(StoreTimer) - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.CountAggregates
- compute(StoreTimer, StoreTimer.Event...) - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Aggregate
- 
Deprecated.useStoreTimer.Aggregate.compute(StoreTimer, Set)instead
- compute(StoreTimer, Set<? extends StoreTimer.Event>) - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Aggregate
- 
Compute the value for this aggregate.
- COMPUTE_BOUNDARY_KEYS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
Deprecated.this is no longer used
- computeDigest() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingDigest
- computeIfAbsent(Map<K, V>, K, Function<K, V>) - Static method in class com.apple.foundationdb.record.util.MapUtils
- 
In older versions of javaConcurrentHashMap.computeIfAbsent()has an issue where threads can contend on reads even when the value is present.
- computeNextResultStates() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Determine which cursors should have their values included in the next iteration.
- computeNextResultStates() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ProbableIntersectionCursor
- computeNextResultStates() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnionCursor
- computeNextResultStates() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnorderedUnionCursor
- concat(KeyExpression, KeyExpression, KeyExpression...) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Concatenate multiple expressions together.
- concat(List<KeyExpression>) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Concatenate multiple expressions together.
- ConcatCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that returns the elements of a first cursor followed by the elements of a second cursor.
- ConcatCursor(FDBRecordContext, ScanProperties, TriFunction<FDBRecordContext, ScanProperties, byte[], RecordCursor<T>>, TriFunction<FDBRecordContext, ScanProperties, byte[], RecordCursor<T>>, byte[]) - Constructor for class com.apple.foundationdb.record.cursors.ConcatCursor
- concatenate(Object, Object...) - Static method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
Primarily for tests, shorthand for creating a concatenation with a bunch of elements, see concatenate.
- concatenate(List<Object>) - Static method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
Take a list of scalars and concatenate them in a single key.
- Concatenate - com.apple.foundationdb.record.metadata.expressions.KeyExpression.FanType
- 
Convert a repeated field into a single list.
- concatenateFields(String, String, String...) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Shortuct for `concat(field(first), field(second), field(rest[0]), ...)`
- concatenateFields(List<String>) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Concatenate multiple fields together.
- Conditions(List<Comparisons.Comparison>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys.Conditions
- conditionsToGroupKeys(KeyExpression, QueryComponent) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys
- conditionsToGroupKeys(IndexAggregateFunction, QueryComponent) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys
- configLoader - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- Constituent(String, RecordType) - Constructor for class com.apple.foundationdb.record.metadata.SyntheticRecordType.Constituent
- Constituent(String, RecordTypeBuilder) - Constructor for class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder.Constituent
- consume() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
- contains(ReadTransactionContext, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.InstrumentedRankedSet
- contains(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.RelationalExpressionPointerSet
- contains(String) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains a token.
- contains(T) - Method in class com.apple.foundationdb.record.query.plan.temp.RelationalExpressionPointerSet
- containsAll(String) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains all of the provided tokens.
- containsAll(String, int) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field text contains all of the provided tokens within a given number of tokens.
- containsAll(Collection<KeyExpression>) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields
- containsAll(List<String>) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains all of provided tokens.
- containsAll(List<String>, int) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field text contains all of the provided tokens within a given number of tokens.
- containsAllInMemo(ExpressionRef<? extends RelationalExpression>, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.temp.ExpressionRef
- containsAllInMemo(ExpressionRef<? extends RelationalExpression>, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- containsAllInMemo(ExpressionRef<? extends RelationalExpression>, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- containsAllPrefixes(String) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains tokens matching all of of the given prefixes.
- containsAllPrefixes(String, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains tokens matching all of of the given prefixes.
- containsAllPrefixes(String, boolean, long, double) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains tokens matching all of of the given prefixes.
- containsAllPrefixes(List<String>) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains tokens matching all of of the given prefixes.
- containsAllPrefixes(List<String>, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains tokens matching all of of the given prefixes.
- containsAllPrefixes(List<String>, boolean, long, double) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains tokens matching all of of the given prefixes.
- containsAny(String) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains any of the provided tokens.
- containsAny(List<String>) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains all of provided tokens.
- containsAnyPrefix(String) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains a token that matches any of the given prefixes.
- containsAnyPrefix(List<String>) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains a token that matches any of the given prefixes.
- containsCounter(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
- 
Determine if there is a counter recorded for a given event.
- containsExactly(T) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- containsInMemo(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- containsKey(ExpressionMatcher<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.PlannerBindings
- 
Checks whether there is a bindable bound tokey.
- containsNonUniqueNull() - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
Check for NULL value that inhibits unique indexes.
- containsPhrase(String) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains the given phrase.
- containsPhrase(List<String>) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field text contains the given phrase.
- containsPrefix(String) - Method in class com.apple.foundationdb.record.query.expressions.Text
- 
Checks if the field contains any token matching the provided prefix.
- containsSource(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- containsTarget(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- containsTimeoutCounter(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
- 
Determine if there is a timeout counter recorded for a given event.
- containsTimestamp(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- context - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- context - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
- CONTINUATION - com.apple.foundationdb.record.EndpointType
- copy(int, int, long, IsolationLevel, ExecuteState, boolean, CursorStreamingMode) - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Create a new instance with these fields, copying any additional fields from subclasses.
- copyBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Make a copy of this builder.
- copyBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- copyBuilder() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Make a copy of this builder.
- copyBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- copyFrom(FDBRecordStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- 
Copy state from a record store.
- copyFrom(FDBRecordStore.Builder) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- 
Copy state from another store builder.
- copyTo(LocatableResolver) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingReplicator
- 
Copy the mappings stored in aLocatableResolverto the specified replica.
- copyToAsync(LocatableResolver) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingReplicator
- 
Copy the mappings stored in aLocatableResolverto the specified replica.
- Correlated<S extends Correlated<S>> - Interface in com.apple.foundationdb.record.query.plan.temp
- 
A correlated entity is one which can only be evaluated as a function of some input (usually aQuantifierfrom its relational parent).
- CorrelationIdentifier - Class in com.apple.foundationdb.record.query.plan.temp
- 
A correlation identifier is an immutable object that is created with a string uniquely identifying it.
- count(KeyExpression) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- COUNT - com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- COUNT - Static variable in class com.apple.foundationdb.record.FunctionNames
- COUNT - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
A count of the number of indexed entries.
- COUNT_DISTINCT - Static variable in class com.apple.foundationdb.record.FunctionNames
- COUNT_NOT_NULL - com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- COUNT_NOT_NULL - Static variable in class com.apple.foundationdb.record.FunctionNames
- COUNT_NOT_NULL - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
A count of the number of non-null values for a field.
- COUNT_UPDATES - com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- COUNT_UPDATES - Static variable in class com.apple.foundationdb.record.FunctionNames
- COUNT_UPDATES - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
A count of the number of times that any indexed record has been updated.
- counters - Variable in class com.apple.foundationdb.record.provider.common.StoreTimer
- countKeysAndValues(StoreTimer.Count, StoreTimer.Count, StoreTimer.Count, FDBStoredSizes) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- countKeyValue(StoreTimer.Count, StoreTimer.Count, StoreTimer.Count, byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- countKeyValue(StoreTimer.Count, StoreTimer.Count, StoreTimer.Count, KeyValue) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- countRecords(Tuple, Tuple, EndpointType, EndpointType) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Count the number of records in the database in a range.
- countRecords(Tuple, Tuple, EndpointType, EndpointType, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- countRecords(Tuple, Tuple, EndpointType, EndpointType, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Count the number of records in the database in a range.
- countRecords(Tuple, Tuple, EndpointType, EndpointType, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- COUNTS_UNKNOWN - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
- countUpdates(KeyExpression) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- covered(Index, IndexEntry, Tuple, RecordType, M) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
- coveredIndexQueriedRecord(Index, IndexEntry, RecordType, M, boolean) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get a query result from a covering index entry.
- COVERING_INDEX_SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- COVERING_SPATIAL_INDEX_SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- CRC - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetHashFunctions
- create() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Synchronous version ofFDBRecordStoreBase.BaseBuilder.createAsync().
- create(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- create(FDBRecordContext, String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- create(FDBRecordContext, String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- create(FDBRecordContext, String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- create(FDBRecordContext, String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- create(FDBRecordContext, String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- create(FDBRecordStoreBase<M>, KeyExpression, boolean, Function<byte[], RecordCursor<S>>, Function<byte[], RecordCursor<S>>, byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.IntersectionCursor
- 
Create an intersection cursor from two compatibly-ordered cursors.
- create(FDBRecordStoreBase<M>, KeyExpression, boolean, Function<byte[], RecordCursor<S>>, Function<byte[], RecordCursor<S>>, byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnionCursor
- 
Create a union cursor from two compatibly-ordered cursors.
- create(FDBRecordStoreBase<M>, KeyExpression, boolean, List<Function<byte[], RecordCursor<S>>>, byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.IntersectionCursor
- 
Create an intersection cursor from two or more compatibly-ordered cursors.
- create(FDBRecordStoreBase<M>, KeyExpression, boolean, List<Function<byte[], RecordCursor<S>>>, byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnionCursor
- 
Create a union cursor from two or more compatibly-ordered cursors.
- create(String, KeyExpression) - Static method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- 
Create a function.
- create(Function<? super T, ? extends List<Object>>, boolean, Function<byte[], RecordCursor<T>>, Function<byte[], RecordCursor<T>>, byte[], FDBStoreTimer) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.IntersectionCursor
- 
Create an intersection cursor from two compatibly-ordered cursors.
- create(Function<? super T, ? extends List<Object>>, boolean, Function<byte[], RecordCursor<T>>, Function<byte[], RecordCursor<T>>, byte[], FDBStoreTimer) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnionCursor
- 
Create a union cursor from two compatibly-ordered cursors.
- create(Function<? super T, ? extends List<Object>>, boolean, List<Function<byte[], RecordCursor<T>>>, byte[], FDBStoreTimer) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.IntersectionCursor
- 
Create an intersection cursor from two or more compatibly-ordered cursors.
- create(Function<? super T, ? extends List<Object>>, boolean, List<Function<byte[], RecordCursor<T>>>, byte[], FDBStoreTimer) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.IntersectionMultiCursor
- 
Create an intersection cursor from two or more compatibly-ordered cursors.
- create(Function<? super T, ? extends List<Object>>, boolean, List<Function<byte[], RecordCursor<T>>>, byte[], FDBStoreTimer) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnionCursor
- 
Create a union cursor from two or more compatibly-ordered cursors.
- create(Function<? super T, ? extends List<Object>>, List<Function<byte[], RecordCursor<T>>>, byte[], FDBStoreTimer) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ProbableIntersectionCursor
- 
Create a cursor merging the results of two or more cursors.
- create(Function<? super T, ? extends List<Object>>, List<Function<byte[], RecordCursor<T>>>, long, double, byte[], FDBStoreTimer) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ProbableIntersectionCursor
- 
Create a cursor merging the results of two or more cursors.
- create(List<Function<byte[], RecordCursor<T>>>, byte[], FDBStoreTimer) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnorderedUnionCursor
- 
Create a union cursor from two or more cursors.
- CREATE_RECORD_STORE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of times a record store is created in the database.
- createAsync() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Opens a newFDBRecordStoreinstance in the given path with the given meta-data.
- createCursorStates(Function<byte[], RecordCursor<T>>, Function<byte[], RecordCursor<T>>, byte[], Function<? super T, ? extends List<Object>>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnionCursor
- createCursorStates(List<Function<byte[], RecordCursor<T>>>, byte[], Function<? super T, ? extends List<Object>>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnionCursor
- createHtmlLauncher(AbstractPlannerGraph<PlannerGraph.Node, PlannerGraph.Edge>) - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraphProperty
- 
For debugging only! This method locates a template html launcher file from the resources folder and writes a specific launcher html file into a temp directory.
- createIndexPlannerGraph(RecordQueryPlan, NodeInfo, List<String>, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- 
Create a planner graph for better visualization of a query index plan.
- createIndexPlannerGraph(RecordQueryPlan, NodeInfo, List<String>, Map<String, Attribute>) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithIndex
- 
Create an planner graph for this index scan.
- createIndexPlannerGraph(RecordQueryPlan, NodeInfo, List<String>, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- createMetaDataBuilder(RecordMetaDataProto.MetaData) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- createMetaDataBuilder(RecordMetaDataProto.MetaData, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- createOrOpen() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Synchronous version ofFDBRecordStoreBase.BaseBuilder.createOrOpenAsync().
- createOrOpen(FDBRecordStoreBase.StoreExistenceCheck) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Synchronous version ofFDBRecordStoreBase.BaseBuilder.createOrOpenAsync(FDBRecordStoreBase.StoreExistenceCheck).
- createOrOpenAsync() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Opens aFDBRecordStoreinstance in the given path with the given meta-data.
- createOrOpenAsync(FDBRecordStoreBase.StoreExistenceCheck) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- createOrOpenAsync(FDBRecordStoreBase.StoreExistenceCheck) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Opens aFDBRecordStoreinstance in the given path with the given meta-data.
- createOrOpenAsync(FDBRecordStoreBase.StoreExistenceCheck) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- createsDuplicates() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
This states whether the given expression type is capable of evaluating more to more than one value when applied to a single record.
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- createsDuplicates() - Method in class com.apple.foundationdb.record.query.plan.TextScan
- 
Determines whether this scan might return duplicate results for the same record.
- createsDuplicates(Index, GroupingKeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons
- createsDuplicatesAfter(int) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- CreatesDuplicatesProperty - Class in com.apple.foundationdb.record.query.plan.temp.properties
- 
A property that determines whether the expression may produce duplicate entries.
- createSyntheticUnion(Descriptors.FileDescriptor, Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
- 
Creates a default union descriptor for the given file descriptor and a base union descriptor.
- createTransaction(Executor, Map<String, String>, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Deprecated.useFDBDatabase.openContext()instead
- CURR_ATTEMPT - com.apple.foundationdb.record.logging.LogMessageKeys
- CURRENT_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- CURSOR_ELAPSED_MILLIS - com.apple.foundationdb.record.logging.LogMessageKeys
- CURSOR_TIME_LIMIT_MILLIS - com.apple.foundationdb.record.logging.LogMessageKeys
- CursorLimitManager - Class in com.apple.foundationdb.record.cursors
- 
Handles the logic of tracking various out-of-band limits on aBaseCursor.
- CursorLimitManager(FDBRecordContext, ScanProperties) - Constructor for class com.apple.foundationdb.record.cursors.CursorLimitManager
- CursorLimitManager(RecordScanLimiter, boolean, ByteScanLimiter, TimeScanLimiter) - Constructor for class com.apple.foundationdb.record.cursors.CursorLimitManager
- CursorLimitManager(ScanProperties) - Constructor for class com.apple.foundationdb.record.cursors.CursorLimitManager
- CursorStreamingMode - Enum in com.apple.foundationdb.record
- 
The streaming mode to use when openingRecordCursors.
D
- data - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.TransformState
- DATA_ACCESS_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeIcon
- database - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- database - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- database() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Get the underlying FDB database.
- DataNodeWithInfo(NodeInfo) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.DataNodeWithInfo
- DataNodeWithInfo(NodeInfo, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.DataNodeWithInfo
- DataNodeWithInfo(NodeInfo, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.DataNodeWithInfo
- decodeRecordCount(byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- decodeSignedLong(byte[]) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- decodeSubspaceKey(ByteString) - Static method in class com.apple.foundationdb.record.metadata.Index
- decodeUnsignedLong(byte[]) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- decodeValue(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- decodeValue(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainer
- decodeValue(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Decode value portion of key value pair.
- decompress(TransformedRecordSerializer.TransformState, StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- DECOMPRESS_SERIALIZED_RECORD - com.apple.foundationdb.record.provider.common.RecordSerializer.Events
- 
The amount of time spent decompressing serialized bytes.
- decrypt(TransformedRecordSerializer.TransformState, StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- decrypt(TransformedRecordSerializer.TransformState, StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
- DECRYPT_SERIALIZED_RECORD - com.apple.foundationdb.record.provider.common.RecordSerializer.Events
- 
The amount of time spent decrypting serialized bytes.
- DEFAULT - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.VersionstampSaveBehavior
- DEFAULT - com.apple.foundationdb.record.provider.foundationdb.FDBTraceFormat
- 
Use the system default.
- DEFAULT - com.apple.foundationdb.record.provider.foundationdb.FDBTransactionPriority
- 
The default priority level for most transactions.
- DEFAULT - Static variable in interface com.apple.foundationdb.record.query.IndexQueryabilityFilter
- 
The default index queryability filter which uses all indexes except those with theIndexOptions.ALLOWED_FOR_QUERY_OPTIONset tofalse.
- DEFAULT - Static variable in class com.apple.foundationdb.record.query.plan.PlannableIndexTypes
- DEFAULT_CHECK - Static variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverCreateHooks
- DEFAULT_CIPHER - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
- DEFAULT_COMPLEXITY_THRESHOLD - Static variable in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- 
Default limit on the complexity of the plans generated by the planner.
- DEFAULT_COMPRESSION_LEVEL - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- DEFAULT_DEADLINE_TIME_MILLIS - Static variable in class com.apple.foundationdb.record.AsyncLoadingCache
- 
The default deadline to impose on loading elements.
- DEFAULT_DEADLINE_TIME_MILLIS - Static variable in class com.apple.foundationdb.record.provider.foundationdb.storestate.ReadVersionRecordStoreStateCacheFactory
- 
Default deadline time to load entries into this cache.
- DEFAULT_DIRECTORY_CACHE_SIZE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
The default number of entries that is to be cached, per database, fromLocatableResolverretrieval requests.
- DEFAULT_ENTRY_SIZE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainer
- DEFAULT_EXPECTED_RESULTS - Static variable in class com.apple.foundationdb.record.provider.foundationdb.cursors.ProbableIntersectionCursor
- 
The default number of results to expect to be read from each child cursor of this cursor.
- DEFAULT_EXPIRE_AFTER_ACCESS_MILLIS - Static variable in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCacheFactory
- 
The default amount of time in milliseconds after last access that cache entries should start to be expired.
- DEFAULT_FALSE_POSITIVE_PERCENTAGE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.cursors.ProbableIntersectionCursor
- 
The default acceptable false positive percentage when evaluating whether an element is contained with a given cursor's result set.
- DEFAULT_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- DEFAULT_GRAPH_ID - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- 
Default graph id used by the exporter.
- DEFAULT_HOOK - Static variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverCreateHooks
- DEFAULT_LATENCY_INJECTOR - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- DEFAULT_LEASE_LENGTH_MILLIS - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Default length between last access and lease's end time in milliseconds.
- DEFAULT_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Default number of records to attempt to run in a single transaction.
- DEFAULT_MAX_ENTRIES - Static variable in class com.apple.foundationdb.record.provider.common.MappedPool
- DEFAULT_MAX_RETRIES - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Default number of times to retry a single range rebuild.
- DEFAULT_MAX_REVERSE_CACHE_ENTRIES - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- DEFAULT_MAX_SIZE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCacheFactory
- 
The default maximum number of items to include in the cache.
- DEFAULT_MAX_SIZE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.storestate.ReadVersionRecordStoreStateCacheFactory
- 
Default maximum number of elements to cache.
- DEFAULT_PIPELINE_SIZE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- DEFAULT_PIPELINE_SIZER - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- DEFAULT_POOL_SIZE - Static variable in class com.apple.foundationdb.record.provider.common.MappedPool
- DEFAULT_PROGRESS_LOG_INTERVAL - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Default interval to be logging successful progress in millis when building across transactions.
- DEFAULT_RECORDS_PER_SECOND - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Default limit to the number of records to attempt in a single second.
- DEFAULT_REFRESH_TIME_MILLIS - Static variable in class com.apple.foundationdb.record.provider.foundationdb.storestate.ReadVersionRecordStoreStateCacheFactory
- 
Default refresh time for cache entries (in milliseconds).
- DEFAULT_RESOLVER_STATE_CACHE_REFRESH_SECONDS - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- DEFAULT_SIZE_LIMIT - Static variable in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
- 
The default limit on the size of the DNF that will be produced by the normalizer.
- DEFAULT_TR_TIMEOUT_MILLIS - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Special value to set the transaction timeout to to indicate that transactions should use the system default.
- DEFAULT_UNION_NAME - Static variable in class com.apple.foundationdb.record.RecordMetaDataBuilder
- DEFAULT_WRITE_LIMIT_BYTES - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Default transaction write size limit.
- DefaultTextTokenizer - Class in com.apple.foundationdb.record.provider.common.text
- 
This is the default tokenizer used by full-text indexes.
- DefaultTextTokenizerFactory - Class in com.apple.foundationdb.record.provider.common.text
- 
Factory class for theDefaultTextTokenizer.
- DefaultTextTokenizerFactory() - Constructor for class com.apple.foundationdb.record.provider.common.text.DefaultTextTokenizerFactory
- DELAY - com.apple.foundationdb.record.logging.LogMessageKeys
- DELETE_INDEX_ENTRY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent deleting an entry from a secondary index.
- DELETE_INDEX_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of index key-value pairs deleted.
- DELETE_INDEX_KEY_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of keys for index key-value pairs deleted.
- DELETE_INDEX_VALUE_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of values for index key-value pairs deleted.
- DELETE_RECORD - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken deleting records.
- DELETE_RECORD_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of record key-value pairs deleted.
- DELETE_RECORD_KEY_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of keys for record key-value pairs deleted.
- DELETE_RECORD_VALUE_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of values for record key-value pairs deleted.
- deleteAllData(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Synchronous version ofKeySpacePath.deleteAllDataAsync(FDBRecordContext).
- deleteAllDataAsync(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Delete all data from this path.
- deleteAllDataAsync(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- deleteAllRecords() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- deleteAllRecords() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Delete all the data in the record store.
- deleteAllRecords() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- deleteRecord(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Delete the record with the given primary key.
- deleteRecordAsync(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- deleteRecordAsync(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Async version ofFDBRecordStoreBase.deleteRecord(com.apple.foundationdb.tuple.Tuple).
- deleteRecordAsync(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- deleteRecordsWhere(QueryComponent) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Delete records and associated index entries matching a query filter.
- deleteRecordsWhere(String, QueryComponent) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Delete records and associated index entries matching a query filter.
- deleteRecordsWhereAsync(QueryComponent) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- deleteRecordsWhereAsync(QueryComponent) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- deleteRecordsWhereAsync(QueryComponent) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- deleteRecordsWhereAsync(String, QueryComponent) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Async version ofFDBRecordStoreBase.deleteRecordsWhere(String, QueryComponent).
- DELETES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
Total number of delete (clear) operations.
- deleteSplit(FDBRecordContext, Subspace, Tuple, boolean, boolean, boolean, FDBStoredSizes) - Static method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper
- 
Delete the serialized representation of a record.
- deleteStore(FDBRecordContext, KeySpacePath) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Delete the record store at the givenKeySpacePath.
- deleteStore(FDBRecordContext, Subspace) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Delete the record store at the givenSubspace.
- deleteTypedRecord(RecordSerializer<M>, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- deleteWhere(Transaction, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- deleteWhere(Transaction, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainer
- deleteWhere(Transaction, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- deleteWhere(Transaction, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Clear index storage associated with the given key prefix.
- deleteWhere(Transaction, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- deprecateField(RecordMetaDataProto.MetaData.Builder, String, String) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
- 
Deprecate a field from a record type.
- deprecateRecordType(RecordMetaDataProto.MetaData.Builder, String) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
- 
Deprecate a record type from the meta-data.
- depth() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Get the depth in the directory tree of this directory.
- derived() - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- derived(int) - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- derivedFrom(StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
- 
Determine if this snapshot is derived from the provided timer.
- description() - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry.Reason
- 
Get the description of the reason for user displays.
- description() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry.Reasons
- DESCRIPTION - com.apple.foundationdb.record.logging.LogMessageKeys
- DeserializationException(String) - Constructor for exception com.apple.foundationdb.record.metadata.expressions.KeyExpression.DeserializationException
- DeserializationException(String, Exception) - Constructor for exception com.apple.foundationdb.record.metadata.expressions.KeyExpression.DeserializationException
- deserialize(RecordMetaData, Tuple, byte[], StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.DynamicMessageRecordSerializer
- deserialize(RecordMetaData, Tuple, byte[], StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.MessageBuilderRecordSerializerBase
- deserialize(RecordMetaData, Tuple, byte[], StoreTimer) - Method in interface com.apple.foundationdb.record.provider.common.RecordSerializer
- 
Convert a byte array to a Protobuf record.
- deserialize(RecordMetaData, Tuple, byte[], StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- DESERIALIZE_PROTOBUF_RECORD - com.apple.foundationdb.record.provider.common.RecordSerializer.Events
- 
The amount of time spent deserializing a Protobuf record from bytes.
- deserializeEntries(Tuple, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexBunchedSerializer
- 
Deserializes an entry list from bytes.
- deserializeFromBytes(Descriptors.Descriptor, byte[]) - Method in class com.apple.foundationdb.record.provider.common.DynamicMessageRecordSerializer
- deserializeKey(byte[], int, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexBunchedSerializer
- 
Deserializes a key using standardTupleunpacking.
- deserializeKeys(Tuple, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexBunchedSerializer
- 
Deserializes the keys from a serialized entry list.
- deserializeUnion(Descriptors.Descriptor, Tuple, byte[], int) - Method in class com.apple.foundationdb.record.provider.common.DynamicMessageRecordSerializer
- deserializeValue(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- deserializeValue(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Deserialize the raw bytes value stored in the mapping subspace.
- deserializeValue(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- deserializeValue(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- deserializeValue(byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- DIR_NAME - com.apple.foundationdb.record.logging.LogMessageKeys
- DIR_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- DIR_VALUE - com.apple.foundationdb.record.logging.LogMessageKeys
- DIRECTORY_NOT_FOR_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Return value frompathFromKeyto indicate that a given tuple value is not appropriate for a given directory.
- DIRECTORY_READ - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent reading an entry from a directory layer.
- DirectoryLayerDirectory - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
AKeySpaceDirectorythat maps aSTRINGvalue to a compactLONGvalue using the FDB directory layer.
- DirectoryLayerDirectory(String) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
- 
Constructor forDirectoryLayerDirectory.
- DirectoryLayerDirectory(String, Object) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
- 
Constructor forDirectoryLayerDirectory.
- DirectoryLayerDirectory(String, Object, Function<KeySpacePath, KeySpacePath>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
- 
Constructor forDirectoryLayerDirectory.
- DirectoryLayerDirectory(String, Object, Function<KeySpacePath, KeySpacePath>, Function<FDBRecordContext, CompletableFuture<LocatableResolver>>, ResolverCreateHooks) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
- 
Constructor forDirectoryLayerDirectory.
- DirectoryLayerDirectory(String, Function<KeySpacePath, KeySpacePath>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
- 
Constructor forDirectoryLayerDirectory.
- DirectoryLayerDirectory(String, Function<KeySpacePath, KeySpacePath>, Function<FDBRecordContext, CompletableFuture<LocatableResolver>>, ResolverCreateHooks) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
- 
Constructor forDirectoryLayerDirectory.
- DIRECTOY - com.apple.foundationdb.record.logging.LogMessageKeys
- DISABLED - com.apple.foundationdb.record.IndexState
- 
Indicates that this store does not use this index.
- DISABLED - com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
- 
The detection of blocking in an asynchronous context is disabled.
- disableWriteLock() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Unlocks thisLocatableResolver, so that calls toLocatableResolver.resolve(FDBStoreTimer, String)will create entries if they do not exist.
- disallowsTypeRenames() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Get whether this validator will disallow record types from being renamed.
- disallowsTypeRenames() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Whether this validator disallows record types from being renamed.
- DISTINCT_FILTER_DEPTH - Static variable in class com.apple.foundationdb.record.query.plan.temp.properties.RelationalExpressionDepthProperty
- DNF_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
- DNF_SIZE_LIMIT - com.apple.foundationdb.record.logging.LogMessageKeys
- DO_NOT_RE_INCREASE_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
IfOnlineIndexer.Builder.getIncreaseLimitAfter()is this value, the limit will not go back up, no matter how many successes there are.
- DOCUMENT - com.apple.foundationdb.record.logging.LogMessageKeys
- dot(Object) - Static method in interface com.apple.foundationdb.record.query.plan.temp.explain.Attribute
- 
Static factory method to create a DOT attribute based on a reference to some object.
- DotExporter<N extends PlannerGraph.Node,E extends PlannerGraph.Edge> - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Exports a graph into a DOT file.
- DotExporter(GraphExporter.ComponentIdProvider<N>, GraphExporter.ComponentAttributeProvider<N>, GraphExporter.ComponentAttributeProvider<E>, Map<String, Attribute>, GraphExporter.ClusterProvider<N, E>, GraphExporter.ComponentAttributeProvider<N>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- 
Constructs a new DotExporter object with the given ID, label, attribute, and graph ID providers.
- DOUBLE - com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- dropIndex(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Remove the given index from the record meta-data.
- dropIndexAsync(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Remove the given index from the record meta-data asynchronously.
- DURATION_MILLIS - com.apple.foundationdb.record.logging.LogMessageKeys
- DynamicMessageRecordSerializer - Class in com.apple.foundationdb.record.provider.common
- 
Serialize records using default Protobuf serialization usingDynamicMessage.
- DynamicMessageRecordSerializer() - Constructor for class com.apple.foundationdb.record.provider.common.DynamicMessageRecordSerializer
E
- EARLIEST_ADDED_START_TIMESTAMP - com.apple.foundationdb.record.logging.LogMessageKeys
- Edge() - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Edge
- Edge(String) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Edge
- Edge(String, Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Edge
- Edge(Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Edge
- Element - Interface in com.apple.foundationdb.record.query.plan.temp.view
- 
A value in theViewExpressionlanguage that can be represented as an element of FoundationDB tuple.
- ElementKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
A key expression that derives its values from anElement.
- ElementKeyExpression(Element) - Constructor for class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- ElementPredicate - Class in com.apple.foundationdb.record.query.predicates
- ElementPredicate(Element, Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.predicates.ElementPredicate
- ElementPredicateCountProperty - Class in com.apple.foundationdb.record.query.plan.temp.properties
- 
A property that counts the number ofElementPredicates that appear in a planner expression tree.
- ElementPredicateCountProperty() - Constructor for class com.apple.foundationdb.record.query.plan.temp.properties.ElementPredicateCountProperty
- empty() - Static method in class com.apple.foundationdb.record.EvaluationContext
- 
Get an empty evaluation context.
- empty() - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
The empty key expression.
- empty() - Static method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- empty() - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.ListChildrenMatcher
- 
Get a matcher with no child matchers which matches an empty collection of children.
- empty() - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.PlannerBindings
- 
Return an empty set of bindings.
- empty() - Static method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that does not return any records.
- empty(Executor) - Static method in interface com.apple.foundationdb.record.RecordCursor
- EMPTY - com.apple.foundationdb.record.query.plan.temp.ComparisonRange.Type
- EMPTY - Static variable in class com.apple.foundationdb.record.EvaluationContext
- EMPTY - Static variable in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- EMPTY - Static variable in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
A key containing no elements.
- EMPTY - Static variable in class com.apple.foundationdb.record.query.plan.ScanComparisons
- EMPTY - Static variable in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- EMPTY - Static variable in class com.apple.foundationdb.record.query.plan.temp.view.SourceEntry
- EMPTY - Static variable in class com.apple.foundationdb.record.RecordStoreState
- 
Deprecated.as this object usually has the wrong store header
- EMPTY_BINDINGS - Static variable in class com.apple.foundationdb.record.Bindings
- EMPTY_NO_MATCHES - com.apple.foundationdb.record.query.expressions.Field.OneOfThemEmptyMode
- 
An empty repeated field is treated like any other list, just with no elements, so none can match.
- EMPTY_OPTIONS - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
No options.
- EMPTY_PROTO - Static variable in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- EMPTY_UNKNOWN - com.apple.foundationdb.record.query.expressions.Field.OneOfThemEmptyMode
- 
An empty repeated field causesoneOfThempredicates to return UNKNOWN, like a scalar NULL value.
- EMPTY_VALUE - Static variable in class com.apple.foundationdb.record.metadata.Index
- EmptyComparison - Class in com.apple.foundationdb.record.query.expressions
- 
A comparison to determine whether a repeated field is empty (has no occurrences).
- EmptyComparison(String, boolean) - Constructor for class com.apple.foundationdb.record.query.expressions.EmptyComparison
- EmptyCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
ARecordCursorthat always returns zero items.
- EmptyCursor(Executor) - Constructor for class com.apple.foundationdb.record.cursors.EmptyCursor
- EmptyKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
A single empty key.
- enableCounterBasedSubspaceKeys() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Enable counter-based subspace keys assignment.
- enableSplitLongRecords() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Enable splitting long records.
- enableSplitLongRecordsAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Enable splitting long records asynchronously.
- enableWriteLock() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Puts thisLocatableResolverinto a write locked state which will prevent any new entries from being created.
- encodeSignedLong(long) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- encodeUnsignedLong(long) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- ENCODING_CLEAR - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- ENCODING_COMPRESSED - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- ENCODING_ENCRYPTED - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- ENCODING_PROTO_MESSAGE_FIELD - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- ENCODING_PROTO_TYPE_MASK - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- encrypt(TransformedRecordSerializer.TransformState, StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- encrypt(TransformedRecordSerializer.TransformState, StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
- ENCRYPT_SERIALIZED_RECORD - com.apple.foundationdb.record.provider.common.RecordSerializer.Events
- 
The amount of time spent encrypting serialized bytes.
- encrypted - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.TransformState
- encryptionKey - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- encryptionKey - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
- encryptWhenSerializing - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
- encryptWhenSerializing - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- END - com.apple.foundationdb.record.logging.TestLogMessageKeys
- END - Static variable in class com.apple.foundationdb.record.RecordCursorEndContinuation
- END_TUPLE - com.apple.foundationdb.record.logging.LogMessageKeys
- endAnySession() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- 
Synchronous/blocking version ofSynchronizedSessionRunner.endAnySessionAsync().
- endAnySessionAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- 
Releases the lock to end any synchronized session on the same lock subspace, no matter whether the current session holds the lock or not.
- ENDPOINT_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- EndpointType - Enum in com.apple.foundationdb.record
- 
The type of one of the endpoints of aTupleRange.
- endRead() - Method in class com.apple.foundationdb.record.MutableRecordStoreState
- 
End using this record store state.
- endRead() - Method in class com.apple.foundationdb.record.RecordStoreState
- 
End using this record store state.
- endSession() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- 
Synchronous/blocking version ofSynchronizedSessionRunner.endSessionAsync().
- endSessionAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- 
Releases the lock to end the synchronized session.
- endWrite() - Method in class com.apple.foundationdb.record.MutableRecordStoreState
- 
End modifying this record store state.
- enforce(int) - Static method in class com.apple.foundationdb.record.RecordScanLimiterFactory
- 
Creates a limiter that enforces a maximum number of records that can be processed in a single scan.
- enforce(long) - Static method in class com.apple.foundationdb.record.ByteScanLimiterFactory
- 
Creates a limiter that enforces a maximum number of bytes that can be processed in a single scan.
- ensureActive() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- ensureActive() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- ensureContextActive() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- EQUALITY - com.apple.foundationdb.record.query.plan.ScanComparisons.ComparisonType
- EQUALITY - com.apple.foundationdb.record.query.plan.temp.ComparisonRange.Type
- EQUALITY - com.apple.foundationdb.record.query.QueryToKeyMatcher.MatchType
- equalityComparisons - Variable in class com.apple.foundationdb.record.query.plan.ScanComparisons
- equals(Object) - Method in class com.apple.foundationdb.record.IndexEntry
- equals(Object) - Method in class com.apple.foundationdb.record.IndexScanType
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.FormerIndex
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.Index
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.IndexRecordFunction
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- equals(Object) - Method in class com.apple.foundationdb.record.metadata.StoreRecordFunction
- equals(Object) - Method in class com.apple.foundationdb.record.MutableRecordStoreState
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Whether thisFDBRecordVersionmathces the given object.
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexBuildState
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverResult
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedValue
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowAggregateFunction
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.TimeWindowSpec
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowRecordFunction
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderByKeySpacePath
- equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderBySubspace
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.AndComponent
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.BaseField
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextWithMaxDistanceComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.EmptyComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.NestedField
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.OrComponent
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.ScoreForRank
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.CorrelationIdentifier
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractNode
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.FullUnorderedScanExpression
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalTypeFilterExpression
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalUnorderedUnionExpression
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.IndexEntrySource
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeElement
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.view.Source
- 
Override of equality to ensure that sources are compared using reference equality.
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ValueElement
- equals(Object) - Method in class com.apple.foundationdb.record.query.plan.TextScan
- equals(Object) - Method in class com.apple.foundationdb.record.query.predicates.AndOrPredicate
- equals(Object) - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- equals(Object) - Method in class com.apple.foundationdb.record.query.predicates.NotPredicate
- equals(Object) - Method in class com.apple.foundationdb.record.RecordCursorResult
- equals(Object) - Method in class com.apple.foundationdb.record.RecordFunction
- equals(Object) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Checks if thisRecordStoreStatespecifies identical state as the given object.
- equals(Object) - Method in class com.apple.foundationdb.record.TupleRange
- equals(Object) - Method in class com.apple.foundationdb.record.ValueRange
- EQUALS - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- equalsAtomic(AtomKeyExpression) - Method in interface com.apple.foundationdb.record.metadata.expressions.AtomKeyExpression
- equalsAtomic(AtomKeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- equalsAtomic(AtomKeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- equalsAtomic(AtomKeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- equalsAtomic(AtomKeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- equalsAtomic(AtomKeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- equalsAtomic(AtomKeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- equalsAtomic(AtomKeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- equalsOnKind(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- equalsParameter(String) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Checks if the field has a value equal to the given parameter.
- equalsParameter(String) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
- 
Checks if the key expression has a value equal to the given parameter.
- equalsValue(Object) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Checks if the field has a value equal to the given comparand.
- equalsValue(Object) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field is equal to the given comparand.
- equalsValue(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
- 
Checks if the key expression has a value equal to the given comparand.
- equalsValue(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- 
Checks if the calculated value has a value equal to the given comparand.
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.FullUnorderedScanExpression
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalUnorderedUnionExpression
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.temp.expressions.TypeFilterExpression
- equalsWithoutChildren(RelationalExpression, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpression
- equalsWithoutChildren(AndOrPredicate, AliasMap) - Method in class com.apple.foundationdb.record.query.predicates.AndOrPredicate
- ERROR - com.apple.foundationdb.record.logging.LogMessageKeys
- ERROR - com.apple.foundationdb.record.provider.foundationdb.IndexOrphanBehavior
- 
Throw an exception when an orphaned entry is hit.
- ERROR_CODE - com.apple.foundationdb.record.logging.LogMessageKeys
- ERROR_IF_DISABLED_CONTINUE_IF_WRITE_ONLY - com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
- 
Error if the index is disabled, or continue to build if the index is write only.
- ERROR_IF_EXISTS - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
- 
Throw if the record already exists.
- ERROR_IF_EXISTS - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.StoreExistenceCheck
- 
Throw if the record store already exists.
- ERROR_IF_NO_INFO_AND_HAS_RECORDS_OR_INDEXES - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.StoreExistenceCheck
- 
Throw if the record store does not have an info header but does have have at least one record.
- ERROR_IF_NO_INFO_AND_NOT_EMPTY - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.StoreExistenceCheck
- 
Throw if the record store does not have an info header but is not empty.
- ERROR_IF_NOT_EXISTS - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
- 
Throw if the record does not already exist.
- ERROR_IF_NOT_EXISTS - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.StoreExistenceCheck
- 
Throw if the record store does not already exist.
- ERROR_IF_NOT_EXISTS_OR_RECORD_TYPE_CHANGED - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
- 
Throw if the record does not already exist or has a different record type.
- ERROR_IF_RECORD_TYPE_CHANGED - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
- 
Throw if an existing record has a different record type.
- errorIfExists() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
- errorIfNotExists() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
- errorIfTypeChanged() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
- ESCHEW_RECORD_COMPRESSION - com.apple.foundationdb.record.provider.common.RecordSerializer.Counts
- 
The number of times that record compression was not effective and the record was kept uncompressed.
- eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
- 
Evaluate this comparison for the value taken from the target record.
- eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
- eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
- eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
- eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- eval(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>) - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
- 
Return whether or not the given record matches this component.
- eval(FDBRecordStoreBase<M>, EvaluationContext, FDBStoredRecord<M>) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- eval(FDBRecordStoreBase<M>, EvaluationContext, SourceEntry) - Method in class com.apple.foundationdb.record.query.predicates.AndPredicate
- eval(FDBRecordStoreBase<M>, EvaluationContext, SourceEntry) - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- eval(FDBRecordStoreBase<M>, EvaluationContext, SourceEntry) - Method in class com.apple.foundationdb.record.query.predicates.NotPredicate
- eval(FDBRecordStoreBase<M>, EvaluationContext, SourceEntry) - Method in class com.apple.foundationdb.record.query.predicates.OrPredicate
- eval(FDBRecordStoreBase<M>, EvaluationContext, SourceEntry) - Method in interface com.apple.foundationdb.record.query.predicates.QueryPredicate
- eval(SourceEntry) - Method in interface com.apple.foundationdb.record.query.plan.temp.view.Element
- 
Evaluate this element with respect to the given source entry, producing an object that can be interpreted by aComparisons.Comparison.
- eval(SourceEntry) - Method in class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- eval(SourceEntry) - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- eval(SourceEntry) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeElement
- eval(SourceEntry) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ValueElement
- eval(SourceEntry) - Method in class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- evalAsync(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>) - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
- 
Asynchronous version ofeval.
- evalComparison(Comparisons.Type, Object, Object) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons
- evalFilter(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- evalFilter(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- evalFilterAsync(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- evalFilterAsync(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- evalForQuery(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in interface com.apple.foundationdb.record.metadata.expressions.QueryableKeyExpression
- evalForQueryAsTuple() - Method in interface com.apple.foundationdb.record.metadata.expressions.QueryableKeyExpression
- evalListComparison(Comparisons.Type, Object, List) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons
- evalMessage(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.AndOrComponent
- evalMessage(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.EmptyComparison
- evalMessage(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
- evalMessage(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.NestedField
- evalMessage(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
- evalMessage(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
- evalMessage(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
- evalMessage(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
- 
Return whether or not the given record matches this component.
- evalMessage(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- evalMessage(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- evalMessage(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- evalMessageAsync(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.AndOrComponent
- evalMessageAsync(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
- evalMessageAsync(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
- 
Asynchronous version ofevalMessage.
- evalMessageAsync(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- evalSourceEntriesFor(SourceEntry) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeSource
- evalSourceEntriesFor(SourceEntry) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RepeatedFieldSource
- evalSourceEntriesFor(SourceEntry) - Method in class com.apple.foundationdb.record.query.plan.temp.view.Source
- 
Produce the stream of source entries that this source represents, drawing the values for dependent sources from the given source entry if needed.
- evalSourceEntriesFor(MessageOrBuilder) - Method in class com.apple.foundationdb.record.query.plan.temp.view.Source
- 
Produce the stream of source entries that this source represents, drawing the value for the input of this source from the givenMessageOrBuilder.
- evaluate(FDBRecord<M>) - Method in class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- evaluate(FDBRecord<M>) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Evaluate against a given record producing a list of evaluated keys.
- evaluate(ExpressionRef<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.temp.properties.ElementPredicateCountProperty
- evaluate(ExpressionRef<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.temp.properties.FieldWithComparisonCountProperty
- evaluate(ExpressionRef<? extends RelationalExpression>, PlanContext) - Static method in class com.apple.foundationdb.record.query.plan.temp.properties.CreatesDuplicatesProperty
- evaluate(PlanContext, ExpressionRef<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.temp.properties.RecordTypesProperty
- evaluate(PlanContext, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.temp.properties.RecordTypesProperty
- evaluate(PlanContext, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.temp.properties.UnmatchedFieldsProperty
- evaluate(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.temp.properties.ElementPredicateCountProperty
- evaluate(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.temp.properties.FieldWithComparisonCountProperty
- evaluate(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.RelationalExpressionDepthProperty
- evaluate(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.temp.properties.TypeFilterCountProperty
- evaluate(RelationalExpression, PlanContext) - Static method in class com.apple.foundationdb.record.query.plan.temp.properties.CreatesDuplicatesProperty
- evaluateAggregateFunction(EvaluationContext, List<String>, IndexAggregateFunction, TupleRange, IsolationLevel) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Evaluate anIndexAggregateFunctionagainst a range of the store.
- evaluateAggregateFunction(IndexAggregateFunction, TupleRange, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- evaluateAggregateFunction(IndexAggregateFunction, TupleRange, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainer
- evaluateAggregateFunction(IndexAggregateFunction, TupleRange, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- evaluateAggregateFunction(IndexAggregateFunction, TupleRange, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainer
- evaluateAggregateFunction(IndexAggregateFunction, TupleRange, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- evaluateAggregateFunction(IndexAggregateFunction, TupleRange, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainer
- evaluateAggregateFunction(IndexAggregateFunction, TupleRange, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Evaluate an aggregate function over the given range using this index.
- evaluateAggregateFunction(IndexAggregateFunction, TupleRange, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- evaluateAggregateFunction(List<String>, IndexAggregateFunction, Key.Evaluated, IsolationLevel) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Evaluate anIndexAggregateFunctionagainst a group value.
- evaluateAggregateFunction(List<String>, IndexAggregateFunction, TupleRange, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- evaluateAggregateFunction(List<String>, IndexAggregateFunction, TupleRange, IsolationLevel) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Evaluate anIndexAggregateFunctionagainst a range of the store.
- evaluateAggregateFunction(List<String>, IndexAggregateFunction, TupleRange, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- evaluateAtExpression(RelationalExpression, List<PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraphProperty
- evaluateAtExpression(RelationalExpression, List<Boolean>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.CreatesDuplicatesProperty
- evaluateAtExpression(RelationalExpression, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.ElementPredicateCountProperty
- evaluateAtExpression(RelationalExpression, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.FieldWithComparisonCountProperty
- evaluateAtExpression(RelationalExpression, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.RelationalExpressionDepthProperty
- evaluateAtExpression(RelationalExpression, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.TypeFilterCountProperty
- evaluateAtExpression(RelationalExpression, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.UnmatchedFieldsProperty
- evaluateAtExpression(RelationalExpression, List<Set<String>>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.RecordTypesProperty
- evaluateAtExpression(RelationalExpression, List<T>) - Method in interface com.apple.foundationdb.record.query.plan.temp.PlannerProperty
- 
Evaluate the property at the given expression, using the results of evaluating the property at its children.
- evaluateAtQuantifier(Quantifier, T) - Method in interface com.apple.foundationdb.record.query.plan.temp.PlannerProperty
- 
Evaluate the property at the given quantifier, using the result of evaluating the property at the reference the quantifier ranges over.
- evaluateAtRef(ExpressionRef<? extends RelationalExpression>, List<PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraphProperty
- evaluateAtRef(ExpressionRef<? extends RelationalExpression>, List<Boolean>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.CreatesDuplicatesProperty
- evaluateAtRef(ExpressionRef<? extends RelationalExpression>, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.ElementPredicateCountProperty
- evaluateAtRef(ExpressionRef<? extends RelationalExpression>, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.FieldWithComparisonCountProperty
- evaluateAtRef(ExpressionRef<? extends RelationalExpression>, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.RelationalExpressionDepthProperty
- evaluateAtRef(ExpressionRef<? extends RelationalExpression>, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.TypeFilterCountProperty
- evaluateAtRef(ExpressionRef<? extends RelationalExpression>, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.UnmatchedFieldsProperty
- evaluateAtRef(ExpressionRef<? extends RelationalExpression>, List<Set<String>>) - Method in class com.apple.foundationdb.record.query.plan.temp.properties.RecordTypesProperty
- evaluateAtRef(ExpressionRef<? extends RelationalExpression>, List<T>) - Method in interface com.apple.foundationdb.record.query.plan.temp.PlannerProperty
- 
Evaluate the property at the given reference, using the results of evaluating the property at its members.
- EVALUATED_INDEX - com.apple.foundationdb.record.logging.LogMessageKeys
- EVALUATED_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
- evaluateFunction(FDBRecord<M>, Message, Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
- evaluateFunction(FDBRecord<M>, Message, Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- 
TheevaluateFunctionmethod implements the function execution.
- evaluateIndex(FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Apply the key and value expressions to arecord.
- evaluateIndexRecordFunction(EvaluationContext, IndexRecordFunction<T>, FDBRecord<Message>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- evaluateIndexRecordFunction(EvaluationContext, IndexRecordFunction<T>, FDBRecord<M>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Evaluate aIndexRecordFunctionagainst a record.
- evaluateIndexRecordFunction(EvaluationContext, IndexRecordFunction<T>, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Evaluate this expression against a record or a Protobuf message.
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- evaluateRecordFunction(EvaluationContext, IndexRecordFunction<T>, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- evaluateRecordFunction(EvaluationContext, IndexRecordFunction<T>, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainer
- evaluateRecordFunction(EvaluationContext, IndexRecordFunction<T>, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- evaluateRecordFunction(EvaluationContext, IndexRecordFunction<T>, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Evaluate a record function on the given record.
- evaluateRecordFunction(EvaluationContext, IndexRecordFunction<T>, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- evaluateRecordFunction(EvaluationContext, RecordFunction<T>, FDBRecord<M>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Evaluate aRecordFunctionagainst a record.
- evaluateRecordFunction(RecordFunction<T>, FDBRecord<M>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Evaluate aRecordFunctionagainst a record.
- evaluateSingleton(FDBRecord<M>) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Evaluate this expression with the expectation of getting exactly one result.
- evaluateStoreFunction(EvaluationContext, StoreRecordFunction<T>, FDBRecord<Message>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- evaluateStoreFunction(EvaluationContext, StoreRecordFunction<T>, FDBRecord<M>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Evaluate aStoreRecordFunctionagainst a record.
- evaluateStoreFunction(EvaluationContext, StoreRecordFunction<T>, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- evaluateStoreFunction(StoreRecordFunction<T>, FDBRecord<M>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Evaluate aStoreRecordFunctionagainst a record.
- evaluateTypedIndexRecordFunction(EvaluationContext, IndexRecordFunction<T>, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- evaluateTypedStoreFunction(EvaluationContext, StoreRecordFunction<T>, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- EvaluationContext - Class in com.apple.foundationdb.record
- 
A context for query evaluation.
- EvaluationContextBuilder - Class in com.apple.foundationdb.record
- 
A builder forEvaluationContext.
- EvaluationContextBuilder() - Constructor for class com.apple.foundationdb.record.EvaluationContextBuilder
- 
Create an empty builder.
- EvaluationContextBuilder(EvaluationContext) - Constructor for class com.apple.foundationdb.record.EvaluationContextBuilder
- 
Create a builder based on an existingEvaluationContext.
- EvaluationContextRequiredException(String) - Constructor for exception com.apple.foundationdb.record.query.expressions.Comparisons.EvaluationContextRequiredException
- exclusiveLock() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Checks the lock state for the resolver and if it is unlocked puts thisLocatableResolverinto a write locked state which will prevent any new entries from being created.
- execute(FDBRecordStore) - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Execute this query plan.
- execute(FDBRecordStore) - Method in interface com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlan
- 
Execute this plan.
- execute(FDBRecordStoreBase<M>) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
- 
Execute this query plan.
- execute(FDBRecordStoreBase<M>, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
- 
Execute this query plan.
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
- 
Execute this query plan.
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithIndex
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- execute(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- execute(FDBRecordStore, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlan
- 
Execute this plan.
- execute(FDBRecordStore, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Execute this query plan.
- execute(FDBRecordStore, EvaluationContext, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Execute this query plan.
- execute(FDBRecordStore, EvaluationContext, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
- execute(FDBRecordStore, FDBStoredRecord<M>) - Method in interface com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordFromStoredRecordPlan
- 
Execute this plan.
- execute(FDBRecordStore, FDBStoredRecord<M>, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordFromStoredRecordPlan
- 
Execute this plan.
- executeEntries(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- executeEntries(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithIndex
- executeEntries(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- ExecuteProperties - Class in com.apple.foundationdb.record
- 
Limits on the execution of a query.
- ExecuteProperties.Builder - Class in com.apple.foundationdb.record
- 
A builder forExecuteProperties.
- executeQuery(RecordQueryPlan) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Execute a query.
- executeQuery(RecordQueryPlan, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Execute a query.
- executeQuery(RecordQuery) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Plan and execute a query.
- executeQuery(RecordQuery, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Plan and execute a query.
- ExecuteState - Class in com.apple.foundationdb.record
- 
An encapsulation of the mutable state of query or scan execution.
- ExecuteState() - Constructor for class com.apple.foundationdb.record.ExecuteState
- ExecuteState(RecordScanLimiter) - Constructor for class com.apple.foundationdb.record.ExecuteState
- 
Deprecated.in favor of the constructor that takes multiple limiters
- ExecuteState(RecordScanLimiter, ByteScanLimiter) - Constructor for class com.apple.foundationdb.record.ExecuteState
- 
Creates an execute state with a supplied set of resource limiters.
- exhausted() - Static method in class com.apple.foundationdb.record.RecordCursorResult
- 
Obtain the static result that a cursor can return when it is completely exhausted.
- existential(ExpressionRef<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- 
Shorthand to create an existential quantifier ranging over a reference.
- existential(ExpressionRef<? extends RelationalExpression>, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- 
Shorthand to create an existential quantifier ranging over a reference using a given alias.
- existential(ExpressionMatcher<? extends Bindable>) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.QuantifierMatcher
- 
Matches aQuantifier.Existentialquantifier together with the given matcher for itsrangesOver().
- existentialBuilder() - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- 
Create a builder for an existential quantifier containing relational expressions.
- ExistentialBuilder() - Constructor for class com.apple.foundationdb.record.query.plan.temp.Quantifier.Existential.ExistentialBuilder
- existentialQuantifiers(Iterable<? extends ExpressionRef<E>>) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifiers
- 
Create a list of existential quantifiers from a list of expression references these quantifiers should range over.
- exists(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- EXPECTED_CHILD_COUNT - com.apple.foundationdb.record.logging.LogMessageKeys
- EXPECTED_COLUMN_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
- EXPECTED_INDEX - com.apple.foundationdb.record.logging.LogMessageKeys
- EXPECTED_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- EXPECTED_VALUE_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- explain(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraphProperty
- 
Generate the explain of the planner expression that is passed in.
- explain(RelationalExpression, Map<String, Attribute>) - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraphProperty
- 
Generate the explain of the planner expression that is passed in.
- ExplainPlannerGraphRewritable - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Interface to allowRelationalExpressions to rewrite their own explain graph representation.
- EXPLICIT - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
- ExporterContext(ImmutableNetwork<N, E>, PrintWriter) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter.ExporterContext
- exportGraph(ImmutableNetwork<N, E>, Writer) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Exports a network in DOT format.
- exportLogInfo() - Method in exception com.apple.foundationdb.record.LoggableTimeoutException
- exportToDot(AbstractPlannerGraph<PlannerGraph.Node, PlannerGraph.Edge>) - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraphProperty
- 
Creates a serialized format of this graph as a dot-compatible definition.
- exportToGml(PlannerGraph, Map<String, Attribute>) - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraphProperty
- 
Creates a serialized format of this graph as a gml-compatible definition.
- ExpressionChildrenMatcher - Interface in com.apple.foundationdb.record.query.plan.temp.matchers
- 
AnExpressionChildrenMatcherdescribes how to match the children of aRelationalExpression(i.e., the references returned by theRelationalExpression.getQuantifiers()method).
- ExpressionMatcher<T extends Bindable> - Interface in com.apple.foundationdb.record.query.plan.temp.matchers
- 
AExpressionMatcheris an expression that can be matched against aRelationalExpressiontree, while binding certain expressions/references in the tree to expression matcher objects.
- ExpressionRef<T extends RelationalExpression> - Interface in com.apple.foundationdb.record.query.plan.temp
- 
This interface is used mostly as an (admittedly surmountable) barrier to rules mutating bound references directly, which is undefined behavior.
- ExpressionRef.UngettableReferenceException - Exception in com.apple.foundationdb.record.query.plan.temp
- 
An exception thrown whenExpressionRef.get()is called on a reference that does not support it, such as a group reference.
- ExpressionRefDelegate<T extends RelationalExpression> - Class in com.apple.foundationdb.record.query.plan.temp
- 
An expression reference that wraps another expression reference.
- ExpressionRefDelegate(ExpressionRef<T>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- ExpressionRefHeadNode(ExpressionRef<? extends RelationalExpression>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefHeadNode
- ExpressionRefMemberNode() - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefMemberNode
- ExpressionRefTraversal - Class in com.apple.foundationdb.record.query.plan.temp
- 
Utility class to provide a view on a graph given by a root expression reference (to aRelationalExpressionthat allows to perform traversal operations that are normally not possible on instances ofExpressionRefsuch asExpressionRefTraversal.getLeaves()andExpressionRefTraversal.FullyTraversableExpressionRef.getParentRefs().
- ExpressionRefTraversal.FullyTraversableExpressionRef<T extends RelationalExpression> - Class in com.apple.foundationdb.record.query.plan.temp
- 
Expression reference that provides some additional functionality to navigate to parents, leaves, etc.
- ExpressionRefTraversal.RefPath - Class in com.apple.foundationdb.record.query.plan.temp
- 
Case class to hold information about the path from an expression to another expression reference.
- EXTENDED_DIRECTORY_LAYER_CREATE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent adding a new entry to anExtendedDirectoryLayer.
- EXTENDED_DIRECTORY_LAYER_READ - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent reading an entry from anExtendedDirectoryLayer.
- ExtendedDirectoryLayer - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
An implementation ofLocatableResolverthat uses a key format that is compatible with theScopedDirectoryLayerto keep track of the allocation of strings to integers.
- ExtendedDirectoryLayer(FDBDatabase, ResolvedKeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- 
Create an extended directory layer.
- ExtendedDirectoryLayer(FDBRecordContext, KeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- 
Deprecated.
F
- FAIL - com.apple.foundationdb.record.logging.TestLogMessageKeys
- fan(List<Object>) - Static method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
Fanout a list of scalars into a key for each value.
- FanOut - com.apple.foundationdb.record.metadata.expressions.KeyExpression.FanType
- 
Create an index value for each value of the field.
- FDBDatabase - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A known FDBDatabase, associated with a cluster file location.
- FDBDatabase(FDBDatabaseFactory, String) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- FDBDatabase.ExceptionMapper - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
Function for mapping an underlying exception to a synchronous failure.
- FDBDatabase.WeakReadSemantics - Class in com.apple.foundationdb.record.provider.foundationdb
- 
1.
- FDBDatabaseFactory - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A singleton maintaining a list ofFDBDatabaseinstances, indexed by their cluster file location.
- FDBDatabaseFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- FDBDatabaseRunner - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
A context for running against anFDBDatabasewith retrying of transient exceptions.
- FDBDatabaseRunner.RunnerClosed - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown whenFDBDatabaseRunnerhas been closed but tries to do work.
- FDBDatabaseRunnerImpl - Class in com.apple.foundationdb.record.provider.foundationdb
- 
The standard implementation ofFDBDatabaseRunner.
- FDBExceptions - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Namespace for exceptions that wrap the underlying exceptions from the FDB API.
- FDBExceptions.FDBStoreException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exceptions that are reported by (or due to limitations of, etc.) the FDB API.
- FDBExceptions.FDBStoreKeySizeException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown when key size is exceeded.
- FDBExceptions.FDBStoreRetriableException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
An exception that should be retried by the caller because is stems from a transient condition in FDB.
- FDBExceptions.FDBStoreTransactionConflictException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Transaction failed due to a conflict with another transaction.
- FDBExceptions.FDBStoreTransactionIsTooOldException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Transaction is too old to perform reads or be committed.
- FDBExceptions.FDBStoreTransactionSizeException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown when transaction size is exceeded.
- FDBExceptions.FDBStoreTransactionTimeoutException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown when a transaction times out.
- FDBExceptions.FDBStoreValueSizeException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown when value size is exceeded.
- FDBIndexableRecord<M extends Message> - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
A record that can be passed to an index maintainer.
- FDBIndexedRecord<M extends Message> - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A record that has been loaded via an index.
- FDBIndexedRecord(IndexEntry, FDBStoredRecord<M>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- 
Wrap a stored record with an index entry that pointed to it.
- FDBIndexedRecord(Index, IndexEntry, FDBStoredRecord<M>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- 
Deprecated.useFDBIndexedRecord(IndexEntry, FDBStoredRecord)instead
- FDBLatencySource - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
Indicates which FDB API calls are to have latency injected into them viaFDBDatabaseFactory.setLatencyInjector(Function).
- FDBLocalityProvider - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
An interface containing a set of functions for discovering the location of the keys within a cluster.
- FDBLocalityUtil - Class in com.apple.foundationdb.record.provider.foundationdb
- 
An implementation of theFDBLocalityProviderinterface that uses foundationDB'sLocalityUtilAPI to discover the storage locations of keys within a cluster.
- FDBMetaDataStore - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Serialization ofRecordMetaDatainto the database.
- FDBMetaDataStore(FDBRecordContext, KeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- FDBMetaDataStore(FDBRecordContext, Subspace, MetaDataCache) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- FDBMetaDataStore.MissingMetaDataException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Thrown if meta-data was never written to the store.
- FDBQueriedRecord<M extends Message> - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A record returned by a query and therefore possibly associated with a particular entry in some index.
- FDBQueriedRecord() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
- FDBRecord<M extends Message> - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
A record associated with the corresponding meta-data.
- FDBRecordContext - Class in com.apple.foundationdb.record.provider.foundationdb
- 
An open transaction against FDB.
- FDBRecordContext(FDBDatabase, Transaction, FDBRecordContextConfig) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- FDBRecordContext.AfterCommit - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
A hook to run after commit has completed successfully.
- FDBRecordContext.CommitCheck - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
A synchronousFDBRecordContext.CommitCheckAsync.
- FDBRecordContext.CommitCheckAsync - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
A consistency check, such as uniqueness, that can execute asynchronously and is finally checked at or before commit time.
- FDBRecordContext.PostCommit - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
A supplier of a future to be executed after the transaction has been successfully committed.
- FDBRecordContextConfig - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A configuration struct that can be used to set various options on anFDBRecordContext.
- FDBRecordContextConfig.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A builder ofFDBRecordContextConfigs using the standard builder pattern.
- FDBRecordStore - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A multi-type record store.
- FDBRecordStore(FDBRecordContext, SubspaceProvider, int, RecordMetaDataProvider, RecordSerializer<Message>, IndexMaintainerRegistry, IndexMaintenanceFilter, FDBRecordStoreBase.PipelineSizer, FDBRecordStoreStateCache) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- FDBRecordStore.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A builder forFDBRecordStore.
- FDBRecordStore.IndexNotBuiltException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception that can be thrown if one attempts to mark an index as readable if it is not yet readable.
- FDBRecordStore.RebuildIndexReason - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
Reason that an index is being rebuilt now.
- FDBRecordStoreBase<M extends Message> - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
Base interface for typed and untyped record stores.
- FDBRecordStoreBase.BaseBuilder<M extends Message,R extends FDBRecordStoreBase<M>> - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
Builder forFDBRecordStoreBase.
- FDBRecordStoreBase.PipelineSizer - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
Function for computing the number of elements to allow in the asynchronous pipeline for an operation of the given type.
- FDBRecordStoreBase.RecordExistenceCheck - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
Action to take if the record being saved does / does not already exist.
- FDBRecordStoreBase.StoreExistenceCheck - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
Action to take if the record store does / does not already exist.
- FDBRecordStoreBase.UserVersionChecker - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
Hook for checking if store state for client changes.
- FDBRecordStoreBase.VersionstampSaveBehavior - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
Provided during record save (viaFDBRecordStoreBase.saveRecord(Message, FDBRecordVersion, VersionstampSaveBehavior)), directs the behavior of the save w.r.t.
- FDBRecordStoreKeyspace - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
Unique integers used as the first tuple item within a record store's subspace.
- FDBRecordStoreStateCache - Interface in com.apple.foundationdb.record.provider.foundationdb.storestate
- 
A cache forFDBRecordStoreStateCacheEntryobjects.
- FDBRecordStoreStateCacheEntry - Class in com.apple.foundationdb.record.provider.foundationdb.storestate
- 
Information needed to initialize anFDBRecordStorethat is not stored within the record store'sRecordMetaData.
- FDBRecordStoreStateCacheFactory - Interface in com.apple.foundationdb.record.provider.foundationdb.storestate
- 
A factory interface forFDBRecordStoreStateCaches.
- FDBRecordVersion - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Class representing a specific version within FDB.
- FDBRecordVersion.IncompleteRecordVersionException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception that can be thrown if one tries to get the global version associated with a version whose global version has not yet been set.
- FDBReverseDirectoryCache - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A persistent cache providing reverse lookup facilities from the FDBDirectoryLayer.
- FDBReverseDirectoryCache(FDBDatabase) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- FDBReverseDirectoryCache(FDBDatabase, int, long) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- FDBStoreBase - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Base class for record stores and meta-data stores, which have in common that they are opened by anFDBRecordContextand occupy someSubspacein the database.
- FDBStoreBase(FDBRecordContext, SubspaceProvider) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- FDBStoreBase(FDBRecordContext, Subspace) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- FDBStoredRecord<M extends Message> - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A record stored in the database.
- FDBStoredRecord(Tuple, RecordType, M, int, int, int, boolean, boolean, FDBRecordVersion) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- FDBStoredRecord(Tuple, RecordType, M, FDBStoredSizes, FDBRecordVersion) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- FDBStoredRecordBuilder<M extends Message> - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A builder forFDBStoredRecord.
- FDBStoredRecordBuilder() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- FDBStoredRecordBuilder(M) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- FDBStoredSizes - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
Information about how a record is stored in the database.
- FDBStoreException(FDBException) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreException
- FDBStoreException(String) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreException
- FDBStoreException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreException
- FDBStoreKeySizeException(FDBException) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreKeySizeException
- FDBStoreKeySizeException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreKeySizeException
- FDBStoreRetriableException(FDBException) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreRetriableException
- FDBStoreTimer - Class in com.apple.foundationdb.record.provider.foundationdb
- 
AStoreTimerassociated withFDBRecordStoreoperations.
- FDBStoreTimer() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer
- FDBStoreTimer.CountAggregates - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
An aggregate over other count events.
- FDBStoreTimer.Counts - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
StandardStoreTimer.Countevents.
- FDBStoreTimer.DetailEvents - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
StandardStoreTimer.DetailEvents.
- FDBStoreTimer.Events - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
Ordinary top-level events which surround a single body of code.
- FDBStoreTimer.Waits - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
StandardStoreTimer.Waitevents.
- FDBStoreTransactionConflictException(FDBException) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreTransactionConflictException
- FDBStoreTransactionIsTooOldException(FDBException) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreTransactionIsTooOldException
- FDBStoreTransactionSizeException(FDBException) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreTransactionSizeException
- FDBStoreTransactionTimeoutException(FDBException) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreTransactionTimeoutException
- FDBStoreValueSizeException(FDBException) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreValueSizeException
- FDBStoreValueSizeException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreValueSizeException
- FDBSyntheticRecord - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A record synthesized from stored records.
- FDBSyntheticRecord(Tuple, SyntheticRecordType<?>, Message, FDBStoredSizes, Map<String, FDBStoredRecord<? extends Message>>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- FDBTraceFormat - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
The FoundationDB native client can be configured to emit its trace logs (containing important metrics and instrumentation information) in one of several different formats.
- FDBTransactionContext - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Wrapper class for an open FDBTransaction.
- FDBTransactionContext(FDBDatabase, Transaction, FDBStoreTimer) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- FDBTransactionPriority - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
An enum indicating the priority of transactions against FoundationDB.
- FDBTypedRecordStore<M extends Message> - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A type-safe record store.
- FDBTypedRecordStore(FDBRecordStore, RecordSerializer<M>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- FDBTypedRecordStore.Builder<M extends Message> - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A builder forFDBTypedRecordStore.
- FETCH_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- fetchIndexRecords(Index, RecordCursor<IndexEntry>, IndexOrphanBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Deprecated.
- fetchIndexRecords(Index, RecordCursor<IndexEntry>, IndexOrphanBehavior, ExecuteState) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Deprecated.
- fetchIndexRecords(RecordCursor<IndexEntry>, IndexOrphanBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Given a cursor that iterates over entries in an index, attempts to fetch the associated records for those entries.
- fetchIndexRecords(RecordCursor<IndexEntry>, IndexOrphanBehavior, ExecuteState) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Given a cursor that iterates over entries in an index, attempts to fetch the associated records for those entries.
- FEW_RECORDS - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
- field(String) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Create an expression of a single scalar (i.e.
- field(String) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
Creates a new Field context.
- field(String, KeyExpression.FanType) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Creates an expression of a field.
- field(String, KeyExpression.FanType, Key.Evaluated.NullStandin) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Creates an expression of a field.
- Field - Class in com.apple.foundationdb.record.query.expressions
- 
Class that provides context for asserting about a field value.
- Field(String) - Constructor for class com.apple.foundationdb.record.query.expressions.Field
- FIELD_COMPARATOR - Static variable in class com.apple.foundationdb.record.provider.foundationdb.cursors.KeyComparisons
- FIELD_NAME - com.apple.foundationdb.record.logging.LogMessageKeys
- Field.OneOfThemEmptyMode - Enum in com.apple.foundationdb.record.query.expressions
- 
How an empty / unset repeated field should be handled.
- FieldElement - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
An element that extracts a single, non-repeated field (at an arbitrary nesting depth) from a source.
- FieldElement(Source, String) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- FieldElement(Source, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- FieldKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
Take keys from a record field.
- FieldKeyExpression(RecordMetaDataProto.Field) - Constructor for class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- FieldKeyExpression(String, KeyExpression.FanType, Key.Evaluated.NullStandin) - Constructor for class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- FieldWithComparison - Class in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentthat implements aComparisons.Comparisonagainst a field of the record.
- FieldWithComparison(String, Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.expressions.FieldWithComparison
- FieldWithComparisonCountProperty - Class in com.apple.foundationdb.record.query.plan.temp.properties
- 
A property that counts the number ofFieldWithComparisons that appear in a planner expression tree.
- FieldWithComparisonCountProperty() - Constructor for class com.apple.foundationdb.record.query.plan.temp.properties.FieldWithComparisonCountProperty
- filter - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
- filter(Function<T, Boolean>) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that skips records that do not satisfy the given predicate.
- FILTER - com.apple.foundationdb.record.logging.LogMessageKeys
- filterAsync(Function<T, CompletableFuture<Boolean>>, int) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that skips records that do not satisfy the given asynchronous predicate.
- filterAsyncInstrumented(Function<T, CompletableFuture<Boolean>>, int, StoreTimer, StoreTimer.Count, StoreTimer.Event, StoreTimer.Count, StoreTimer.Count) - Method in interface com.apple.foundationdb.record.RecordCursor
- filterAsyncInstrumented(Function<T, CompletableFuture<Boolean>>, int, StoreTimer, Set<StoreTimer.Count>, Set<StoreTimer.Event>, Set<StoreTimer.Count>, Set<StoreTimer.Count>) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that skips records that do not satisfy the given asynchronous predicate, while instrumenting the number of records that the filter sees, the number that it passes, the number that it fails, and the amount of time that it spends computing the predicate.
- FilterCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that filters elements using a predicate.
- FilterCursor(RecordCursor<T>, Function<T, Boolean>) - Constructor for class com.apple.foundationdb.record.cursors.FilterCursor
- filteredIndexEntries(FDBIndexableRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Filter out index keys according toIndexMaintenanceFilter.
- filterInstrumented(Function<T, Boolean>, StoreTimer, StoreTimer.Count, StoreTimer.Event, StoreTimer.Count, StoreTimer.Count) - Method in interface com.apple.foundationdb.record.RecordCursor
- filterInstrumented(Function<T, Boolean>, StoreTimer, Set<StoreTimer.Count>, Set<StoreTimer.Event>, Set<StoreTimer.Count>, Set<StoreTimer.Count>) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that skips records that do not satisfy the given predicate, while instrumenting the number of records that the filter sees, the number that it passes, the number that it fails, and the amount of time that it spends computing the predicate.
- FilterSatisfiedMask - Class in com.apple.foundationdb.record.query.plan.planning
- 
A mask that can be applied over aQueryComponentto determine whether a filter and any sub-filters or child components have been satisfied.
- FilterSatisfiedMask.FilterMismatchException - Exception in com.apple.foundationdb.record.query.plan.planning
- 
Thrown in instances where one expects the underlying filter associated with anotherFilterSatisfiedMaskto match this one but they do not.
- FilterSatisfiedMask.FilterNotFoundException - Exception in com.apple.foundationdb.record.query.plan.planning
- 
Thrown if the user requests a child mask from a component, but the mask does not contain that component in any of its children.
- FilterVisitor - Class in com.apple.foundationdb.record.query.plan.visitor
- 
A substitution visitor that pushes a filter below a record fetch if all of the (non-repeated) field are available in a covering scan.
- FilterVisitor(RecordMetaData, PlannableIndexTypes, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.visitor.FilterVisitor
- FilterWithElementWithComparisonRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rewrite rule that turns a logical filter on the results of a full scan (without a sort) into an index scan on a compatibly ordered index.
- FilterWithElementWithComparisonRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.FilterWithElementWithComparisonRule
- findChildForKey(FDBRecordContext, ResolvedKeySpacePath, Tuple, int, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Iterates over the subdirectories of this directory looking for one that is compatible with thekeytuple, starting at positionkeyIndex.
- findChildForValue(FDBRecordContext, ResolvedKeySpacePath, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Iterates over the subdirectories of this directory looking for one that is compatible with the given value.
- findFieldDescriptor(MessageOrBuilder) - Method in class com.apple.foundationdb.record.query.expressions.BaseField
- findFieldDescriptorOnMessage(MessageOrBuilder, String) - Static method in class com.apple.foundationdb.record.query.plan.temp.view.MessageValue
- findLeaderboard(int, long, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- FindPossibleIndexForAndPredicateRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule that finds all indexes that could implement one of theComponentWithComparisonconjuncts of an AND filter, leaving all the other filters (of any type, including other fields) as a residual filter.
- FindPossibleIndexForAndPredicateRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.FindPossibleIndexForAndPredicateRule
- first() - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Fetches the first item returned by the cursor.
- firstInDBVersion(long) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Return the firstFDBRecordVersionthat could be written at a given database version or later.
- firstInGlobalVersion(byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Return the firstFDBRecordVersionthat could be written at the given global version.
- firstUnbuiltRange(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Returns the first unbuilt range of an index that is currently being bulit.
- flatMapNullable(Function<T, ExpressionRef<U>>) - Method in interface com.apple.foundationdb.record.query.plan.temp.ExpressionRef
- flatMapNullable(Function<T, ExpressionRef<U>>) - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- flatMapNullable(Function<T, ExpressionRef<U>>) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- flatMapPipelined(Function<byte[], ? extends RecordCursor<T>>, BiFunction<T, byte[], ? extends RecordCursor<V>>, byte[], int) - Static method in interface com.apple.foundationdb.record.RecordCursor
- flatMapPipelined(Function<byte[], ? extends RecordCursor<T>>, BiFunction<T, byte[], ? extends RecordCursor<V>>, Function<T, byte[]>, byte[], int) - Static method in interface com.apple.foundationdb.record.RecordCursor
- 
Resume a nested cursor with the given continuation or start ifnull.
- flatMapPipelined(Function<T, ? extends RecordCursor<V>>, int) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Deprecated.because it does not support continuations and is easy to misuse. UseRecordCursor.flatMapPipelined(Function, BiFunction, byte[], int)instead.
- FlatMapPipelinedCursor<T,V> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that maps elements to another cursor which is then flattened.
- FlatMapPipelinedCursor(RecordCursor<T>, BiFunction<T, byte[], ? extends RecordCursor<V>>, Function<T, byte[]>, byte[], byte[], byte[], int) - Constructor for class com.apple.foundationdb.record.cursors.FlatMapPipelinedCursor
- flatten() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Flattens the path into a list ofKeySpacePathentries, with the root of the path located at position 0.
- flatten() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- flatten() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Flattens the path into a list ofResolvedKeySpacePathentries, with the root of the path located at position 0.
- flattenForPlanner() - Method in class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- flattenForPlanner() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Flatten this key expression into a list ofElements, much likeKeyExpression.normalizeKeyForPositions().
- flattenForPlanner() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- FlattenNestedAndPredicateRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A simple rule that performs some basic Boolean normalization by flattening a nestedAndPredicateinto a single, wider AND.
- FlattenNestedAndPredicateRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.FlattenNestedAndPredicateRule
- FLOAT - com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- forBinding(String, Object) - Static method in class com.apple.foundationdb.record.EvaluationContext
- 
Create a newEvaluationContextwith a single binding.
- forBindings(Bindings) - Static method in class com.apple.foundationdb.record.EvaluationContext
- 
Create a newEvaluationContextaround a given set ofBindingsfrom parameter names to values.
- FORCE_BUILD - com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
- 
Rebuild the index anyway, no matter it it disabled or write-only or readable.
- forceAllocate(String, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
- forceSetMaxSuppressedCountForTesting(int) - Static method in class com.apple.foundationdb.record.logging.CompletionExceptionLogHelper
- 
Change the maximum number of suppressed exceptions to add to any given exception, even if the maximum has already been set.
- forConfiguration(RecordQueryPlannerConfiguration) - Static method in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
- 
Obtain a normalizer for the given planner configuration.
- forEach(ExpressionRef<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- 
Shorthand to create a for-each quantifier ranging over a reference.
- forEach(ExpressionRef<? extends RelationalExpression>, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- 
Shorthand to create a for-each quantifier ranging over a reference using a given alias.
- forEach(ExpressionMatcher<? extends Bindable>) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.QuantifierMatcher
- 
Matches aQuantifier.ForEachquantifier together with the given matcher for itsrangesOver().
- forEach(Consumer<T>) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Call the given consumer as each record becomes available.
- forEachAsync(Function<T, CompletableFuture<Void>>, int) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Call the function as each record becomes available.
- forEachBuilder() - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- 
Create a builder for a for-each quantifier containing relational expressions.
- ForEachBuilder() - Constructor for class com.apple.foundationdb.record.query.plan.temp.Quantifier.ForEach.ForEachBuilder
- forEachQuantifiers(Iterable<ExpressionRef<E>>) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifiers
- 
Create a list of for-each quantifiers from a list of references to range over.
- forEachResult(Consumer<RecordCursorResult<T>>) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Call the given consumer as each record result becomes available.
- forEachResultAsync(Function<RecordCursorResult<T>, CompletableFuture<Void>>) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Call the function as each record result becomes available.
- forExplain() - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraphProperty
- forIndex(Index) - Method in class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
- 
Construct a plan for generating synthetic records for a given index.
- forInternalShow(boolean) - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraphProperty
- forJoinConstituent(JoinedRecordType, JoinedRecordType.JoinConstituent) - Method in class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
- 
Construct a plan for generating synthetic records from a constituent of a joined record type.
- FORMAT_CONTROL_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- FORMAT_VERSION - com.apple.foundationdb.record.logging.LogMessageKeys
- formatVersion - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- FormerIndex - Class in com.apple.foundationdb.record.metadata
- 
The location where a deleted index used to live.
- FormerIndex(RecordMetaDataProto.FormerIndex) - Constructor for class com.apple.foundationdb.record.metadata.FormerIndex
- FormerIndex(Object, int, int, String) - Constructor for class com.apple.foundationdb.record.metadata.FormerIndex
- forPlan(RecordMetaData, RecordQueryPlan, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
- forRecordStoreAndIndex(FDBRecordStore, String) - Static method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Create an online indexer for the given record store and index.
- forRoot(FDBRecordContext, KeySpacePath) - Static method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
- forRoot(FDBRecordContext, Subspace, Subspace) - Static method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
- forType(JoinedRecordType) - Method in class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
- 
Construct a plan for generating all joined records of a given type.
- forType(SyntheticRecordType<?>) - Method in class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
- 
Construct a plan for generating all synthetic records of a given type.
- FORWARD_SCAN - Static variable in class com.apple.foundationdb.record.ScanProperties
- FOUND_INDEX - com.apple.foundationdb.record.logging.LogMessageKeys
- FoundSplitWithoutStartException(long, boolean) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.SplitHelper.FoundSplitWithoutStartException
- from(StoreTimer) - Static method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
- 
Creates an immutable snapshot of aStoreTimer.
- from(StoreTimer.Counter) - Static method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot.CounterSnapshot
- 
Creates an immutable snapshot of aStoreTimer.Counter.
- from(Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- from(Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- from(RecordQueryPlan, RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
- from(RecordQueryPlan, RecordQueryPlan, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- 
Construct a new union of two compatibly-ordered plans.
- from(RecordQueryPlan, RecordQueryPlan, KeyExpression, boolean) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- 
Construct a new union of two compatibly-ordered plans.
- from(ExpressionRef<T>) - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefTraversal
- from(ExpressionMatcher<? extends Bindable>, Bindable) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.PlannerBindings
- 
Build a new set of bindings containing a single binding from the given key to the given bindable.
- from(Source, Object) - Static method in class com.apple.foundationdb.record.query.plan.temp.view.SourceEntry
- from(Collection<T>) - Static method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- from(Function<byte[], RecordCursor<T>>, RecordCursorContinuation) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
- from(List<? extends QueryComponent>) - Static method in class com.apple.foundationdb.record.query.expressions.AndComponent
- from(List<QueryComponent>) - Static method in class com.apple.foundationdb.record.query.expressions.OrComponent
- from(List<RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
- from(List<RecordQueryPlan>, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- 
Construct a new union of two or more compatibly-ordered plans.
- from(List<RecordQueryPlan>, KeyExpression, boolean) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- 
Construct a new union of two or more compatibly-ordered plans.
- from(Q) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Builder
- fromBytes(byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Create aFDBRecordVersionfrom the given serialized bytes.
- fromBytes(byte[], boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Create aFDBRecordVersionfrom the given serialized bytes.
- fromCode(Object) - Static method in enum com.apple.foundationdb.record.IndexState
- fromCommonPrimaryKey(Collection<String>, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.temp.IndexEntrySource
- fromDescriptor(Descriptors.FieldDescriptor) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Convert a field descriptor into a expression.
- fromExpressions(Iterable<? extends ExpressionRef<E>>, Function<ExpressionRef<E>, Q>) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifiers
- 
Create a list of quantifiers given a list of references these quantifiers should range over.
- fromFuture(CompletableFuture<T>) - Static method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that has the contents of the given future as its only record The record will be available when the future is complete.
- fromFuture(Executor, CompletableFuture<T>) - Static method in interface com.apple.foundationdb.record.RecordCursor
- fromFuture(Executor, CompletableFuture<T>, byte[]) - Static method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that has the contents of the given future as its only record.
- fromIndex(RecordType, Index, PlannableIndexTypes, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields
- fromIndex(Collection<RecordType>, Index) - Static method in class com.apple.foundationdb.record.query.plan.temp.IndexEntrySource
- fromIndexDefinition(String, Collection<String>, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpression
- 
Generate a view expression that represents the structure of an index defined using aKeyExpression.
- fromIndexWithTypeStrings(Collection<String>, Index) - Static method in class com.apple.foundationdb.record.query.plan.temp.IndexEntrySource
- fromInt(int) - Static method in class com.apple.foundationdb.record.ByteArrayContinuation
- 
Return aRecordCursorContinuationthat wraps a byte array consisting of the given integer.
- fromIterator(Executor, Iterator<T>) - Static method in interface com.apple.foundationdb.record.RecordCursor
- fromIterator(Iterator<T>) - Static method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor from an ordinaryIterator.
- fromKey(Object) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- fromList(Executor, List<T>) - Static method in interface com.apple.foundationdb.record.RecordCursor
- fromList(Executor, List<T>, byte[]) - Static method in interface com.apple.foundationdb.record.RecordCursor
- fromList(List<T>) - Static method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor from an ordinaryList.
- fromList(List<T>, byte[]) - Static method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor from an ordinaryList, skipping ahead according to the given continuation.
- fromNodeAndChildGraphs(PlannerGraph.Node, List<? extends PlannerGraph>) - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph
- fromNullable(byte[]) - Static method in class com.apple.foundationdb.record.ByteArrayContinuation
- 
Return aRecordCursorContinuationfrom a byte array.
- fromPlans(Iterable<? extends ExpressionRef<E>>) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifiers
- 
Create a list of physical quantifiers given a list of references these quantifiers should range over.
- fromProto(RecordMetaDataProto.Function) - Static method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- 
Create a function from its protobuf serialized form.
- fromProto(RecordMetaDataProto.KeyExpression) - Static method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- fromProto(RecordMetaDataProto.Value) - Static method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- fromProto(TupleFieldsProto.NullableBool) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a ProtobufNullableBoolto a Javaboolean.
- fromProto(TupleFieldsProto.NullableBytes) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a ProtobufNullableBytesto a JavaByteString.
- fromProto(TupleFieldsProto.NullableDouble) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a ProtobufNullableDoubleto a Javadouble.
- fromProto(TupleFieldsProto.NullableFloat) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a ProtobufNullableFloatto a Javafloat.
- fromProto(TupleFieldsProto.NullableInt32) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a ProtobufNullableInt32to a Javaint.
- fromProto(TupleFieldsProto.NullableInt64) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a ProtobufNullableInt64to a Javalong.
- fromProto(TupleFieldsProto.NullableString) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a ProtobufNullableStringto a JavaString.
- fromProto(TupleFieldsProto.UUID) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a ProtobufUUIDto a JavaUUID.
- fromProto(Message, Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a field's value from a message to aTupleitem.
- fromProtoValue(RecordMetaDataProto.Value) - Static method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- fromRecordQuery(RecordQuery, PlanContext) - Static method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpression
- fromStoredType(RecordType, boolean) - Method in class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
- 
Construct a plan for generating synthetic records from a record of a given stored record type.
- fromTuple(Tuple) - Static method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
Take aTupleand create the corresponding key from it.
- fromVersionstamp(Versionstamp) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Create aFDBRecordVersionfrom the givenVersionstampinstance.
- fromVersionstamp(Versionstamp, boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Create aFDBRecordVersionfrom the givenVersionstampinstance.
- FullUnorderedExpressionToScanPlanRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule for implementing aFullUnorderedScanExpressionas aRecordQueryScanPlanof the full primary key space.
- FullUnorderedExpressionToScanPlanRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.FullUnorderedExpressionToScanPlanRule
- FullUnorderedScanExpression - Class in com.apple.foundationdb.record.query.plan.temp.expressions
- 
A planner expression representing a full, unordered scan of the records by primary key, which is the logical version of aRecordQueryScanPlanwithScanComparisons.EMPTY.
- FullUnorderedScanExpression(Set<String>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.FullUnorderedScanExpression
- FullyTraversableExpressionRef(ExpressionRef<T>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.ExpressionRefTraversal.FullyTraversableExpressionRef
- function(String) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Create a function call with arguments that will result in a key expression.
- function(String, KeyExpression) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Create a function call with arguments that will result in a key expression.
- FUNCTION - com.apple.foundationdb.record.logging.LogMessageKeys
- FUNCTION_NAME - Static variable in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpressionFactoryJRE
- FunctionKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
AFunctionKeyExpressionis aKeyExpressionthat is dynamically loaded and defined by aStringname and aKey.Expressionthat produces sets of arguments to which the function is to be evaluated.
- FunctionKeyExpression(String, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- FunctionKeyExpression.BiFunctionBuilder - Class in com.apple.foundationdb.record.metadata.expressions
- 
An implementation of aBuilderthat can construct aKeyExpressionFunctionvia a provided generator.
- FunctionKeyExpression.Builder - Class in com.apple.foundationdb.record.metadata.expressions
- 
A builder is capable of producing an instance of aFunctionKeyExpressiongiven the arguments to the function.
- FunctionKeyExpression.Factory - Interface in com.apple.foundationdb.record.metadata.expressions
- 
Implementations ofFunctionKeyExpression.Factoryare dynamically located by theFunctionKeyExpression.Registryand are polled once to request a list of builders for functions that the factory is capable of producing.
- FunctionKeyExpression.Registry - Class in com.apple.foundationdb.record.metadata.expressions
- 
TheRegistrymaintains a mapping from a function name to aBuildercapable of producing an instance of the function.
- functionName - Variable in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression.Builder
- FunctionNames - Class in com.apple.foundationdb.record
- 
Names of core-supported query functions.
- FUTURE_COMPLETED - com.apple.foundationdb.record.logging.LogMessageKeys
- FutureCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that returns a single element when a future completes.
- FutureCursor(Executor, CompletableFuture<T>) - Constructor for class com.apple.foundationdb.record.cursors.FutureCursor
G
- get() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext.PostCommit
- get() - Method in interface com.apple.foundationdb.record.query.plan.temp.ExpressionRef
- 
Return the expression contained in this reference.
- get() - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- get() - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- get() - Method in class com.apple.foundationdb.record.RecordCursorResult
- 
Return the value of this result.
- get(FDBRecordStore, FDBRecordStoreBase.StoreExistenceCheck) - Method in interface com.apple.foundationdb.record.provider.foundationdb.storestate.FDBRecordStoreStateCache
- 
Load the record store state for the record store stored at the given location.
- get(FDBRecordStore, FDBRecordStoreBase.StoreExistenceCheck) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCache
- get(FDBRecordStore, FDBRecordStoreBase.StoreExistenceCheck) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.PassThroughRecordStoreStateCache
- get(FDBRecordStore, FDBRecordStoreBase.StoreExistenceCheck) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.ReadVersionRecordStoreStateCache
- get(FDBStoreTimer, ScopedValue<Long>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
Retrieves the name of the directory entry corresponding to the value of that entry in the directory layer.
- get(ScopedValue<Long>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
Retrieves the name of the directory entry corresponding to the value of that entry in the directory layer.
- get(ExpressionMatcher<T>) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.PlannerBindings
- 
Retrieve the single bindable bound tokey.
- get(ExpressionMatcher<U>) - Method in interface com.apple.foundationdb.record.query.plan.temp.PlannerRuleCall
- 
Return the bindable that is bound to the given key.
- get(String) - Method in class com.apple.foundationdb.record.Bindings.Builder
- get(String) - Method in class com.apple.foundationdb.record.Bindings
- get(CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Get a future, following the same logic thatasyncToSync()uses to validate that the operation isn't blocking in an asynchronous context.
- get(CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get a future following the same logic thatasyncToSync()uses to validate that the operation isn't blocking in an asynchronous context.
- get(K) - Method in interface com.apple.foundationdb.record.provider.common.MappedPool.MappedPoolProvider
- GET_META_DATA_CACHE_ENTRY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken getting cached meta-data from aMetaDataCache.
- GET_META_DATA_CACHE_VERSION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken getting the current version from aMetaDataCache.
- GET_READ_VERSION - com.apple.foundationdb.record.provider.foundationdb.FDBLatencySource
- GET_READ_VERSION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken to get a read version when explicitly called.
- GET_RECORD_RANGE_RAW_FIRST_CHUNK - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent until the first part of a split record is available.
- GET_RECORD_RAW_VALUE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent loading the raw bytes of a record.
- GET_SCAN_RANGE_RAW_FIRST_CHUNK - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent until the first part of a range scan (such as an index) is available.
- getAddedVersion() - Method in class com.apple.foundationdb.record.metadata.FormerIndex
- 
Get the version at which the index was first added.
- getAddedVersion() - Method in class com.apple.foundationdb.record.metadata.Index
- 
Get the version at which the index was first added.
- getAggregates() - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Return the set of aggregates that this store timer can produce.
- getAggregates() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer
- getAggregator() - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation
- 
Get a function to aggregate multiple index entries.
- getAggregator() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- getAlias() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- getAll(ExpressionMatcher<T>) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.PlannerBindings
- 
Retrieve all bindables bound tokeyif there is at least one such bindable.
- getAllIndexes() - Method in class com.apple.foundationdb.record.metadata.RecordType
- 
Gets the list of all indexes that apply for this type.
- getAllIndexes() - Method in class com.apple.foundationdb.record.RecordMetaData
- getAllIndexStates() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Gets a map fromIndextoIndexStatefor all the indexes in the meta-data.
- getAllocationSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
- getAllowedIndexes() - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- getAllowedIndexes() - Method in class com.apple.foundationdb.record.query.RecordQuery
- getAncestralSources() - Method in interface com.apple.foundationdb.record.query.plan.temp.view.Element
- 
Get the set of all sources for this element, including all ancestors of this element's sources.
- getAncestralSources() - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- getAncestralSources() - Method in class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- getAnyValue() - Method in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- getApproximateSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- getApproximateTransactionSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- getArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- getAsyncToSyncTimeout() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getAsyncToSyncTimeout(StoreTimer.Wait) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getAtomicMutation(Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractEdge
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractNode
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.DataNodeWithInfo
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Edge
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefHeadNode
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefMemberNode
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.GroupExpressionRefInternalEdge
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNode
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNodeWithInfo
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Node
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.NodeWithInfo
- getAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.OperatorNodeWithInfo
- getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- getAvailableFields() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
- getAvailableFields() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
- getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- getAverage() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get the mean size (in bytes) of combined key-value pairs in the requested key range.
- getAverageKeySize() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get the mean size (in bytes) of keys in the requested key range.
- getAverageValueSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get the mean size (in bytes) of values in the requested key range.
- getBaseSource() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- getBaseSource() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- getBaseSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Deprecated.blocks until the mapping subspace is fetched from the database, instead useLocatableResolver.getBaseSubspaceAsync()
- getBaseSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- getBaseSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Get aCompletableFuturethat will contain theSubspacethis resolver is rooted at (e.g.
- getBaseSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- getBaseSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- getBaseTimestamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.TimeWindowSpec
- getBinding(String) - Method in class com.apple.foundationdb.record.EvaluationContext
- 
Get the value bound to a single parameter.
- getBinding(String) - Method in class com.apple.foundationdb.record.EvaluationContextBuilder
- 
Get the current binding for some parameter in the currentBindings.
- getBindingName() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.ScoreForRank
- getBindings() - Method in class com.apple.foundationdb.record.EvaluationContext
- 
Retrieve the mapping from parameter names to values associated with this context.
- getBindings() - Method in class com.apple.foundationdb.record.query.plan.temp.CascadesRuleCall
- getBindings() - Method in interface com.apple.foundationdb.record.query.plan.temp.PlannerRuleCall
- 
Return the map of bindings that this rule's matcher expression produced, which includes (by contract) all of the bindings specified by the rule associated with this call.
- getBlockingInAsyncDetection() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getBlockingInAsyncDetectionSupplier() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getBooleanOption(String, boolean) - Method in class com.apple.foundationdb.record.metadata.Index
- getBoundaryKeys(Transaction, byte[], byte[]) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBLocalityProvider
- 
Return aCloseableAsyncIteratorof keysksuch thatbegin <= k < endandkis located at the start of a contiguous range stored on a single server.
- getBoundaryKeys(Transaction, byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBLocalityUtil
- 
Return an estimate of the keys boundaries within the given range.
- getBuilder(String) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression.Registry
- getBuilders() - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpressionFactoryJRE
- getBuilders() - Method in interface com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression.Factory
- getByteScanLimiter() - Method in class com.apple.foundationdb.record.ExecuteState
- 
Get a limiter for the maximum number of bytes that can be retrieved from the database.
- getBytesScanned() - Method in interface com.apple.foundationdb.record.ByteScanLimiter
- 
Returns the number of bytes that have been scanned thus far.
- getBytesScanned() - Method in class com.apple.foundationdb.record.ExecuteState
- 
Return the number of bytes that have been scanned.
- getCache() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- getCache(FDBDatabase) - Method in interface com.apple.foundationdb.record.provider.foundationdb.storestate.FDBRecordStoreStateCacheFactory
- 
Produce aFDBRecordStoreStateCache.
- getCache(FDBDatabase) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCacheFactory
- getCache(FDBDatabase) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.PassThroughRecordStoreStateCacheFactory
- getCache(FDBDatabase) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.ReadVersionRecordStoreStateCacheFactory
- 
Create a newReadVersionRecordStoreStateCache.
- getCachedMetaData() - Method in interface com.apple.foundationdb.record.provider.foundationdb.MetaDataCache
- 
Get cachedRecordMetaDataobject.
- getCachedSerialized() - Method in interface com.apple.foundationdb.record.provider.foundationdb.MetaDataCache
- 
Get cached serialized meta-data.
- getChild() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- getChild() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- getChild() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpressionWithChild
- getChild() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- getChild() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- getChild() - Method in class com.apple.foundationdb.record.query.expressions.BaseNestedField
- getChild() - Method in interface com.apple.foundationdb.record.query.expressions.ComponentWithSingleChild
- getChild() - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
- 
Child for this component.
- getChild() - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
- getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- getChild() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
- getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- getChild() - Method in class com.apple.foundationdb.record.query.predicates.NotPredicate
- getChild(QueryComponent) - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Return the child mask associated with a child of the mask's filter.
- getChildColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- getChildContinuations() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- getChildren() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpressionWithChild
- getChildren() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpressionWithChildren
- getChildren() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- getChildren() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- getChildren() - Method in interface com.apple.foundationdb.record.query.expressions.ComponentWithChildren
- getChildren() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Get the list of children of this filter.
- getChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- getChildren() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
- 
Returns the (zero or more)RecordQueryPlanchildren of this plan.
- getChildren() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
- getChildren() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithNoChildren
- getChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- getChildren() - Method in class com.apple.foundationdb.record.query.predicates.AndOrPredicate
- getChildrenMatcher() - Method in interface com.apple.foundationdb.record.query.plan.temp.matchers.ExpressionMatcher
- 
Return the child matchers of this matcher as a list.
- getChildrenMatcher() - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.ReferenceMatcher
- getChildrenMatcher() - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeMatcher
- getChildrenRefs() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- getClusterAttributeProvider() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- getClusterFile() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Get the path to the cluster file that this database was created with.
- getClusterProvider() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- getColor() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.DataNodeWithInfo
- getColor() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Edge
- getColor() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.GroupExpressionRefEdge
- getColor() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Node
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- getColumnSize() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Returns the number of items in each KeyValue that will be returned.
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- 
Returns the number of items in each KeyValue that will be returned.
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- getColumnSize() - Method in class com.apple.foundationdb.record.metadata.Index
- 
Get the number of indexed value columns.
- getColumnSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys.Conditions
- getColumnSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys
- 
Get the size of the prefix of the index aggregate that is returned.
- getColumnSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys.IndexScan
- getCommittedVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Return the eight byte version assigned to this context at commit time.
- getCommittedVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- getCommonPrimaryKey() - Method in class com.apple.foundationdb.record.query.plan.temp.MetaDataPlanContext
- getCommonPrimaryKey() - Method in interface com.apple.foundationdb.record.query.plan.temp.PlanContext
- getComparand() - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
- 
Get the comparison value without any bindings.
- getComparand() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
- 
Get the comparison value from the evaluation context.
- getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
- getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
- getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
- getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- getComparandConversionFunction() - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
- getComparandConversionFunction() - Method in interface com.apple.foundationdb.record.metadata.expressions.QueryableKeyExpression
- 
Get a function to be applied to the comparison operand before comparing it with the application of the key expression to the record.
- getComparison() - Method in interface com.apple.foundationdb.record.query.expressions.ComponentWithComparison
- getComparison() - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
- getComparison() - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
- getComparison() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- getComparison() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- getComparison() - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- getComparison() - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- getComparisonKey() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- getComparisonKey() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- getComparisons() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- getComparisons() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithComparisons
- getComparisons() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- getComparisons() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- getComparisons() - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
- getComparisonType(Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- getComplexity() - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Returns an integer representing the "complexity" of the generated plan.
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- getComplexityThreshold() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
- 
A limit on the complexity of the plans generated by the planner.
- getComponentEvents() - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Aggregate
- 
Returns the set of events that make up the aggregate.
- getComponentEvents() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.CountAggregates
- getComposer() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- getConfig(Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper
- 
Parse standard options intoRankedSet.Config.
- getConfigLoader() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the function used by the online indexer to load the config parameters on fly.
- getConfiguration() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- getConstituent(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- getConstituents() - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordType
- getConstituents() - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- 
Get the constitutents of this synthetic record type.
- getConstituents() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- getContentSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- getContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- getContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getContext() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Get the record context (transaction) to use for the record store.
- getContext() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get the record context (transaction) to use for the record store.
- getContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- getContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- getContext() - Method in class com.apple.foundationdb.record.query.plan.temp.CascadesRuleCall
- getContext() - Method in interface com.apple.foundationdb.record.query.plan.temp.PlannerRuleCall
- 
Get the planning context with metadata that might be relevant to the planner, such as the list of available indexes.
- getContextConfigBuilder() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Get the configuration used in record contexts opened by this runner.
- getContextConfigBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- getContextConfigBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.AutoContinuingCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.ChainedCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.ConcatCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.EmptyCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.FilterCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.FlatMapPipelinedCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.FutureCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.LazyCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.ListCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.MapCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.MapWhileCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.OrElseCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.RowLimitedCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.cursors.SkipCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
- getContinuation() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- 
Deprecated.
- getContinuation() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- 
Deprecated.
- getContinuation() - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Deprecated.in favor of theRecordCursor.onNext()method or advancing the cursorRecordCursor.asIterator()
- getContinuation() - Method in class com.apple.foundationdb.record.RecordCursorIterator
- 
Get a byte string that can be used to continue a query after the last record returned.
- getContinuation() - Method in class com.apple.foundationdb.record.RecordCursorResult
- 
Return the continuation of this result.
- getContinuationObject() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Produce aRecordCursorContinuationfor this cursor.
- getContinuationObject() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ProbableIntersectionCursor
- getContinuations() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorContinuation
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- getCorrelatedTo() - Method in interface com.apple.foundationdb.record.query.plan.temp.Correlated
- 
Returns the set ofCorrelationIdentifiers this entity is correlated to.
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.FullUnorderedScanExpression
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- getCorrelatedTo() - Method in interface com.apple.foundationdb.record.query.plan.temp.expressions.RelationalExpressionWithChildren
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.predicates.AndOrPredicate
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.predicates.NotPredicate
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalUnorderedUnionExpression
- getCorrelatedToWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.temp.expressions.RelationalExpressionWithChildren
- getCorrelatedToWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.temp.expressions.TypeFilterExpression
- getCount() - Method in exception com.apple.foundationdb.record.logging.CompletionExceptionLogHelper.IgnoredSuppressedExceptionCount
- getCount() - Method in class com.apple.foundationdb.record.provider.common.StoreTimer.Counter
- 
Get the number of occurrences of the associated event.
- getCount() - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot.CounterSnapshot
- 
Get the number of occurrences of the associated event.
- getCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.TimeWindowSpec
- getCount() - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Count the number of records remaining.
- getCount(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Get the total count for a given event.
- getCounter(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Return the counter for a given event.
- getCounter(StoreTimer.Event, boolean) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Return the counter value for a given event type.
- getCounters() - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
- 
Returns the counters taken at the time of the snapshot.
- getCounterSnapshot(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
- 
Get the counter for a given event.
- getCurrentVersionAsync(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.MetaDataCache
- 
Get a version to use for cache validation of-1to skip validation.
- getCursor() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
- getCursorStates() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Get the child cursors along with associated mutable state.
- getCursorStreamingMode() - Method in class com.apple.foundationdb.record.ScanProperties
- 
Get cursor streaming mode.
- getData() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedValue
- getDataArray() - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.TransformState
- getDatabase() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getDatabase() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Get the database against which functions are run.
- getDatabase() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- getDatabase() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- getDatabase() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- getDatabase() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- getDatabase() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- getDatabase(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getDatacenterId() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getDatacenterId() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getDBVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Retrieves the part of the version that corresponds to the database commit version.
- getDefault() - Static method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverCreateHooks
- 
Gets the default set of no-op create hooks.
- getDefaultCursorStreamingMode() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- 
Get the defaultCursorStreamingModefor newScanProperties.
- getDefaultCursorStreamingMode() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Get the defaultCursorStreamingModefor newScanProperties.
- getDefaultExpireAfterAccessMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCacheFactory
- 
Get the amount of time in milliseconds that each entry is kept in each cache after its last access.
- getDefaultInstance() - Static method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Get the default validator.
- getDefaultInstance() - Static method in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
- 
Obtain a normalizer with the default size limitBooleanNormalizer.DEFAULT_SIZE_LIMIT.
- getDelegate() - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- getDeleteBefore() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
- getDependsOn() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractEdge
- getDescription() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- getDescriptor() - Method in class com.apple.foundationdb.record.metadata.RecordType
- getDescriptor() - Method in class com.apple.foundationdb.record.metadata.RecordTypeBuilder
- getDescriptor() - Method in interface com.apple.foundationdb.record.metadata.RecordTypeOrBuilder
- 
Get the descriptor of the underlying message type.
- getDescriptor(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- getDetails() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractNode
- getDifference(StoreTimer, StoreTimerSnapshot) - Static method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Subtracts counts and times recorded by a snapshot of a timer returning a new timer representing the difference.
- getDirectories() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Returns the available root directories in theKeySpace.
- getDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.Resolved
- getDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedPath
- getDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRoot
- getDirectory() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Returns the directory that corresponds to this path entry.
- getDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- getDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Returns the directory that corresponds to this path entry.
- getDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- getDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectoryResult
- getDirectory(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Retrieves a subdirectory.
- getDirectoryCache(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getDirectoryCacheSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getDirectoryCacheStats() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getDirectoryCacheVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getDirectoryName() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Returns the directory name for this path element.
- getDirectoryName() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- getDirectoryName() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Returns the directory name for this path element.
- getDisabledIndexNames() - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Get the names of any disabled indexes.
- getDouble(int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- getDuration() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.TimeWindowSpec
- getEdgeAttributeProvider() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- getEdgeID(E) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Get a unique string for a edge which adheres to the current language.
- getEdgeIDProvider() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- getEdgeLabel(Attribute) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- getElement() - Method in class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- getElement() - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- getEmptyComparisons() - Method in class com.apple.foundationdb.record.query.plan.temp.IndexEntrySource
- getEnabledIndexes(RecordTypeOrBuilder) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Gets the list of enabled indexes that are on the given record type.
- getEnabledMultiTypeIndexes(RecordTypeOrBuilder) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Gets the list of enabled indexes that are on multiple record types one of which is the given type.
- getEnabledUniversalIndexes() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Gets the list of enabled universal indexes, i.e., the indexes on all record types.
- getEnd() - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator.AllocationWindow
- getEndTimestamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- getEntry() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry
- getEntryPrimaryKey(Tuple) - Method in class com.apple.foundationdb.record.metadata.Index
- 
Get the primary key portion of an index entry.
- getEntrySize(KeyExpression) - Method in class com.apple.foundationdb.record.metadata.Index
- 
The number of columns stored for an index entry.
- getEquality() - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
- getEquality(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
- getEqualityComparison() - Method in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- getEqualityComparisons() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- getEqualityComparisons() - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
- getEqualitySize() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- getEvents() - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Get all events known to this timer.
- getEvolutionValidator() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Get the validator used when saving a new version of the meta-data to ensure the new meta-data is a valid evolution of the old meta-data.
- getEvolutionValidator() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Get the validator used to compare the local file descriptor to the descriptor included in the meta-data proto.
- getExecuteProperties() - Method in class com.apple.foundationdb.record.ScanProperties
- 
Get execute properties for this scan properties.
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.AutoContinuingCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.ChainedCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.ConcatCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.EmptyCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.FilterCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.FlatMapPipelinedCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.FutureCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.LazyCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.ListCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.MapCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.MapWhileCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.OrElseCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.RowLimitedCursor
- getExecutor() - Method in class com.apple.foundationdb.record.cursors.SkipCursor
- getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
- getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getExecutor() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- getExecutor() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- getExecutor() - Method in interface com.apple.foundationdb.record.RecordCursor
- getExistingKey() - Method in exception com.apple.foundationdb.record.RecordIndexUniquenessViolation
- 
Get the existing key of this uniqueness violation.
- getExpectedRecords() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
- 
Get the expected number of records for each token of this predicate.
- getExplicitRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.RecordType
- 
Get any explicit record type key value.
- getExporter() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter.ExporterContext
- getExpression() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Get the expression that satisfied this filter.
- getExpression() - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefTraversal.RefPath
- getExtensionRegistry() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Get the extension registry used when deserializing meta-data proto messages.
- getExternalBinding() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- getFactory() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Get the factory that produced this database.
- getFallbackTokenizerName() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- getFalsePositivePercentage() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
- 
Get the configured false positive percentage for each token scan of this predicate.
- getFanType() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- getFDBCause(Throwable) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBExceptions
- getFieldBuilder(String) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
- getFieldName() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- getFieldName() - Method in class com.apple.foundationdb.record.query.expressions.BaseField
- getFieldNames() - Method in class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- getFieldNames() - Method in class com.apple.foundationdb.record.query.plan.temp.view.RepeatedFieldSource
- getFieldOnMessage(MessageOrBuilder, String) - Static method in class com.apple.foundationdb.record.query.plan.temp.view.MessageValue
- 
Get the value of the field with the given field name on the given message.
- getFieldValue(MessageOrBuilder) - Method in class com.apple.foundationdb.record.query.expressions.BaseField
- getFieldValue(MessageOrBuilder, List<String>) - Static method in class com.apple.foundationdb.record.query.plan.temp.view.MessageValue
- 
Get the value of the (nested) field on the path from the message defined byfieldNames.
- getFillColor() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.DataNodeWithInfo
- getFillColor() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefHeadNode
- getFillColor() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefMemberNode
- getFillColor() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNode
- getFillColor() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNodeWithInfo
- getFillColor() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Node
- getFilter() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Get the filter that this mask is masking.
- getFilter() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- getFilter() - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- getFilter() - Method in class com.apple.foundationdb.record.query.RecordQuery
- getFirstComparison() - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
- getFloat(int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- getFontName() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Edge
- getFontName() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Node
- getFontSize() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Edge
- getFontSize() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefHeadNode
- getFontSize() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefMemberNode
- getFontSize() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Node
- getFormatVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- getFormatVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Get the storage format version currently in use for this record store.
- getFormatVersion() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Get the storage format version for this store.
- getFormatVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- getFormerIndexes() - Method in class com.apple.foundationdb.record.RecordMetaData
- getFormerIndexesSince(int) - Method in class com.apple.foundationdb.record.RecordMetaData
- getFormerName() - Method in class com.apple.foundationdb.record.metadata.FormerIndex
- 
Get the name under which the index existed, if known.
- getFunction() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- getFunction() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- getGlobalVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Retrieves the part of the version that is set by the database.
- getGraphAttributes() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- getGreatestPrimaryKeyWidth() - Method in class com.apple.foundationdb.record.query.plan.temp.MetaDataPlanContext
- getGreatestPrimaryKeyWidth() - Method in interface com.apple.foundationdb.record.query.plan.temp.PlanContext
- getGroup() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardSubDirectory
- getGroup() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardSubDirectoryOperation
- getGroupedCount() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- getGroupedCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- getGroupedKey(KeyExpression) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- getGroupedSubKey() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- getGroupFilters() - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons.RankComparison
- getGrouping() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- getGroupingComparisons() - Method in class com.apple.foundationdb.record.query.plan.TextScan
- 
Get any grouping comparisons necessary to scan only within one grouping key.
- getGroupingCount() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- 
Get number of leading columns that select the group (e.g., ranked set or atomic aggregate); remaining fields are the value (e.g., score) within the set.
- getGroupingCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- getGroupingKey(KeyExpression) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- getGroupingSubkey(GroupingKeyExpression, int, int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- getGroupingSubKey() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- getGroupKeys(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys.Conditions
- getGroupKeys(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys
- 
Get the grouping key (GROUP BY) for the index aggregate from the given context.
- getGroupKeys(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys.IndexScan
- getHashFunction(String) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetHashFunctions
- getHashFunctionName(RankedSet.HashFunction) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetHashFunctions
- getHeaderUserField(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Get the value of a user-settable field from the store header.
- getHigh() - Method in class com.apple.foundationdb.record.TupleRange
- getHigh() - Method in class com.apple.foundationdb.record.ValueRange
- getHighEndpoint() - Method in class com.apple.foundationdb.record.KeyRange
- getHighEndpoint() - Method in class com.apple.foundationdb.record.TupleRange
- getHighEndpoint() - Method in class com.apple.foundationdb.record.ValueRange
- getHighKey() - Method in class com.apple.foundationdb.record.KeyRange
- 
Returns the upper boundary of the range to be scanned.
- getIconId() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- getId() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.NodeIcon
- getId() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- getIdentity() - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation
- 
Get the initial value for aggregating multiple index entries.
- getIdentity() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- getIdentity() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractNode
- getIncreaseLimitAfter() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the number of successful range builds before re-increasing the number of records to process in a single transaction.
- getIncreaseLimitAfter() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config
- 
Get the number of successful range builds before re-increasing the number of records to process in a single transaction.
- getIndex() - Method in class com.apple.foundationdb.record.IndexEntry
- 
Get the index associated with this entry.
- getIndex() - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- getIndex() - Method in class com.apple.foundationdb.record.metadata.IndexRecordFunction
- getIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedIndexKeyspace
- getIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- 
Get the index for this record.
- getIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
- 
Get the index, if any, that produced this query result record.
- getIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the index to be built.
- getIndex() - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons.RankComparison
- getIndex() - Method in class com.apple.foundationdb.record.query.plan.TextScan
- 
Get the index being scanned.
- getIndex() - Method in exception com.apple.foundationdb.record.RecordIndexUniquenessViolation
- 
Get the index associated with this uniqueness violation.
- getIndex(String) - Method in class com.apple.foundationdb.record.RecordMetaData
- getIndex(String) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- getIndexableRecordType(String) - Method in class com.apple.foundationdb.record.RecordMetaData
- 
Get a record type or synthetic record type by name as used in an index.
- getIndexableRecordType(String) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Get a record type or synthetic record type by name for use withRecordMetaDataBuilder.addIndex(com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder, com.apple.foundationdb.record.metadata.Index).
- getIndexBuildStateAsync(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Get the progress of building the given index.
- getIndexByName(String) - Method in class com.apple.foundationdb.record.query.plan.temp.MetaDataPlanContext
- getIndexByName(String) - Method in interface com.apple.foundationdb.record.query.plan.temp.PlanContext
- getIndexEntry() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- 
Get the index entry for this record.
- getIndexEntry() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
- 
Get the index entry, if any, that produced this query result record.
- getIndexEntry() - Method in exception com.apple.foundationdb.record.RecordIndexUniquenessViolation
- 
Get the index value of this uniqueness violation.
- getIndexEntry(IndexEntry, int, TimeWindowLeaderboardDirectory) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- getIndexEntrySource() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- getIndexEntrySources() - Method in class com.apple.foundationdb.record.query.plan.temp.MetaDataPlanContext
- getIndexEntrySources() - Method in interface com.apple.foundationdb.record.query.plan.temp.PlanContext
- getIndexes() - Method in class com.apple.foundationdb.record.metadata.RecordType
- getIndexes() - Method in class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
- getIndexes() - Method in interface com.apple.foundationdb.record.metadata.RecordTypeOrBuilder
- 
Get the list of indexes that are on this record and only this record.
- getIndexes() - Method in class com.apple.foundationdb.record.query.plan.temp.MetaDataPlanContext
- getIndexes() - Method in interface com.apple.foundationdb.record.query.plan.temp.PlanContext
- getIndexesSince(int) - Method in class com.apple.foundationdb.record.RecordMetaData
- getIndexFromSubspaceKey(Object) - Method in class com.apple.foundationdb.record.RecordMetaData
- 
Get the index that uses the given subspace key.
- getIndexMaintainer(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Get the maintainer for a given index.
- getIndexMaintainer(IndexMaintainerState) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainerFactory
- getIndexMaintainer(IndexMaintainerState) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainerFactory
- getIndexMaintainer(IndexMaintainerState) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainerFactory
- getIndexMaintainer(IndexMaintainerState) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainerFactory
- getIndexMaintainer(IndexMaintainerState) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexMaintainerFactory
- getIndexMaintainer(IndexMaintainerState) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainerFactory
- getIndexMaintainer(IndexMaintainerState) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.VersionIndexMaintainerFactory
- getIndexMaintainer(IndexMaintainerState) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerFactory
- 
Get an index maintainer for the given record store and index meta-data.
- getIndexMaintainer(IndexMaintainerState) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerRegistry
- getIndexMaintainer(IndexMaintainerState) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerRegistryImpl
- getIndexMaintainer(IndexMaintainerState) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainerFactory
- getIndexMaintainerRegistry() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Get the registry of index maintainers used to validate indexes.
- getIndexMaintainerRegistry() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Get the registry of index maintainers used to validate indexes.
- getIndexMaintainerRegistry() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- getIndexMaintainerRegistry() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getIndexMaintainerRegistry() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Get the registry of index maintainers to be used by the record store.
- getIndexMaintainerRegistry() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- getIndexMaintainerRegistry() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Get the index registry used for validation.
- getIndexMaintenanceFilter() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- getIndexMaintenanceFilter() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getIndexMaintenanceFilter() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Get theindex filterto be used by the record store.
- getIndexMaintenanceFilter() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- getIndexName() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- getIndexName() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- getIndexName() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithIndex
- 
Gets the name of the index used by this plan.
- getIndexName() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- getIndexName() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- getIndexName() - Method in class com.apple.foundationdb.record.query.plan.temp.IndexEntrySource
- getIndexPlan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- getIndexPlans() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- getIndexQueryabilityFilter() - Method in class com.apple.foundationdb.record.query.RecordQuery
- getIndexScanPreference() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- 
Get whetherRecordQueryIndexPlanis preferred overRecordQueryScanPlaneven when it does not satisfy any additional conditions.
- getIndexScanPreference() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
- 
Get whetherRecordQueryIndexPlanis preferred overRecordQueryScanPlaneven when it does not satisfy any additional conditions.
- getIndexState() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexBuildState
- 
Get the index state.
- getIndexState(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Get the state of the index for this record store.
- getIndexState(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Get the state of the index with the given name for this record store.
- getIndexStates() - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Retrieve the mapping from index names toIndexStatethat is underlying thisRecordStoreState.
- getIndexSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Returns the subspace in which the index data is stored.
- getIndexTokenizerVersion(Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexMaintainer
- 
Get the tokenizer version associated with this index.
- getIndexTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainerFactory
- getIndexTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainerFactory
- getIndexTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainerFactory
- getIndexTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainerFactory
- getIndexTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexMaintainerFactory
- 
A list containing only the name of the ""text"" index type.
- getIndexTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainerFactory
- getIndexTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.VersionIndexMaintainerFactory
- getIndexTypes() - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerFactory
- 
Get the index types supported by this factory.
- getIndexTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainerFactory
- getIndexValidator(Index) - Method in interface com.apple.foundationdb.record.metadata.IndexValidatorRegistry
- getIndexValidator(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainerFactory
- getIndexValidator(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainerFactory
- getIndexValidator(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainerFactory
- getIndexValidator(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainerFactory
- getIndexValidator(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexMaintainerFactory
- 
Validates that the index provided is valid for text indexes.
- getIndexValidator(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainerFactory
- getIndexValidator(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.VersionIndexMaintainerFactory
- getIndexValidator(Index) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerFactory
- 
Get a validator for the given index meta-data.
- getIndexValidator(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerRegistryImpl
- getIndexValidator(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainerFactory
- getInequalityComparisons() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- getInequalityComparisons() - Method in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- getInfoAttributeMap(Set<NodeInfo>) - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- getInfoId() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.NodeWithInfo
- getInfoId() - Method in interface com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.WithInfoId
- getInitialDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Gets the delay ceiling (in milliseconds) that will be applied between attempts to run a transactional database operation.
- getInitialDelayMillis() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Gets the delay ceiling (in milliseconds) that will be applied between attempts to run a transactional database operation.
- getInitialDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- getInitialDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the initial delay between transaction retry attempts.
- getInitialDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- getInner() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- getInner() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- getInnerPlan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- getInnerPlan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- getInReverseDirectoryCacheSubspace(FDBStoreTimer, ScopedValue<Long>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
Retrieves the name of the directory entry corresponding to the value of that entry in the directory layer.
- getInvariableCollator(TextCollatorRegistry, KeyExpression) - Static method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
- getIsolationLevel() - Method in class com.apple.foundationdb.record.ExecuteProperties
- getJoined() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- getJoins() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordType
- getJoins() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder
- 
Get the list of joins for this joined record type.
- getKey() - Method in class com.apple.foundationdb.record.IndexEntry
- 
Get the key portion of the index entry.
- getKey(Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- 
Given aKey.Evaluatedreturned from the evaluation of this expression, splits out the portion of that expression that should be used to represent the key of a covering index.
- getKey(String) - Method in interface com.apple.foundationdb.record.provider.common.text.TextCollator
- 
Get a representation of a string suitable for storing in an index for this collation.
- getKey(String) - Method in class com.apple.foundationdb.record.provider.common.text.TextCollatorRegistryJRE.TextCollatorJRE
- getKeyCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get the total number of keys in the requested key range.
- getKeyCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- getKeyCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- getKeyCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- getKeyCount() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBStoredSizes
- 
Get the number of keys used to store this record.
- getKeyCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- 
Get the number of keys used to store this record.
- getKeyCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- getKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- getKeyExpression() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- getKeyFields(KeyExpression) - Static method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Return the key fields for an expression.
- getKeyHash(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.InstrumentedRankedSet
- getKeyNullType(int) - Method in class com.apple.foundationdb.record.IndexEntry
- 
Get the type of null stored in a given key index location.
- getKeys() - Method in class com.apple.foundationdb.record.provider.common.MappedPool
- getKeys() - Method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
- getKeysAndValues() - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Suitable forKeyValueLogMessage.
- getKeySize() - Method in class com.apple.foundationdb.record.IndexEntry
- getKeySize() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get the total size (in bytes) of all keys in the requested key range.
- getKeySize() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- getKeySize() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- getKeySize() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- getKeySize() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBStoredSizes
- 
Get the size in bytes of all keys used to store this record.
- getKeySize() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- 
Get the size in bytes of all keys used to store this record.
- getKeySize() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- getKeySizeLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getKeySpacePath() - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderByKeySpacePath
- getKeysSource() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- getKeyType() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Returns the type of values this directory stores.
- getKeyValue(int) - Method in class com.apple.foundationdb.record.IndexEntry
- 
Get a tuple element of the key tuple.
- getKeyValueMap() - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- getLabel() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractEdge
- getLastModifiedVersion() - Method in class com.apple.foundationdb.record.metadata.Index
- 
Get the version at which the index was changed.
- getLatencyInjector() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Returns the current latency injector.
- getLatencyToInject(FDBLatencySource) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Given a specific FDB API call, computes an amount of latency (in milliseconds) that should be injected prior to performing the actual operation.
- getLeaderboards() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- getLeaderboardTimestamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- getLeaderboardTimestamp(EvaluationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- getLeaderboardTimestampParameter() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- getLeaderboardType() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- getLeaderboardType(EvaluationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- getLeaderboardTypeParameter() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- getLeaves() - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefTraversal
- getLeft() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordType.Join
- getLeft() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder.Join
- getLeftExpression() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordType.Join
- getLeftExpression() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder.Join
- getLegacyVersionSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getLimit() - Method in interface com.apple.foundationdb.record.ByteScanLimiter
- 
Get the byte scan limit.
- getLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the maximum number of records to process in one transaction.
- getLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Get the current number of records to process in one transaction.
- getLimit() - Method in interface com.apple.foundationdb.record.RecordScanLimiter
- 
Get the record scan limit.
- getLocalFileDescriptor() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Get the local meta-data file descriptor.
- getLocalityProvider() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Get the locality provider that is used to discover the server location of the keys.
- getLocalityProvider() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Get the locality provider that is used to discover the server location of the keys.
- getLocalVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Retrieves the part of the version that is set within a singleFDBRecordContext.
- getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.Resolved
- getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedIndexKeyspace
- getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedKeyField
- getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedPath
- getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRecordStoreKeyspace
- getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRecordTypeKeyspace
- getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRoot
- getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Returns the logical value (prior to resolving) for this path element.
- getLogInfo() - Method in exception com.apple.foundationdb.record.LoggableTimeoutException
- getLogName() - Method in enum com.apple.foundationdb.record.IndexState
- getLong(int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- getLow() - Method in class com.apple.foundationdb.record.TupleRange
- getLow() - Method in class com.apple.foundationdb.record.ValueRange
- getLowEndpoint() - Method in class com.apple.foundationdb.record.KeyRange
- getLowEndpoint() - Method in class com.apple.foundationdb.record.TupleRange
- getLowEndpoint() - Method in class com.apple.foundationdb.record.ValueRange
- getLowKey() - Method in class com.apple.foundationdb.record.KeyRange
- 
Returns the lower boundary of the range to be scanned.
- getMappingSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Deprecated.blocks until the mapping subspace is fetched from the database, instead useLocatableResolver.getMappingSubspaceAsync()
- getMappingSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- getMappingSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- getMappingSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Get aCompletableFuturethat will contain theSubspacewhere this resolver stores the mappings fromkeyStrings tovalueLong.
- getMappingSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- getMappingSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- getMatcher() - Method in class com.apple.foundationdb.record.query.plan.temp.PlannerRule
- getMaxArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
- getMaxArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- 
Get the maximum number of arguments supported by this function.
- getMaxAttempts() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Gets the maximum number of attempts for a database to make when running a retriable transactional operation.
- getMaxAttempts() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Gets the maximum number of attempts for a database to make when running a retriable transactional operation.
- getMaxAttempts() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- getMaxAttempts() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the maximum number of transaction retry attempts.
- getMaxAttempts() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- getMaxDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Gets the maximum delay (in milliseconds) that will be applied between attempts to run a transactional database operation.
- getMaxDelayMillis() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Gets the maximum delay (in milliseconds) that will be applied between attempts to run a transactional database operation.
- getMaxDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- getMaxDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the maximum delay between transaction retry attempts.
- getMaxDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- getMaxDistance() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextWithMaxDistanceComparison
- 
Get the maximum distance allowed between tokens in the source document allowed by this filter.
- getMaxKeySize() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get the size (in bytes) of the largest key in the requested key range.
- getMaxLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config
- 
Get the maximum number of records to process in one transaction.
- getMaxMillisPerTransaction() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
The maximum number of milliseconds spent scanning the directory during a lookup within the context of a single transaction, when this limit is hit, a new one will be started before continuing.
- getMaxRetries() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the maximum number of times to retry a single range rebuild.
- getMaxRetries() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config
- 
Get the maximum number of times to retry a single range rebuild.
- getMaxRowsPerTransaction() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
The maximum number of rows scanned in the directory during a lookup within the context of a single transaction, when this limit is hit, a new one will be started before continuing.
- getMaxSize() - Method in class com.apple.foundationdb.record.AsyncLoadingCache
- 
Get the maximum number of elements stored by the cache.
- getMaxSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCacheFactory
- 
Get the maximum number of elements to keep in produced caches.
- getMaxValueSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get the size (in bytes) of the largest value in the requested key range.
- getMaxVersion() - Method in class com.apple.foundationdb.record.provider.common.text.DefaultTextTokenizer
- 
Get the maximum supported version.
- getMaxVersion() - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizer
- 
The maximum supported version of this tokenizer.
- getMaxWriteLimitBytes() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the approximate maximum transaction write size.
- getMaxWriteLimitBytes() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config
- 
Stop scanning if the write size (bytes) becomes bigger that this value.
- getMdcContext() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Get the logging context used in record contexts opened by this runner.
- getMdcContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- getMdcContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Get the MDC context.
- getMdcContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Get the MDC context used to set additional keys and values when logging.
- getMdcContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the logging context used inOnlineIndexer.buildIndex(boolean).
- getMedian() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get an estimate for the size of the median key-value pair.
- getMembers() - Method in interface com.apple.foundationdb.record.query.plan.temp.ExpressionRef
- getMembers() - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- getMembers() - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- getMessage() - Method in exception com.apple.foundationdb.record.logging.CompletionExceptionLogHelper.IgnoredSuppressedExceptionCount
- getMessageWithKeys() - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- getMetadata() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.PathValue
- 
If thePathValuewas returned by theDirectoryLayerDirectoryor some other directory type that involves aLocatableResolver, this will return any metadata that is associated with the key in byLocatableResolver.
- getMetadata() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverResult
- getMetaData() - Method in class com.apple.foundationdb.record.query.plan.temp.MetaDataPlanContext
- getMetaData() - Method in interface com.apple.foundationdb.record.query.plan.temp.PlanContext
- getMetadataHook() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverCreateHooks
- getMetaDataProvider() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- getMetaDataProvider() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Get the provider for the record store's meta-data.
- getMetaDataProvider() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Get the provider for the record store's meta-data.
- getMetaDataProvider() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- getMetaDataStore() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- getMetaDataStore() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Get theFDBMetaDataStoreto use as the source of meta-data.
- getMetaDataStore() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- getMetaDataVersionStamp(IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
A blocking version ofFDBRecordContext.getMetaDataVersionStampAsync(IsolationLevel).
- getMetaDataVersionStampAsync(IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get the database's meta-data version-stamp.
- getMinArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
- getMinArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- 
Get the the minimum number of arguments supported by this function.
- getMinDelayMillis() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Gets the minimum delay (in milliseconds) that will be applied between attempts to run a transactional database operation.
- getMinDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- getMinDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- getMinVersion() - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizer
- 
The minimum supported version of this tokenizer.
- getMinVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase.WeakReadSemantics
- getMultiTypeIndexes() - Method in class com.apple.foundationdb.record.metadata.RecordType
- 
The Indexes that this record type is on that also contain other record types.
- getMultiTypeIndexes() - Method in class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
- 
TheIndexes that this record type is on that also contain other record types.
- getMultiTypeIndexes() - Method in interface com.apple.foundationdb.record.metadata.RecordTypeOrBuilder
- 
Gets the list of indexes that are on multiple record types one of which is this type.
- getMutationParam(IndexEntry, boolean) - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation
- 
Get the underlying argument to the FDB API.
- getMutationParam(IndexEntry, boolean) - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- getMutationType() - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation
- 
Get the underlying mutation performed by the FDB API.
- getMutationType() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- getName() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression.Builder
- getName() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- getName() - Method in interface com.apple.foundationdb.record.metadata.expressions.QueryableKeyExpression
- getName() - Method in class com.apple.foundationdb.record.metadata.Index
- getName() - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- getName() - Method in class com.apple.foundationdb.record.metadata.RecordType
- getName() - Method in class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
- getName() - Method in interface com.apple.foundationdb.record.metadata.RecordTypeOrBuilder
- 
Get the name of the record type.
- getName() - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordType.Constituent
- getName() - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder.Constituent
- getName() - Method in class com.apple.foundationdb.record.PipelineOperation
- getName() - Method in class com.apple.foundationdb.record.provider.common.text.DefaultTextTokenizer
- 
Get the name for this tokenizer.
- getName() - Method in class com.apple.foundationdb.record.provider.common.text.DefaultTextTokenizerFactory
- 
The name of the default text tokenizer.
- getName() - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizer
- 
Get the name of this tokenizer.
- getName() - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizerFactory
- 
Get the unique name for the text tokenizer.
- getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.Resolved
- getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedIndexKeyspace
- getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedKeyField
- getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedPath
- getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRecordStoreKeyspace
- getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRecordTypeKeyspace
- getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRoot
- getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Returns the name of this directory.
- getName() - Method in class com.apple.foundationdb.record.query.expressions.BaseField
- getName() - Method in interface com.apple.foundationdb.record.query.expressions.ComponentWithComparison
- getName() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- getName() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- getName() - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- getName() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractNode
- getName() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- getName() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefHeadNode
- getName() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefMemberNode
- getName() - Method in class com.apple.foundationdb.record.RecordFunction
- getNameInTree() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
- getNameInTree() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
When displaying the name of this directory in the tree output fromKeySpaceDirectory.toString()allows the directory implementation to ornament the name in any fashion it sees fit.
- getNetwork() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph
- getNetwork() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.PlannerGraphBuilder
- getNetwork() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter.ExporterContext
- getNetworkExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getNewRefWith(T) - Method in interface com.apple.foundationdb.record.query.plan.temp.ExpressionRef
- getNewRefWith(T) - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- getNewRefWith(T) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- getNext() - Method in class com.apple.foundationdb.record.cursors.AutoContinuingCursor
- getNext() - Method in class com.apple.foundationdb.record.cursors.EmptyCursor
- getNext() - Method in class com.apple.foundationdb.record.cursors.ListCursor
- getNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor
- getNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- getNext() - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Get the next result from this cursor.
- getNextResult(List<KeyedMergeCursorState<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.IntersectionCursor
- getNextResult(List<KeyedMergeCursorState<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.IntersectionMultiCursor
- getNextResult(List<ProbableIntersectionCursorState<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ProbableIntersectionCursor
- getNextResult(List<S>) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Determine the next result to return based on the results of the child cursors.
- getNlevels() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
- getNLevels() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- getNodeInfo() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.NodeWithInfo
- getNodeInfos() - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- getNodeLabel(Attribute, Attribute, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- getNodeSubspace(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.AutoContinuingCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.ChainedCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.ConcatCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.EmptyCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.FilterCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.FlatMapPipelinedCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.FutureCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.LazyCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.ListCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.MapCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.MapWhileCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.OrElseCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.RowLimitedCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.cursors.SkipCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- 
Deprecated.
- getNoNextReason() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- 
Deprecated.
- getNoNextReason() - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Deprecated.in favor of theRecordCursor.onNext()method or advancing the cursorRecordCursor.asIterator()
- getNoNextReason() - Method in class com.apple.foundationdb.record.RecordCursorIterator
- 
Get the reason that the cursor has reached the end and returnedfalseforRecordCursorIterator.hasNext().
- getNoNextReason() - Method in class com.apple.foundationdb.record.RecordCursorResult
- 
Return the no-next-reason of this result.
- getNullableDouble(int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- getNullableFloat(int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- getNullableLong(int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- getNullStandin() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- getObject(int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- getObject(int, Class<T>) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- getOnlyRecordType() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
If there is only one record type, get it.
- getOnNextFuture() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
- getOperand() - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- getOperand() - Method in class com.apple.foundationdb.record.metadata.IndexRecordFunction
- getOption(String) - Method in class com.apple.foundationdb.record.metadata.Index
- getOptions() - Method in class com.apple.foundationdb.record.metadata.Index
- getOptionValue() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBTraceFormat
- 
Get the value to supply tosetTraceFormat().
- getOrCreatePostCommit(String, Function<String, FDBRecordContext.PostCommit>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Fetches a post-commit hook, creating a new one if it does not already exist.
- getOrderBy() - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpression
- getOtherFields(KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.planning.TextScanPlanner
- getP90() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get an estimate for the size of the 90th percentile key-value pair.
- getP95() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get an estimate for the size of the 95th percentile key-value pair.
- getParameter() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- getParent() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- getParent() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.Resolved
- getParent() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Returns this directory's parent.
- getParent() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Returns the parent of this entry or null if this is the root of the path.
- getParent() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- getParent() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Returns the parent path element.
- getParent() - Method in class com.apple.foundationdb.record.query.plan.temp.view.RepeatedFieldSource
- getParentRefs() - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefTraversal.FullyTraversableExpressionRef
- 
Return all expression references (asExpressionRefTraversal.FullyTraversableExpressionRefs) that contain a path fromparent -> expression -> quantifier -> this reference
- getPath() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.Resolved
- getPersistentCacheHitCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
Get the number of reverse lookups in which the lookup could not be satisfied by the in-memory cache but was satisfied by the persistent reverse lookup cache.
- getPersistentCacheMissCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
Get the number of reverse lookups in which the persistent cache was found to be missing an entry, resulting in a scan of the directory layer in order to populate the missing entry.
- getPipelineSize(PipelineOperation) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get the number of elements to allow in the asynchronous pipeline for an operation of the given type.
- getPipelineSize(PipelineOperation) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.PipelineSizer
- getPipelineSizer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- getPipelineSizer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getPipelineSizer() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Get theobjectto be used to determine the depth of pipelines run by the record store.
- getPipelineSizer() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get the function for computing the number of elements to allow in the asynchronous pipeline for an operation of the given type.
- getPipelineSizer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- getPipelineSizer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- getPlanComparison(QueryRecordFunctionWithComparison) - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons
- getPoolSize(K) - Method in class com.apple.foundationdb.record.provider.common.MappedPool
- 
Pool size for the key.
- getPostCommit(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Fetches a previously installed post-commit hook.
- getPredicate() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- getPredicate() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- getPredicate() - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpressionWithPredicate
- getPrefixSize() - Method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
- getPreWriteChecks() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverCreateHooks
- getPrimaryKey() - Method in class com.apple.foundationdb.record.IndexEntry
- 
Get the primary key of the record associated with this entry.
- getPrimaryKey() - Method in class com.apple.foundationdb.record.metadata.RecordType
- getPrimaryKey() - Method in class com.apple.foundationdb.record.metadata.RecordTypeBuilder
- getPrimaryKey() - Method in interface com.apple.foundationdb.record.metadata.RecordTypeOrBuilder
- 
Gets the primary key expression for this record type.
- getPrimaryKey() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- getPrimaryKey() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecord
- 
Get the primary key for this record.
- getPrimaryKey() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- getPrimaryKey() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- getPrimaryKey() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- 
Get the primary key for this synthetic record.
- getPrimaryKey() - Method in exception com.apple.foundationdb.record.RecordIndexUniquenessViolation
- 
Get the primary key of this uniqueness violation.
- getPrimaryKeyBoundaries(Tuple, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Return a cursor of boundaries separating the key ranges maintained by each FDB server.
- getPrimaryKeyComponentPositions() - Method in class com.apple.foundationdb.record.metadata.Index
- 
Get the positions of the primary key components within the index key.
- getPrimaryKeys(EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan.KeysSource
- getPrimaryKeyStart() - Method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
- getPrimaryKeyTail() - Method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
- getPrintWriter() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter.ExporterContext
- getPriority() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Get the priority of transactions opened by this runner.
- getPriority() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get the priority of this transaction.
- getPriority() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Get theFDBTransactionPriority.
- getPriority() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Get the priority for the created transaction.
- getPriority() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the priority of transactions used for this index build.
- getProgressLogIntervalMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the minimum time between successful progress logs when building across transactions.
- getProgressLogIntervalMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config
- 
Get the minimum time between successful progress logs when building across transactions.
- getProportion(double) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get an estimate for the size for which the provided proportion of key-value pairs have a combined size that is less than that size.
- getQuantifier() - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefTraversal.RefPath
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- getQuantifiers() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithNoChildren
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.FullUnorderedScanExpression
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalTypeFilterExpression
- getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalUnorderedUnionExpression
- getQuantifiers() - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpression
- 
Return an iterator of references to the children of this planner expression.
- getQueryPlanChildren() - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Returns the (zero or more) childQueryPlans of this plan.
- getQueryPlanChildren() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
- getRangesOver() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Existential
- getRangesOver() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.ForEach
- getRangesOver() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- 
Return the reference that the quantifier ranges over.
- getRangesOver() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical
- getRangesOverPlan() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical
- getRangeType() - Method in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- getRanks() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- getRankTypes() - Method in class com.apple.foundationdb.record.query.plan.PlannableIndexTypes
- getReadableIndexes(RecordTypeOrBuilder) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Gets the list of readable indexes that are on the given record type.
- getReadableMultiTypeIndexes(RecordTypeOrBuilder) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Gets the list of readable indexes that are on multiple record types one of which is the given type.
- getReadableUniversalIndexes() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Gets the list of readable universal indexes, i.e., the indexes on all record types.
- getReadVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get the read version used by this transaction.
- getReadVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- getReadVersion(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Deprecated.useFDBRecordContext.getReadVersionAsync()instead
- getReadVersionAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get the read version used by this transaction.
- getReason() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry
- getRebuild() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
- getRecord() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- getRecord() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecord
- 
Get the Protobuf message form of this record.
- getRecord() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- getRecord() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- getRecord() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- getRecordContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- 
Get theFDBRecordContextwithin which this store operates.
- getRecordCountForRebuildIndexes(boolean, boolean, Map<Index, List<RecordType>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Get count of records to pass to checker to decide whether to build right away.
- getRecordCountKey() - Method in class com.apple.foundationdb.record.RecordMetaData
- getRecordCountKey() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Deprecated.useCOUNTtype indexes instead
- getRecordMetaData() - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
- getRecordMetaData() - Method in class com.apple.foundationdb.record.metadata.RecordType
- 
Get the meta-data of which this record type is a part.
- getRecordMetaData() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRecordStoreKeyspace
- getRecordMetaData() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- getRecordMetaData() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Get theRecordMetaDataused by this store.
- getRecordMetaData() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- getRecordMetaData() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- 
Get theRecordMetaDatafor this planner.
- getRecordMetaData() - Method in class com.apple.foundationdb.record.RecordMetaData
- 
Get thisRecordMetaDatainstance.
- getRecordMetaData() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- getRecordMetaData() - Method in interface com.apple.foundationdb.record.RecordMetaDataProvider
- 
Provide an instance ofRecordMetaData.
- getRecordMetaDataAsync(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- getRecordScanLimiter() - Method in class com.apple.foundationdb.record.ExecuteState
- 
Get a limiter for the maximum number of records that can be retrieved from the database.
- getRecordsDescriptor() - Method in class com.apple.foundationdb.record.RecordMetaData
- getRecordsInTotal() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexBuildState
- 
Get the estimated total number of records that need to be scanned to build the index.
- getRecordsPerSecond() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the maximum number of records to process in a single second.
- getRecordsPerSecond() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config
- 
Get the maximum number of records to process in a single second.
- getRecordsScanned() - Method in class com.apple.foundationdb.record.ExecuteState
- 
Return the number of records that have been scanned.
- getRecordsScanned() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexBuildState
- 
Get the number of records successfully scanned and processed during the online index build process.
- getRecordsScanned() - Method in interface com.apple.foundationdb.record.RecordScanLimiter
- 
Returns the number of records that have been scanned thus far.
- getRecordStoreBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the record store builder that will be used to open record store instances for indexing.
- getRecordStoreKeyspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRecordStoreKeyspace
- getRecordStoreMetaData(FDBRecordContext, KeySpaceCountTree.Resolved, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- 
Given a key space path for whichKeySpaceCountTree.isRecordStoreLeaf(com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext, com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.Resolved, java.lang.Object)istrue, get the record store's meta-data.
- getRecordStoreState() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Get theRecordStoreStatefor this store.
- getRecordStoreState() - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.FDBRecordStoreStateCacheEntry
- 
Get theRecordStoreStatecontained within this entry.
- getRecordStoreState() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- 
Get theRecordStoreStatefor this planner.
- getRecordType() - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordType.Constituent
- getRecordType() - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder.Constituent
- getRecordType() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRecordTypeKeyspace
- getRecordType() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- getRecordType() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecord
- 
Get the record type for this record.
- getRecordType() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- getRecordType() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- getRecordType() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- getRecordType() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
- getRecordType(String) - Method in class com.apple.foundationdb.record.RecordMetaData
- getRecordType(String) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- getRecordTypeForDescriptor(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.RecordMetaData
- getRecordTypeFromRecordTypeKey(Object) - Method in class com.apple.foundationdb.record.RecordMetaData
- 
Get the record type that uses the given record type key.
- getRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.RecordType
- 
Gets theTupleelement value that will be used byRecordTypeKeyExpressionfor this record type.
- getRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
- getRecordTypeKey() - Method in interface com.apple.foundationdb.record.metadata.RecordTypeOrBuilder
- 
Gets theTupleelement value that will be used byRecordTypeKeyExpressionfor this record type.
- getRecordTypeKeyTuple() - Method in class com.apple.foundationdb.record.metadata.RecordType
- 
Get aTuplecontaining only the record type key.
- getRecordTypeNames() - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeSource
- getRecordTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the explicit set of record types to be indexed.
- getRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- getRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- getRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.FullUnorderedScanExpression
- getRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalTypeFilterExpression
- getRecordTypes() - Method in interface com.apple.foundationdb.record.query.plan.temp.expressions.TypeFilterExpression
- getRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.temp.MetaDataPlanContext
- getRecordTypes() - Method in interface com.apple.foundationdb.record.query.plan.temp.PlanContext
- getRecordTypes() - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- getRecordTypes() - Method in class com.apple.foundationdb.record.query.RecordQuery
- getRecordTypes() - Method in class com.apple.foundationdb.record.RecordMetaData
- getReference() - Method in interface com.apple.foundationdb.record.query.plan.temp.explain.Attribute
- 
Return the underlying object this attribute refers to.
- getRefreshTimeSeconds() - Method in class com.apple.foundationdb.record.AsyncLoadingCache
- getRegistry() - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizerRegistry
- 
Returns all registered tokenizers.
- getRegistry() - Method in class com.apple.foundationdb.record.provider.common.text.TextTokenizerRegistryImpl
- getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- getRelationalChildCount() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
- getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalTypeFilterExpression
- getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalUnorderedUnionExpression
- getRelationalChildCount() - Method in interface com.apple.foundationdb.record.query.plan.temp.expressions.RelationalExpressionWithChildren
- getRemainder() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Deprecated.
- getRemainder() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- 
Deprecated.
- getRemainder() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
If this path was created viaKeySpace.resolveFromKey(FDBRecordContext, Tuple), this returns any remaining portion of the input tuple that was not used to construct the path.
- getRemovedVersion() - Method in class com.apple.foundationdb.record.metadata.FormerIndex
- 
Get the version at which the index was removed.
- getRequiredFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- getRequiredFields() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithRequiredFields
- getRequiredFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- getRequiredResults() - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- getRequiredResults() - Method in class com.apple.foundationdb.record.query.RecordQuery
- getResolvedMetadata() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Returns any metadata that may be stored along with the resolved value for this path element.
- getResolvedPath() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.Resolved
- getResolvedPath() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedPath
- getResolvedPathValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Returns the value that will be physically stored to represent this path element along with any metadata that may be associated with it.
- getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.Resolved
- getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedIndexKeyspace
- getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedKeyField
- getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedPath
- getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRecordStoreKeyspace
- getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRecordTypeKeyspace
- getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRoot
- getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.PathValue
- 
Returns the value that will be stored in the FDB row key for a path.
- getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Returns the value that will be physically stored to represent this path element.
- getResolverStateCacheRefreshTime() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getResult() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
- getResult() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer.UpdateState
- getReturnedRowLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Get the limit on the number of rows that will be returned as it would be passed to FDB.
- getReturnedRowLimitOrMax() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Get the limit on the number of rows that will be returned as could be used for counting.
- getReverseDirectoryCache() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getReverseDirectoryInMemoryCache() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getReverseDirectoryMaxMillisPerTransaction() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getReverseDirectoryRowsPerTransaction() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getRight() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordType.Join
- getRight() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder.Join
- getRightExpression() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordType.Join
- getRightExpression() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder.Join
- getRoot() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Get the root of this key space.
- getRoot() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph
- getRoot() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.PlannerGraphBuilder
- getRoot() - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefTraversal
- getRootClass() - Method in interface com.apple.foundationdb.record.query.plan.temp.matchers.ExpressionMatcher
- 
Get a class or interface extendingRelationalExpressionthat is a super class of every planner expression that this matcher can match.
- getRootClass() - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.ReferenceMatcher
- getRootClass() - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeMatcher
- getRootExpression() - Method in class com.apple.foundationdb.record.metadata.Index
- getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.temp.PlannerRule
- 
Returns the class of the operator at the root of the binding expression, if this rule uses a non-trivial binding.
- getRulesMatching(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.temp.PlannerRuleSet
- getRunner() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the runner that will be used to call into the database.
- getScanComparisons() - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons.RankComparison
- getScanForQuery(Index, QueryComponent, boolean, FilterSatisfiedMask) - Static method in class com.apple.foundationdb.record.query.plan.planning.TextScanPlanner
- 
Get a scan that matches a filter in the list of filters provided.
- getScannedBytesLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Get the maximum number of bytes a query with this execute properties will scan.
- getScannedRecordsLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Get the maximum number of records a query with this execute properties will scan.
- getScanType() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- getScanType() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- getScanType() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithIndex
- getScanType() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- getScanType() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- getScope() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedValue
- getScoreForRank(RecordMetaData) - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons.RankComparison
- getScores() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardScoreTrim
- getScores() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardScoreTrimResult
- getSecondarySubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Returns the secondary subspace in which the index data is stored.
- getSerializer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- getSerializer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getSerializer() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Get the serializer used to convert records into byte arrays.
- getSerializer() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get the serializer used to convert records into byte arrays.
- getSerializer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- getSerializer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- getSessionId() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- getShape() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefHeadNode
- getShape() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefMemberNode
- getShape() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Node
- getShorthand() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Existential
- getShorthand() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.ForEach
- getShorthand() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- 
Return a short hand string for the quantifier.
- getShorthand() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical
- getShouldCheckContinuationAccess() - Static method in class com.apple.foundationdb.record.cursors.IllegalContinuationAccessChecker
- getSinceVersion() - Method in class com.apple.foundationdb.record.metadata.RecordType
- getSinceVersion() - Method in class com.apple.foundationdb.record.metadata.RecordTypeBuilder
- getSinceVersion() - Method in interface com.apple.foundationdb.record.metadata.RecordTypeOrBuilder
- 
Gets a metadata version, which shows when this record type got introduced in the metadata.
- getSizeBuckets() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get an array of buckets used to get an estimate of size distribution.
- getSizeLimit() - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
- 
Get the limit on the size of the DNF that this normalizer will produce.
- getSkip() - Method in class com.apple.foundationdb.record.ExecuteProperties
- getSnapshotRecordCount() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get the number of records in the record store.
- getSnapshotRecordCount(KeyExpression, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getSnapshotRecordCount(KeyExpression, Key.Evaluated) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get the number of records in a portion of the record store determined by a group key expression.
- getSnapshotRecordCount(KeyExpression, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- getSnapshotRecordCountForRecordType(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getSnapshotRecordCountForRecordType(String) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get the number of records in the record store of the given record type.
- getSnapshotRecordCountForRecordType(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- getSnapshotRecordUpdateCount() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- getSnapshotRecordUpdateCount(KeyExpression, Key.Evaluated) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- getSort() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- getSort() - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- getSort() - Method in class com.apple.foundationdb.record.query.RecordQuery
- getSortPrefix() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- getSortSuffix() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- getSources() - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeSource
- getSources() - Method in class com.apple.foundationdb.record.query.plan.temp.view.RepeatedFieldSource
- getSources() - Method in class com.apple.foundationdb.record.query.plan.temp.view.Source
- 
Get the set of all sources of ancestor's of this source, include this source itself.
- getSpecs() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
- getSplitPoint() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- getStalenessBoundMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase.WeakReadSemantics
- getStart() - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator.AllocationWindow
- getStartIncrement() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.TimeWindowSpec
- getStartTimestamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- getState() - Method in class com.apple.foundationdb.record.ExecuteProperties
- getState(Index) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Determine the state of an index.
- getState(String) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Determine the state of the index with the given name.
- getStateForResolver(LocatableResolver, Supplier<CompletableFuture<ResolverStateProto.State>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- getStateRefreshTimeMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getStatesForRebuildIndexes(FDBRecordStoreBase.UserVersionChecker, Map<Index, List<RecordType>>, long, boolean, boolean, int, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getStateSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- getStateSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- getStateSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- getStateSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- getStaticMessage() - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- getStoppedReason() - Method in class com.apple.foundationdb.record.cursors.CursorLimitManager
- 
Report a single reason associated with a limit that has been exceeded.
- getStoredRecord() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- getStoredRecord() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
- 
Get the stored record, if any, that produced this query result record.
- getStoredRecordTypes() - Method in interface com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordFromStoredRecordPlan
- 
Get the possible record types for the stored record to which this plan can be applied.
- getStoredValue() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Deprecated.
- getStoredValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- 
Deprecated.
- getStoreHeader() - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Get the store header associated with this record store state.
- getStoreStateCache() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Get the store state cache for this database.
- getStoreStateCache() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- getStoreStateCache() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Get the store state cache to be used by the record store.
- getStoreStateCache() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- getStoreStateCacheFactory() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Get the store state cache factory.
- getString(int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- getStrongestNoNextReason(List<S>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Gets the strongest reason for stopping of all cursor states.
- getStyle() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.DataNodeWithInfo
- getStyle() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Edge
- getStyle() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefHeadNode
- getStyle() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.ExpressionRefMemberNode
- getStyle() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.GroupExpressionRefInternalEdge
- getStyle() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNode
- getStyle() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNodeWithInfo
- getStyle() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Node
- getSubdirectories() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Returns the set of subdirectories contained within this directory.
- getSubdirectory(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Retrieves a subdirectory.
- getSubDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardSaveSubDirectory
- getSubDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardSubDirectoryResult
- getSubDirectory(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- getSubKey(int, int) - Method in class com.apple.foundationdb.record.metadata.expressions.BaseKeyExpression
- getSubKey(int, int) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Returns a sub-set of the key expression.
- getSubKeyImpl(int, int) - Method in class com.apple.foundationdb.record.metadata.expressions.BaseKeyExpression
- getSubKeyImpl(int, int) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- getSubKeyImpl(int, int) - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- getSubKeyImpl(int, int) - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- getSubKeyImpl(int, int) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- getSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- getSubspace(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.SubspaceProvider
- 
This might be blocking if the subspace is never fetched before.
- getSubspace(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderByKeySpacePath
- getSubspace(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderBySubspace
- getSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- getSubspaceAsync(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.SubspaceProvider
- 
Asynchronously resolves the subspace against the database associated withFDBRecordContext.
- getSubspaceAsync(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderByKeySpacePath
- getSubspaceAsync(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderBySubspace
- getSubspaceKey() - Method in class com.apple.foundationdb.record.metadata.FormerIndex
- 
Get the subspace key formerly occupied by the index.
- getSubspaceKey() - Method in class com.apple.foundationdb.record.metadata.Index
- 
Get the key used to determine this index's subspace prefix.
- getSubspaceKey() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- getSubspaceKeyCounter() - Method in class com.apple.foundationdb.record.RecordMetaData
- 
Get value of the counter used for index subspace keys if the counter-based assignment is used.
- getSubspaceKeyCounter() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Get the current value of the index subspace key counter.
- getSubspaceProvider() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- getSubspaceProvider() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Get the subspace provider.
- getSubspaceProvider() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get the subspace provider.
- getSubspaceProvider() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- getSubspaceProvider() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- getSubspaceProvider() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- getSubspaceTupleKey() - Method in class com.apple.foundationdb.record.metadata.FormerIndex
- 
Get aTuple-encodable version of the subspace key formerly occupied by the index.
- getSubspaceTupleKey() - Method in class com.apple.foundationdb.record.metadata.Index
- 
Get aTuple-encodable version of the subspace key of this index.
- getSubstitute() - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons.RankComparison
- getSuffixComparisons() - Method in class com.apple.foundationdb.record.query.plan.TextScan
- 
Get any comparisons performed on fields of the index following the text field.
- getSyntheticRecordType(String) - Method in class com.apple.foundationdb.record.RecordMetaData
- getSyntheticRecordType(String) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- getSyntheticRecordTypeFromRecordTypeKey(Object) - Method in class com.apple.foundationdb.record.RecordMetaData
- getSyntheticRecordTypes() - Method in interface com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordFromStoredRecordPlan
- 
Get the possible record types for the synthetic record generated by this plan.
- getSyntheticRecordTypes() - Method in class com.apple.foundationdb.record.RecordMetaData
- getTextCollator() - Method in interface com.apple.foundationdb.record.provider.common.text.TextCollatorRegistry
- 
Get a weak text collator for the default locale.
- getTextCollator(int) - Method in interface com.apple.foundationdb.record.provider.common.text.TextCollatorRegistry
- 
Get a text collator of the specified strength for the default locale.
- getTextCollator(int) - Method in class com.apple.foundationdb.record.provider.common.text.TextCollatorRegistryJRE
- getTextCollator(Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
- getTextCollator(String) - Method in interface com.apple.foundationdb.record.provider.common.text.TextCollatorRegistry
- 
Get a weak text collator for the given locale.
- getTextCollator(String, int) - Method in interface com.apple.foundationdb.record.provider.common.text.TextCollatorRegistry
- 
Get a text collator of the specified strength for the given locale.
- getTextCollator(String, int) - Method in class com.apple.foundationdb.record.provider.common.text.TextCollatorRegistryJRE
- getTextComparison() - Method in class com.apple.foundationdb.record.query.plan.TextScan
- 
Get the comparison performed on the text field.
- getTextScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- getTextTypes() - Method in class com.apple.foundationdb.record.query.plan.PlannableIndexTypes
- getTimeLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Get the time limit for query execution.
- getTimeNanos() - Method in class com.apple.foundationdb.record.provider.common.StoreTimer.Counter
- 
Get the cumulative time spent on the associated event.
- getTimeNanos() - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot.CounterSnapshot
- 
Get the cumulative time spent on the associated event.
- getTimeNanos(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Get the total time spent for a given event.
- getTimeoutCount(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Get the total count of timeouts for a given event.
- getTimeoutCounter(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Return the timeout counter value for a given event type.
- getTimeoutCounter(StoreTimer.Event, boolean) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- getTimeoutCounters() - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
- 
Returns the timeout counters taken at the time of the snapshot.
- getTimeoutCounterSnapshot(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
- 
Get the timeout counter for a given event.
- getTimeoutEvents() - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Get all events that have timed out.
- getTimeoutMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get the timeout time for the underlying transaction.
- getTimeoutTimeNanos(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Get the total time spent for a given event that timed out.
- getTimer() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Get theFDBStoreTimerused to instrument events of this cursor.
- getTimer() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Get the timer used in record contexts opened by this runner.
- getTimer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Get the timer to use to instrument events.
- getTimer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Get the timer to use to instrument events.
- getTimer() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- getTimer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- getTimer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- getTimer() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- getTimer() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the timer used inOnlineIndexer.buildIndex(boolean).
- getTimerEvent() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBLatencySource
- 
Get the event used to track this latency source byFDBStoreTimers.
- getTimeStamp() - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- getTimeWindow() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowAggregateFunction
- getTimeWindow() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowRecordFunction
- getTokenizedField(KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.planning.TextScanPlanner
- getTokenizer() - Method in class com.apple.foundationdb.record.provider.common.text.DefaultTextTokenizerFactory
- 
The instance of theDefaultTextTokenizersingleton.
- getTokenizer() - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizerFactory
- 
Get an instance of the text tokenizer.
- getTokenizer(Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexMaintainer
- 
Get the text tokenizer associated with this index.
- getTokenizer(String) - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizerRegistry
- 
Gets the tokenizer of the given name.
- getTokenizer(String) - Method in class com.apple.foundationdb.record.provider.common.text.TextTokenizerRegistryImpl
- getTokenizerName() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- getTotalSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get the total size (in bytes) of all keys and values in the requested key range.
- getTrackLastSeenVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getTrackOpenTimeNanos() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get the nanosecond time at which this context was opened.
- getTransactionAge() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get the number of milliseconds since context was created.
- getTransactionCreateTime() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- getTransactionId() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get the ID used by FoundationDB to track this transaction.
- getTransactionId() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Get the ID to use for the transaction within FDB logs.
- getTransactionId() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Get the ID to use for the transaction in FDB logs.
- getTransactionIsTracedSupplier() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- getTransactionTimeoutMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Get the transaction timeout time in milliseconds.
- getTransactionTimeoutMillis() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Get the transaction timeout for all transactions started by this runner.
- getTransactionTimeoutMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Set the transaction timeout time in milliseconds.
- getTransactionTimeoutMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Get the configured transaction timeout time in milliseconds.
- getType() - Method in class com.apple.foundationdb.record.metadata.Index
- getType() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- getType() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.TimeWindowSpec
- getType() - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
- 
Get the comparison type.
- getType() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
- getType() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- getType() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
- getType() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- getType() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
- getType() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- getType() - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
- getTypedRecordStore(RecordSerializer<N>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get a typed record store using the given typed serializer.
- getTypeHighBounds() - Method in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- getTypeLowBounds() - Method in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- getUnbuiltRange() - Method in exception com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.IndexNotBuiltException
- 
Get the unbuilt range associated with this exception.
- getUnionDescriptor() - Method in class com.apple.foundationdb.record.RecordMetaData
- getUnionDescriptor() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- getUnionField(Descriptors.Descriptor, Message) - Method in class com.apple.foundationdb.record.provider.common.MessageBuilderRecordSerializer
- getUnionField(Descriptors.Descriptor, U) - Method in class com.apple.foundationdb.record.provider.common.MessageBuilderRecordSerializerBase
- getUnionField(Descriptors.Descriptor, U) - Method in class com.apple.foundationdb.record.provider.common.TypedRecordSerializer
- getUnionField(DynamicMessage, Tuple) - Method in class com.apple.foundationdb.record.provider.common.DynamicMessageRecordSerializer
- getUnionFieldForRecordType(RecordType) - Method in class com.apple.foundationdb.record.RecordMetaData
- getUnionFieldForRecordType(RecordType) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- getUniversalIndex(String) - Method in class com.apple.foundationdb.record.RecordMetaData
- getUniversalIndexes() - Method in class com.apple.foundationdb.record.RecordMetaData
- getUnmatchedFieldCount() - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpressionComparisons
- getUnsatisfiedFilter() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Construct aQueryComponentthat is equal to the originalQueryComponentbut with any satisfied filters removed.
- getUnsatisfiedFilters() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Create a list of filters that are not satisfied.
- getUntypedRecordStore() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getUntypedRecordStore() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get the untyped record store associated with this possibly typed store.
- getUntypedRecordStore() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- getUntypedSerializer() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- 
Get the serializer that will be used by the underlying record store for non-typed operations such as building indexes.
- getUpdateTimestamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- getUpdateTimestamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
- getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- getUsedIndexes() - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Returns a set of names of the indexes used by this plan (and its sub-plans).
- getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- getUsedIndexes() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
- getUsedIndexes() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChildren
- getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- getUserVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Get the user version currently in use for this record store.
- getUserVersionChecker() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- getUserVersionChecker() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Get thefunctionto be used to check the meta-data version of the record store.
- getUserVersionChecker() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- getValue() - Method in class com.apple.foundationdb.record.IndexEntry
- 
Get the value portion of the index entry.
- getValue() - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- getValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Returns the constant value that this directory stores.
- getValue() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Returns the value that was provided when toKeySpacePath.add(String, Object)when this path was constructed.
- getValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- getValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverResult
- getValue(Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- 
Given aKey.Evaluatedreturned from the evaluation of this expression, splits out the portion of that expression that should be used to represent the value of a covering index.
- getValueExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- getValueFields(KeyExpression) - Static method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Return the value fields for an expression.
- getValueFor(Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.SourceEntry
- getValues() - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- getValues(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- getValues(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- getValues(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
- getValueSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor.SizeStatisticsResults
- 
Get the total size (in bytes) of all values in the requested key range.
- getValueSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- getValueSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- getValueSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- getValueSize() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBStoredSizes
- 
Get the size in bytes of all values used to store this record.
- getValueSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- 
Get the size in bytes of all values used to store this record.
- getValueSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- getValueSizeLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- getValuesWithThrowable(Throwable) - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- getValueTypes() - Method in class com.apple.foundationdb.record.query.plan.PlannableIndexTypes
- getVersion() - Method in class com.apple.foundationdb.record.metadata.FormerIndex
- 
Deprecated.
- getVersion() - Method in class com.apple.foundationdb.record.metadata.Index
- 
Deprecated.
- getVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- getVersion() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecord
- 
Get theFDBRecordVersionassociated with this record (ornull).
- getVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- getVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- getVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- getVersion() - Method in class com.apple.foundationdb.record.RecordMetaData
- getVersion() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- getVersion(FDBStoreTimer) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Gets the version as stored in the state key for thisLocatableResolver.
- getVersionstamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- getVersionStamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Return the ten byte version-stamp assigned to this context at commit time.
- getVertexAttributeProvider() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- getVertexID(N) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Get a unique string for a node which adheres to the current language.
- getVertexIDProvider() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- getVertexIds() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- getWarnAndCloseOpenContextsAfterSeconds() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Get whether to warn and close record contexts open for too long.
- getWeakestNoNextReason(List<S>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Gets the weakest reason for stopping of all cursor states.
- getWeakReadSemantics() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Get the read semantics used in record contexts opened by this runner.
- getWeakReadSemantics() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- getWeakReadSemantics() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Get theFDBDatabase.WeakReadSemanticsfrom this configuration.
- getWeakReadSemantics() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Get theFDBDatabase.WeakReadSemanticsconfiguration used when creating the transaction.
- getWeakReadSemantics() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Get the acceptable staleness bounds for transactions used by this build.
- getWholeKey() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- getWriteOnlyIndexNames() - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Get the names of any write-only indexes.
- geUUID() - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Get the UUID of this timer.
- global(FDBDatabase) - Static method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- 
Creates a default instance of the extended directory layer.
- global(FDBDatabase) - Static method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- 
Creates a default instance of the scoped directory layer.
- global(FDBDatabase) - Static method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- 
Creates a default instance of the scoped interning layer.
- GLOBAL_MIN_VERSION - Static variable in interface com.apple.foundationdb.record.provider.common.text.TextTokenizer
- 
The absolute minimum tokenizer version.
- GLOBAL_VERSION_LENGTH - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Length of the global versions used byFDBRecordVersion.
- gml(Object) - Static method in interface com.apple.foundationdb.record.query.plan.temp.explain.Attribute
- 
Static factory method to create a GML attribute based on a reference to some object.
- GmlExporter<N extends PlannerGraph.Node,E extends PlannerGraph.Edge> - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Exports a graph into a DOT file.
- GmlExporter(GraphExporter.ComponentIdProvider<N>, GraphExporter.ComponentAttributeProvider<N>, GraphExporter.ComponentIdProvider<E>, GraphExporter.ComponentAttributeProvider<E>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.GmlExporter
- 
Constructs a new GmlExporter object with the given ID, label, attribute, and graph ID providers.
- GraphExporter<N,E> - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Exports a graph into a DOT file.
- GraphExporter(GraphExporter.ComponentIdProvider<N>, GraphExporter.ComponentAttributeProvider<N>, GraphExporter.ComponentIdProvider<E>, GraphExporter.ComponentAttributeProvider<E>, Map<String, Attribute>, GraphExporter.ClusterProvider<N, E>, GraphExporter.ComponentAttributeProvider<N>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Constructs a new GraphExporter object with the given ID, label, attribute, and graph ID providers.
- GraphExporter.ClusterProvider<N,E> - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Shorthand-type for the extended functional interface.
- GraphExporter.ComponentAttributeProvider<T> - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Shorthand-type for the extended functional interface.
- GraphExporter.ComponentIdProvider<T> - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Shorthand-type for the extended functional interface.
- GraphExporter.ExporterContext - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Context class used while serializing the graph.
- GREATER_THAN - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- GREATER_THAN_OR_EQUALS - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- greaterThan(Object) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Checks if the field has a value greater than the given comparand.
- greaterThan(Object) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field is greater than the given comparand.
- greaterThan(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
- 
Checks if the key expression has a value greater than the given comparand.
- greaterThan(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- 
Checks if the calculated value has a value greater than the given comparand.
- greaterThanOrEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Checks if the field has a value greater than or equal to the given comparand.
- greaterThanOrEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field is greater than or equal to the given comparand.
- greaterThanOrEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
- 
Checks if the key expression has a value greater than or equal to the given comparand.
- greaterThanOrEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- 
Checks if the calculated value has a value greater than or equal to the given comparand.
- group(int) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- groupBy(KeyExpression, KeyExpression...) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- groupBy(KeyExpression, KeyExpression...) - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- groupBy(KeyExpression, KeyExpression...) - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- groupBy(KeyExpression, KeyExpression...) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- groupBy(KeyExpression, KeyExpression...) - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- GroupExpressionPrinter - Class in com.apple.foundationdb.record.query.plan.temp
- 
A utility class for printing out aGroupExpressionRefin a readable form.
- GroupExpressionPrinter(GroupExpressionRef<? extends RelationalExpression>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.GroupExpressionPrinter
- GroupExpressionRef<T extends RelationalExpression> - Class in com.apple.foundationdb.record.query.plan.temp
- 
A Cascades-style group expression, representing the members of set ofRelationalExpressions that belong to the same equivalence class.
- GroupExpressionRef() - Constructor for class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- GroupExpressionRef(T) - Constructor for class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- GroupExpressionRefEdge() - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.GroupExpressionRefEdge
- GroupExpressionRefEdge(Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.GroupExpressionRefEdge
- GroupExpressionRefInternalEdge() - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.GroupExpressionRefInternalEdge
- GroupingKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
A key expression that divides into two parts for the sake of aggregate or rank indexing.
- GroupingKeyExpression(KeyExpression, int) - Constructor for class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- GroupingKeyExpression(RecordMetaDataProto.Grouping) - Constructor for class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- groupOrderedScoreIndexKeys(Iterable<IndexEntry>, TimeWindowLeaderboardDirectory, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- 
Group the givenindexKeysby group of sizegroupPrefixSize, ordering within each group by score, takinghighScoreFirstinto account from the directory or any sub-directory (ifincludesGroupistrue).
H
- handleNextCursorResult(RecordCursorResult<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
- hasAllFields() - Method in class com.apple.foundationdb.record.query.plan.AvailableFields
- hasAllowedIndexes() - Method in class com.apple.foundationdb.record.query.RecordQuery
- hasAsyncFilter() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- hasAsyncFilter() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- hasAsyncToSyncTimeout() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- hasBytesRemaining() - Method in interface com.apple.foundationdb.record.ByteScanLimiter
- 
Atomically check whether the number of remaining bytes is at least 0.
- hasComparison(Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpressionComparisons
- hasData(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Synchronous version ofKeySpacePath.hasDataAsync(FDBRecordContext).
- hasDataAsync(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Check whether data exists for this path.
- hasDataAsync(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- hasDirtyStoreState() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Return whether any record store opened with this context has had its cache-able store state modified.
- hasExplicitRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.RecordType
- 
Get whether this record type sets an explicit value forRecordType.getRecordTypeKey().
- hasExplicitSubspaceKey() - Method in class com.apple.foundationdb.record.metadata.Index
- 
Checks whether the subspace key was set usingIndex.setSubspaceKey(Object).
- hasField(String) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
- hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- hasFullRecordScan() - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Indicates whether this plan (or one of its components) must perform a scan over all records in the store directly rather than going through a secondary index.
- hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- hasFullRecordScan() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
- hasFullRecordScan() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChildren
- hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- HASH - com.apple.foundationdb.record.logging.LogMessageKeys
- HASH_FUNCTION - com.apple.foundationdb.record.logging.LogMessageKeys
- hashCode - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- hashCode() - Method in class com.apple.foundationdb.record.IndexEntry
- hashCode() - Method in class com.apple.foundationdb.record.IndexScanType
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- hashCode() - Method in class com.apple.foundationdb.record.metadata.FormerIndex
- hashCode() - Method in class com.apple.foundationdb.record.metadata.Index
- hashCode() - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- hashCode() - Method in class com.apple.foundationdb.record.metadata.IndexRecordFunction
- hashCode() - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- hashCode() - Method in class com.apple.foundationdb.record.metadata.StoreRecordFunction
- hashCode() - Method in class com.apple.foundationdb.record.MutableRecordStoreState
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Hash code derived from the local and global version hash codes.
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexBuildState
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverResult
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedValue
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowAggregateFunction
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.TimeWindowSpec
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowRecordFunction
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderByKeySpacePath
- hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderBySubspace
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.AndComponent
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.BaseField
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextWithMaxDistanceComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.EmptyComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.NestedField
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.OrComponent
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.ScoreForRank
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.CorrelationIdentifier
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.AbstractNode
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.FullUnorderedScanExpression
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalTypeFilterExpression
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalUnorderedUnionExpression
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.IndexEntrySource
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.view.Source
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- hashCode() - Method in class com.apple.foundationdb.record.query.plan.TextScan
- hashCode() - Method in class com.apple.foundationdb.record.query.predicates.AndOrPredicate
- hashCode() - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- hashCode() - Method in class com.apple.foundationdb.record.query.predicates.NotPredicate
- hashCode() - Method in class com.apple.foundationdb.record.RecordCursorResult
- hashCode() - Method in class com.apple.foundationdb.record.RecordFunction
- hashCode() - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Creates a valid hash code of this state based on the hashes of its members.
- hashCode() - Method in class com.apple.foundationdb.record.TupleRange
- hashCode() - Method in class com.apple.foundationdb.record.ValueRange
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.FullUnorderedScanExpression
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalUnorderedUnionExpression
- hashCodeWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.temp.expressions.TypeFilterExpression
- hashCodeWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpression
- hasHookForAsyncToSync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- hasIndex(String) - Method in class com.apple.foundationdb.record.RecordMetaData
- hasIndexEntryRecord(IndexEntry, IsolationLevel) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Determine if a given index entry points to a record.
- hasIndexEntryRecord(Index, IndexEntry, IsolationLevel) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Deprecated.
- hasIndexScan(String) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- hasIndexScan(String) - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Indicates whether this plan scans the given index.
- hasIndexScan(String) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- hasIndexScan(String) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- hasIndexScan(String) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- hasIndexScan(String) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
- hasIndexScan(String) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChildren
- hasIndexScan(String) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- hasIndexScan(String) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- hasLoadBykeys() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- hasLoadBykeys() - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Indicates whether this plan (or one of its components) loads records by their primary key.
- hasLoadBykeys() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- hasLoadBykeys() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- hasLoadBykeys() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- hasLoadBykeys() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
- hasLoadBykeys() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChildren
- hasLoadBykeys() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- hasLoadBykeys() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- hasLongValue() - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation
- 
Determine whether this type aggregates long (integer) values.
- hasLongValue() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- hasMultiColumnComparand() - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
- 
Get whether the comparison is with the result of a multi-column key.
- hasMultiColumnComparand() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- hasNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- 
Deprecated.
- hasNext() - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Deprecated.in favor of theRecordCursor.onNext()method or advancing the cursorRecordCursor.asIterator()
- hasNext() - Method in class com.apple.foundationdb.record.RecordCursorIterator
- 
Synchronously check whether there are more records available from the cursor.
- hasNext() - Method in class com.apple.foundationdb.record.RecordCursorResult
- 
Return whether or not this result includes a next value.
- hasOrderBySourceWithoutComparison() - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpressionComparisons
- hasProperInterfaces() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- hasReadVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get whether this transaction's read version has already been set.
- hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- hasRecordScan() - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Indicates whether this plan (or one of its components) scans at least a subset of the record range directly rather than going through a secondary index.
- hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- hasRecordScan() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
- hasRecordScan() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChildren
- hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- hasRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- hasRecordTypeKey() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Check whether a key expression uses record type key in some way.
- hasRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- hasRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- hasRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- hasRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- hasRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- hasRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- hasRecordTypeKeyComparison(ScanComparisons) - Static method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- hasRecordTypePrefix(KeyExpression) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Determine whether the given key expression has a record type key prefix.
- hasSingleValue() - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation
- 
Determine whether this type aggregates exactly one value.
- hasSingleValue() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- hasStoppedBeforeEnd() - Method in class com.apple.foundationdb.record.RecordCursorResult
- 
Returnstrueif the cursor has reached its end but a continuation is not an end continuation (i.e., the source is not yet exhausted).
- hasStoredRecord() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- 
When scanning for orphaned index entries, this method must be used to determine whether or not a record exists before callinggetStoredRecord().
- hasStoredValue() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Deprecated.useKeySpace.resolveFromKey(FDBRecordContext, Tuple)instead
- hasStoredValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- 
Deprecated.
- hasUnion(Descriptors.FileDescriptor) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
- 
Checks if the file descriptor has a union.
- hasUniversalIndex(String) - Method in class com.apple.foundationdb.record.RecordMetaData
- hasValues() - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation
- 
Determine whether this type aggregates values (as opposed to something like counting records).
- hasValues() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- hasVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- hasVersion() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecord
- 
Get whether aFDBRecordVersionhas been set for thisStoredRecord.
- hasVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- hasVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- hasVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- HEADER_USER_FIELDS_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- HIGH_BYTES - com.apple.foundationdb.record.logging.LogMessageKeys
- HighContentionAllocator - Class in com.apple.foundationdb.record.provider.foundationdb.layers.interning
- 
A supplier of unique integers that tries to balance size of the integer and conflicts on the assignment.
- HighContentionAllocator(FDBRecordContext, KeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
- HighContentionAllocator(FDBRecordContext, KeySpacePath, Function<Long, CompletableFuture<Boolean>>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
- HighContentionAllocator(FDBRecordContext, Subspace, Subspace) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
- HighContentionAllocator(FDBRecordContext, Subspace, Subspace, Function<Long, CompletableFuture<Boolean>>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
- HighContentionAllocator(FDBRecordContext, Subspace, Function<Long, CompletableFuture<Boolean>>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
- HighContentionAllocator.AllocationWindow - Class in com.apple.foundationdb.record.provider.foundationdb.layers.interning
- 
A range of possible values to try.
- HISTORY_KEY_PREFIX - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
I
- id() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- identitiesFor(Set<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- IF_OVERLAPPING_CHANGED - com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.Rebuild
- IGNORE_COMPLETE_EXCEPTION_BLOCKING - com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
- 
WhenasyncToSync()is called in an asynchronous context and the future it is passed would block, an exception will be thrown.
- IGNORE_COMPLETE_WARN_BLOCKING - com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
- 
WhenasyncToSync()is called in an asynchronous context and the future it is passed would block, a warning is logged.
- ignoreComplete() - Method in enum com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
- 
Indicates how to react if the future passed intoasyncToSync()was completed.
- IllegalContinuationAccessChecker - Class in com.apple.foundationdb.record.cursors
- 
Check thatRecordCursor.getContinuation()is only called when allowed.
- IllegalResultNoNextReasonAccessException(Object, RecordCursorContinuation) - Constructor for exception com.apple.foundationdb.record.RecordCursorResult.IllegalResultNoNextReasonAccessException
- IllegalResultValueAccessException(RecordCursorContinuation, RecordCursor.NoNextReason) - Constructor for exception com.apple.foundationdb.record.RecordCursorResult.IllegalResultValueAccessException
- IllegalSubKeyException(int, int, int) - Constructor for exception com.apple.foundationdb.record.metadata.expressions.BaseKeyExpression.IllegalSubKeyException
- ImplementDistinctRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule that implements a distinct expression by adding aRecordQueryUnorderedPrimaryKeyDistinctPlanif necessary.
- ImplementDistinctRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.ImplementDistinctRule
- ImplementFilterRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule that implements a logical filter around aRecordQueryPlanas aRecordQueryFilterPlan.
- ImplementFilterRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.ImplementFilterRule
- ImplementTypeFilterRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule that implements a logical type filter on an (already implemented)RecordQueryPlanas aRecordQueryTypeFilterPlan.
- ImplementTypeFilterRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.ImplementTypeFilterRule
- ImplementUnorderedUnionRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule that implements an unordered union of its (already implemented) children.
- ImplementUnorderedUnionRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.ImplementUnorderedUnionRule
- in(String) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Query where the value of this field is in the list that is bound to the given param.
- in(String) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field is in the list that is bound to the given param.
- in(String) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- 
Checks if the result for this function is in the list that is bound to the given param.
- in(List<?>) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Query where the value of this field is in the given list.
- in(List<?>) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field is in the given list.
- in(List<?>) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- 
Checks if the result for this function is in the given list.
- IN - com.apple.foundationdb.record.Bindings.Internal
- IN - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- IN_JOIN - Static variable in class com.apple.foundationdb.record.PipelineOperation
- IN_MEMORY_TEMPORARY_DATA - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeIcon
- incomplete(int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Create aFDBRecordVersionthat is incomplete and has the given local version.
- IncompleteRecordVersionException() - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion.IncompleteRecordVersionException
- increment(int) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer.Counter
- 
Add an additional number of occurrences spent performing the associated event.
- increment(StoreTimer.Count) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Record that an event occurred once.
- increment(StoreTimer.Count) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- 
Record that an event occurred one time.
- increment(StoreTimer.Count) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- 
Record that an event occurred one time.
- increment(StoreTimer.Count, int) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Record that an event occurred one or more times.
- increment(StoreTimer.Count, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- 
Record that an event occurred one or more times.
- increment(StoreTimer.Count, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- 
Record that an event occurred one or more times.
- increment(Set<StoreTimer.Count>) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Record that each event in a set occurred once.
- increment(Set<StoreTimer.Count>, int) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Record that each event occurred one or more times.
- incrementCount() - Method in exception com.apple.foundationdb.record.logging.CompletionExceptionLogHelper.IgnoredSuppressedExceptionCount
- incrementVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Increments the version of the data stored in this directory layer.
- index - Variable in class com.apple.foundationdb.record.metadata.IndexValidator
- index - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
- index - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- Index - Class in com.apple.foundationdb.record.metadata
- 
Meta-data for a secondary index.
- Index(Index) - Constructor for class com.apple.foundationdb.record.metadata.Index
- 
Copy constructor.
- Index(RecordMetaDataProto.Index) - Constructor for class com.apple.foundationdb.record.metadata.Index
- Index(String, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.Index
- Index(String, KeyExpression, KeyExpression, String, Map<String, String>) - Constructor for class com.apple.foundationdb.record.metadata.Index
- Index(String, KeyExpression, String) - Constructor for class com.apple.foundationdb.record.metadata.Index
- Index(String, KeyExpression, String, Map<String, String>) - Constructor for class com.apple.foundationdb.record.metadata.Index
- 
Construct new index meta-data.
- Index(String, String) - Constructor for class com.apple.foundationdb.record.metadata.Index
- Index(String, String, String, String...) - Constructor for class com.apple.foundationdb.record.metadata.Index
- INDEX - com.apple.foundationdb.record.logging.TestLogMessageKeys
- INDEX - com.apple.foundationdb.record.provider.common.text.TextTokenizer.TokenizerMode
- 
Tokenize aStringas if it were about to be indexed.
- INDEX - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- INDEX_ASYNC_FILTER - Static variable in class com.apple.foundationdb.record.PipelineOperation
- INDEX_BUILD_SPACE - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- INDEX_BUILD_SPACE_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- INDEX_DATA - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeIcon
- INDEX_DATA - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- INDEX_KEY - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEX_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- INDEX_NAME - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEX_OPERATION - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEX_OPTION - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEX_RANGE_SPACE - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- INDEX_RANGE_SPACE_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- INDEX_SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- INDEX_SECONDARY_SPACE - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- INDEX_SECONDARY_SPACE_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- INDEX_STATE - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEX_STATE_PRECONDITION - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEX_STATE_SPACE - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- INDEX_STATE_SPACE_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- INDEX_SUBSPACE - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEX_TO_RECORD - Static variable in class com.apple.foundationdb.record.PipelineOperation
- INDEX_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEX_UNIQUENESS_VIOLATIONS_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- INDEX_UNIQUENESS_VIOLATIONS_SPACE - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- INDEX_VALUE - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEX_VERSION - com.apple.foundationdb.record.logging.LogMessageKeys
- IndexAggregateFunction - Class in com.apple.foundationdb.record.metadata
- 
An aggregate function implemented by scanning an appropriate index.
- IndexAggregateFunction(String, KeyExpression, String) - Constructor for class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- IndexAggregateGroupKeys - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Helper class for extracting grouping keys from anIndexAggregateFunctiongiven query conditions.
- IndexAggregateGroupKeys() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys
- IndexAggregateGroupKeys.Conditions - Class in com.apple.foundationdb.record.provider.foundationdb
- IndexAggregateGroupKeys.IndexScan - Class in com.apple.foundationdb.record.provider.foundationdb
- indexBuildScannedRecordsSubspace(FDBRecordStoreBase<?>, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- IndexBuildState - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A class that contains the build progress of a given index in a given record store.
- indexed(FDBIndexedRecord<M>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
- IndexEntry - Class in com.apple.foundationdb.record
- 
AnIndexEntrycarries around the key and value read from an index (as the name would imply).
- IndexEntry(Index, Key.Evaluated) - Constructor for class com.apple.foundationdb.record.IndexEntry
- IndexEntry(Index, Key.Evaluated, Key.Evaluated) - Constructor for class com.apple.foundationdb.record.IndexEntry
- IndexEntry(Index, Tuple, Tuple) - Constructor for class com.apple.foundationdb.record.IndexEntry
- indexEntryKey(Index, Tuple, Tuple) - Static method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Return a tuple to be used as the key for an index entry for the given value and primary key.
- indexEntryKey(Tuple, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
The entire index key to be used, including both the indexed value(s) and the primary key(s), with redundancy removed.
- indexEntryPrimaryKey(Index, Tuple) - Static method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Deprecated.useIndex.getEntryPrimaryKey(Tuple)instead
- IndexEntrySource - Class in com.apple.foundationdb.record.query.plan.temp
- 
A source of abstract index entries, each of which references a single record.
- IndexEntrySourceScanExpression - Class in com.apple.foundationdb.record.query.plan.temp.expressions
- 
A logical version ofRecordQueryIndexPlanthat represents a partially-implemented index scan.
- IndexEntrySourceScanExpression(IndexEntrySource, IndexScanType, ViewExpressionComparisons, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- indexEntryToQueriedRecord(FDBRecordStoreBase<M>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- INDEXER_CURR_RETRY - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEXER_ID - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEXER_MAX_RETRIES - com.apple.foundationdb.record.logging.LogMessageKeys
- INDEXER_SESSION_ID - com.apple.foundationdb.record.logging.LogMessageKeys
- indexes - Variable in class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
- INDEXES_NEED_REBUILDING - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of indexes that need to be rebuilt in the record store.
- indexesForRecordTypes(FDBRecordStore, List<String>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- 
The indexes that apply to exactly the given types, no more, no less.
- indexesForRecordTypes(RecordMetaData, Collection<String>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- 
The indexes that apply to exactly the given types, no more, no less.
- IndexFunctionHelper - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Helper class for finding appropriate indexes forIndexRecordFunctionandIndexAggregateFunction.
- IndexKeyValueToPartialRecord - Class in com.apple.foundationdb.record.query.plan
- 
Construct a record from a covering index.
- IndexKeyValueToPartialRecord.Builder - Class in com.apple.foundationdb.record.query.plan
- 
A builder forIndexKeyValueToPartialRecord.
- IndexKeyValueToPartialRecord.TupleSource - Enum in com.apple.foundationdb.record.query.plan
- 
Which side of theIndexEntryto take a field from.
- IndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Object responsible for translating record saves and deletes into updates to a secondary index.
- IndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- IndexMaintainerFactory - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
A factory forIndexMaintainer.
- indexMaintainerForAggregateFunction(FDBRecordStore, IndexAggregateFunction, List<String>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- indexMaintainerForRecordFunction(FDBRecordStore, IndexRecordFunction<?>, FDBRecord<?>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- 
Find an index that can evaluate the given function against the given record.
- indexMaintainerForRecordFunction(FDBRecordStore, IndexRecordFunction<?>, List<String>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- 
Find an index that can evaluate the given function against all of the given record types.
- indexMaintainerRegistry - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- IndexMaintainerRegistry - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
A registry ofIndexMaintainers.
- IndexMaintainerRegistryImpl - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A singletonIndexMaintainerRegistrythat findsIndexMaintainerFactoryclasses in the classpath.
- IndexMaintainerRegistryImpl() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerRegistryImpl
- IndexMaintainerState - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Common state for anIndexMaintainer.
- IndexMaintainerState(FDBRecordStore, Index, IndexMaintenanceFilter) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
- IndexMaintainerState(FDBRecordStore, FDBRecordContext, Index, Subspace, Transaction, IndexMaintenanceFilter) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
- indexMaintenanceFilter - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- IndexMaintenanceFilter - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
A hook for suppressing secondary indexing of some records.
- IndexMaintenanceFilter.IndexValues - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
Whether to maintain a subset of the indexable values for the given record.
- indexName - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- IndexNotBuiltException(String, Range, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.IndexNotBuiltException
- 
Creates an exception with the given message and the given range set as one of the unbuilt ranges.
- IndexOperation - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A maintenance operation on a secondary index.
- IndexOperation() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexOperation
- IndexOperationResult - Class in com.apple.foundationdb.record.provider.foundationdb
- 
The result of anIndexOperation.
- IndexOperationResult() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexOperationResult
- IndexOptions - Class in com.apple.foundationdb.record.metadata
- 
The standard options for use withIndex.
- IndexOrphanBehavior - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
Provided during index scan operations in which associated records are being retrieved, to indicate what should happen in response to an index entry which has no associated record.
- IndexQueryabilityFilter - Interface in com.apple.foundationdb.record.query
- 
A filter used to determine whether an index should be considered when planning queries.
- indexRangeSubspace(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Subspace for index in which to place aRangeSet.
- IndexRecordFunction<T> - Class in com.apple.foundationdb.record.metadata
- 
A function which is applied to a record with the help of an index.
- IndexRecordFunction(String, GroupingKeyExpression, String) - Constructor for class com.apple.foundationdb.record.metadata.IndexRecordFunction
- indexRegistry - Variable in class com.apple.foundationdb.record.metadata.MetaDataValidator
- IndexScan(String, int) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys.IndexScan
- indexScanToGroupKeys(String, int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys
- IndexScanType - Class in com.apple.foundationdb.record
- 
The way in which an index should be scanned.
- IndexScanType(String) - Constructor for class com.apple.foundationdb.record.IndexScanType
- indexSecondarySubspace(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- IndexState - Enum in com.apple.foundationdb.record
- 
Different states an index might be in within a given store.
- indexStateMap - Variable in class com.apple.foundationdb.record.RecordStoreState
- indexStateSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- indexStoredKeys(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- indexSubspace - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
- indexSubspace(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- indexSubspaceFromMaintainer(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- IndexTypes - Class in com.apple.foundationdb.record.metadata
- 
The standard index types.
- indexTypeToOptions(RecordMetaDataProto.Index.Type) - Static method in class com.apple.foundationdb.record.metadata.Index
- indexTypeToType(RecordMetaDataProto.Index.Type) - Static method in class com.apple.foundationdb.record.metadata.Index
- indexUniquenessViolationsSubspace(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Subspace for index in which to place a record in uniqueness violations.
- IndexValidator - Class in com.apple.foundationdb.record.metadata
- 
Validate an index according to the constraints of the index's type.
- IndexValidator(Index) - Constructor for class com.apple.foundationdb.record.metadata.IndexValidator
- IndexValidatorRegistry - Interface in com.apple.foundationdb.record.metadata
- 
A registry ofIndexValidators.
- INEQUALITY - com.apple.foundationdb.record.query.plan.ScanComparisons.ComparisonType
- INEQUALITY - com.apple.foundationdb.record.query.plan.temp.ComparisonRange.Type
- INEQUALITY - com.apple.foundationdb.record.query.QueryToKeyMatcher.MatchType
- inequalityComparisons - Variable in class com.apple.foundationdb.record.query.plan.ScanComparisons
- InExtractor - Class in com.apple.foundationdb.record.query.plan.planning
- 
ExtractINpredicates in a query filter by replacing them with equality comparisons with a bound parameter that will take on the values of the comparison list in turn.
- InExtractor(QueryComponent) - Constructor for class com.apple.foundationdb.record.query.plan.planning.InExtractor
- INFO_ADDED_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- init(TransactionContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.InstrumentedRankedSet
- initFDB() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- INITIAL_INDEX_STATE - com.apple.foundationdb.record.logging.LogMessageKeys
- INITIAL_PREFIX - com.apple.foundationdb.record.logging.LogMessageKeys
- initRegistry() - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerRegistryImpl
- INJECTED_COMMIT_LATENCY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time injected into committing transactions.
- INJECTED_GET_READ_VERSION_LATENCY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time injected by the client prior to getting a read version.
- inner - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
- inner - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- inner - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- inner - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- insert(T) - Method in interface com.apple.foundationdb.record.query.plan.temp.ExpressionRef
- 
Insert a new expression into this reference.
- insert(T) - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- insert(T) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- insertRecord(M) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Save the given record and throw an exception if a record already exists with the same primary key.
- insertRecordAsync(M) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Save the given record and throw an exception if a record already exists with the same primary key.
- instance() - Static method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression.Registry
- instance() - Static method in class com.apple.foundationdb.record.provider.common.DynamicMessageRecordSerializer
- instance() - Static method in class com.apple.foundationdb.record.provider.common.text.DefaultTextTokenizer
- 
Get this class's singleton.
- instance() - Static method in class com.apple.foundationdb.record.provider.common.text.TextCollatorRegistryJRE
- 
Get the singleton instance of this registry.
- instance() - Static method in class com.apple.foundationdb.record.provider.common.text.TextTokenizerRegistryImpl
- instance() - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- instance() - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBLocalityUtil
- 
Get the single instance of this utility class.
- instance() - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexBunchedSerializer
- 
Get the serializer singleton.
- instance() - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerRegistryImpl
- instance() - Static method in class com.apple.foundationdb.record.provider.foundationdb.storestate.PassThroughRecordStoreStateCache
- instance() - Static method in class com.apple.foundationdb.record.provider.foundationdb.storestate.PassThroughRecordStoreStateCacheFactory
- 
Get the factory singleton.
- INSTANCE - Static variable in class com.apple.foundationdb.record.provider.common.text.TextCollatorRegistryJRE
- INSTANCE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerRegistryImpl
- instrument(StoreTimer.Event, RecordCursor<T>) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Instrument an asynchronous cursor.
- instrument(StoreTimer.Event, RecordCursor<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- instrument(StoreTimer.Event, CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- instrument(StoreTimer.Event, CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- instrument(StoreTimer.Event, CompletableFuture<T>, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- instrument(StoreTimer.Event, CompletableFuture<T>, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- instrument(StoreTimer.Event, CompletableFuture<T>, Executor) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Add timing instrumentation to an asynchronous operation.
- instrument(StoreTimer.Event, CompletableFuture<T>, Executor, long) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Add timing instrumentation to an asynchronous operation.
- instrument(Set<StoreTimer.Event>, CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- instrument(Set<StoreTimer.Event>, CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- instrument(Set<StoreTimer.Event>, CompletableFuture<T>, Executor) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Add timing instrumentation to an asynchronous operation.
- instrument(Set<StoreTimer.Event>, CompletableFuture<T>, Executor, long) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Add timing instrumentation to an asynchronous operation.
- instrumentAsync(Set<StoreTimer.Event>, CompletableFuture<T>, Executor, long) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- InstrumentedRankedSet(IndexMaintainerState, Subspace, RankedSet.Config) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.InstrumentedRankedSet
- InstrumentedTransaction - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Wrapper aroundTransactionthat instruments certain calls to expose their behavior withFDBStoreTimermetrics.
- InstrumentedTransaction(StoreTimer, Transaction, boolean) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- intern(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- InternalPlannerGraphBuilder(PlannerGraph.Node) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.InternalPlannerGraphBuilder
- InternalPlannerGraphRewritable - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Interface to allowRelationalExpressions to rewrite their own internal graph representation.
- INTERNING_LAYER_CREATE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent adding a new entry to aScopedInterningLayer.
- INTERNING_LAYER_READ - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent reading an entry from aScopedInterningLayer.
- intersection(List<AvailableFields>) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields
- INTERSECTION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- IntersectionCursor<T> - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
- 
A cursor that implements an intersection of matching elements from a set of cursors all of whom are ordered compatibly.
- IntersectionMultiCursor<T> - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
- 
A cursor that implements an intersection of matching elements from a set of cursors all of whom are ordered compatibly.
- IntersectionVisitor - Class in com.apple.foundationdb.record.query.plan.visitor
- 
This visitor pulls index fetches after the intersection if possible.
- IntersectionVisitor(RecordMetaData, PlannableIndexTypes, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.visitor.IntersectionVisitor
- INVALID_KEY_LENGTH - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of record keys with an incorrect length found byFDBRecordStore.repairRecordKeys(byte[], com.apple.foundationdb.record.ScanProperties).
- INVALID_SPLIT_SUFFIX - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of record keys with an invalid split suffix found byFDBRecordStore.repairRecordKeys(byte[], com.apple.foundationdb.record.ScanProperties).
- InvalidExpressionException(String) - Constructor for exception com.apple.foundationdb.record.metadata.expressions.KeyExpression.InvalidExpressionException
- InvalidExpressionException(String) - Constructor for exception com.apple.foundationdb.record.query.expressions.Query.InvalidExpressionException
- InvalidExpressionException(String, Object...) - Constructor for exception com.apple.foundationdb.record.metadata.expressions.KeyExpression.InvalidExpressionException
- InvalidIndexEntry - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
An invalid index entry including the entry and the reason why it is invalid.
- InvalidIndexEntry(IndexEntry, InvalidIndexEntry.Reason) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry
- 
Deprecated.
- InvalidIndexEntry.Reason - Interface in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
The reason why an index entry is invalid.
- InvalidIndexEntry.Reasons - Enum in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
The reasons supported in the Record Layer.
- InvalidResultException(String) - Constructor for exception com.apple.foundationdb.record.metadata.expressions.KeyExpression.InvalidResultException
- invisible(Object) - Static method in interface com.apple.foundationdb.record.query.plan.temp.explain.Attribute
- 
Static factory method to create an attribute based on a reference to some object.
- IS_NULL - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- IS_SPLIT - com.apple.foundationdb.record.logging.LogMessageKeys
- IS_VERSIONED_INLINE - com.apple.foundationdb.record.logging.LogMessageKeys
- isAllTime() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
- isAsync() - Method in class com.apple.foundationdb.record.query.expressions.AndOrComponent
- isAsync() - Method in class com.apple.foundationdb.record.query.expressions.BaseNestedField
- isAsync() - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
- isAsync() - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
- 
Get whether this component is asynchronous.
- isAsync() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- isCausalReadRisky() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase.WeakReadSemantics
- isChanged() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdateResult
- isCheckForDuplicateConditions() - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
- 
Get whether this normalizer attempts to remove redundant conditions.
- isClosed() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- isCompatible(KeySpaceDirectory, KeySpaceDirectory) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
- isCompatible(KeySpaceDirectory, KeySpaceDirectory) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
When a subdirectory is being added to a directory and an existing subdirectory is found that stores the same data type but with a different constant value, this method will be called both on the directory being added as well as the existing subdirectory to allow them to determine if they are compatible with each other.
- isComplete() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Whether this version has all of its relevant data set.
- isContinueIfWriteOnly() - Method in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
- isDefaultValue() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBTraceFormat
- 
Get whether this is the default trace format.
- isDisabled(Index) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Determines whether the index is disabled.
- isDisabled(String) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Determines whether the index of the given is disabled.
- isEmpty() - Method in class com.apple.foundationdb.record.query.expressions.EmptyComparison
- isEmpty() - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Returns true if the repeated field does not have any occurrences.
- isEmpty() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- isEmpty() - Method in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- isEmpty() - Method in class com.apple.foundationdb.record.query.plan.temp.RelationalExpressionPointerSet
- isEnd() - Method in class com.apple.foundationdb.record.ByteArrayContinuation
- isEnd() - Method in interface com.apple.foundationdb.record.RecordCursorContinuation
- 
Return whether this continuation is an "end continuation", i.e., represents that the iteration has reached its end and would not produce more results even if restarted.
- isEnd() - Method in class com.apple.foundationdb.record.RecordCursorEndContinuation
- isEnd() - Method in class com.apple.foundationdb.record.RecordCursorStartContinuation
- isEnforcing() - Method in interface com.apple.foundationdb.record.ByteScanLimiter
- 
Return whether or not this limiter is actully enforcing the limit (vs one that simply tracks resource consumption).
- isEnforcing() - Method in interface com.apple.foundationdb.record.RecordScanLimiter
- 
Return whether or not this limiter has an actual limit.
- isEquality() - Method in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
- isEquality() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- isEquality() - Method in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- isEquals() - Method in class com.apple.foundationdb.record.TupleRange
- isExplored() - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- isFailOnScanLimitReached() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Get whether reaching the scan limit throws an exception.
- isGroupPrefix(KeyExpression, KeyExpression) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
- 
Is the operand for this function compatible with this index? The grouped part must match.
- isHighScoreFirst() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- isHighScoreFirst() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardSubDirectory
- isHighScoreFirst() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
- isHighScoreFirst(TimeWindowLeaderboardDirectory, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- isIdempotent() - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation
- 
Determine whether this type is idempotent.
- isIdempotent() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- isIdempotent() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- isIdempotent() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- isIdempotent() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainer
- isIdempotent() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- isIdempotent() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Whether updating or removing a record on this index is idempotent.
- isIdempotent() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- isIncludesGroup() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardScoreTrim
- isIndexDisabled(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Determine if the index is disabled for this record store.
- isIndexDisabled(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Determine if the index with the given name is disabled for this record store.
- isIndexReadable(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Determine if the index is readable for this record store.
- isIndexReadable(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Determine if the index with the given name is readable for this record store.
- isIndexScan() - Method in class com.apple.foundationdb.record.query.plan.temp.IndexEntrySource
- isIndexWriteOnly(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Determine if the index is write-only for this record store.
- isIndexWriteOnly(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Determine if the index with the given name is write-only for this record store.
- isInequality() - Method in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- isInternal(String) - Static method in enum com.apple.foundationdb.record.Bindings.Internal
- isLeaf() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Returns whether or not the directory is a leaf directory (has no subdirectories).
- isLimitReached() - Method in enum com.apple.foundationdb.record.RecordCursor.NoNextReason
- 
Does this reason indicate that some limit was reached? This includes both the in-band returned row limit and the out-of-band time and other resource limits.
- isLogged() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get whether the current transaction details are logged to the client trace logs.
- isLogTransaction() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Get whether transaction is logged to FDB client logs.
- isLogTransaction() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Get whether transaction is logged to FDB client logs.
- isMatch(Object) - Method in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- 
Get whether the provided value can be represented by this type.
- isNull() - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Returns true if the field has not been set and uses the default value.
- isNull() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
- 
Returns true if the key expression evaluates tonull.
- isolationLevel - Variable in class com.apple.foundationdb.record.ExecuteProperties
- IsolationLevel - Enum in com.apple.foundationdb.record
- 
The isolation level for reads from the database.
- isOr() - Method in class com.apple.foundationdb.record.query.expressions.AndComponent
- isOr() - Method in class com.apple.foundationdb.record.query.expressions.AndOrComponent
- isOr() - Method in class com.apple.foundationdb.record.query.expressions.OrComponent
- isOuterJoined() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordType.JoinConstituent
- isOuterJoined() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder.JoinConstituent
- isOutOfBand() - Method in enum com.apple.foundationdb.record.RecordCursor.NoNextReason
- 
Does this reason represent an out-of-band (that is, not solely dependent on the records returned) completion? In general, when an out-of-band reason is encountered, the entire cursor tree unwinds and returns to the client to start over fresh with a new cursor.
- isPrefixKey(KeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.BaseKeyExpression
- isPrefixKey(KeyExpression) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Check whether a key is a prefix of another key.
- isPrimaryKeyOrdered() - Method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
- 
Returntrueif only primary key fields follow the prefix.
- isQueryable(Index) - Method in interface com.apple.foundationdb.record.query.IndexQueryabilityFilter
- 
Return whether the given index should be considered by the query planner.
- isReadable(Index) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Determines whether the index is readable.
- isReadable(String) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Determines whether the index of the given name is readable.
- isReady() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext.CommitCheckAsync
- 
Get whether the check is ready to be tested.
- isRebuildConditional() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer.UpdateState
- isRebuilt() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdateResult
- isRecordStoreLeaf(FDBRecordContext, KeySpaceCountTree.Resolved, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- 
Determine whether this leaf of theKeySpaceDirectorytree is the root of aFDBRecordStore.
- isRetriable(Throwable) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBExceptions
- 
Returns whether an exception is retriable or is caused by a retriable error.
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- isReverse() - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Indicates whether this plan will return values in "reverse" order from the natural order of results of this plan.
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- isReverse() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- isReverse() - Method in class com.apple.foundationdb.record.ScanProperties
- 
Get direction of scans.
- isSatisfied() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Return whether this filter is known to have been satisfied.
- isSaveOpenStackTrace() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Get whether stack trace is recorded when context is opened.
- isSaveOpenStackTrace() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Get whether stack trace is recorded when context is opened.
- isSingleFieldComparison(QueryComponent) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- isSize() - Method in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Counts
- isSize() - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Count
- 
Get whether the count value is actually a size in bytes.
- isSize() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.CountAggregates
- isSize() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- isSnapshot() - Method in enum com.apple.foundationdb.record.IsolationLevel
- isSnapshot() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- isSorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- isSortReverse() - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- isSortReverse() - Method in class com.apple.foundationdb.record.query.RecordQuery
- isSourceExhausted() - Method in enum com.apple.foundationdb.record.RecordCursor.NoNextReason
- 
Does this reason indicate that there is no more data available? These are the cases in whichRecordCursor.getContinuation()would returnnull.
- isSplit() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- isSplit() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- isSplit() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- isSplit() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBStoredSizes
- 
Get whether this record is split between two or more key-value pairs.
- isSplit() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- isSplit() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- isSplitLongRecords() - Method in class com.apple.foundationdb.record.RecordMetaData
- isSplitLongRecords() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- isStopped() - Method in class com.apple.foundationdb.record.cursors.CursorLimitManager
- 
Report whether any limit handled by this manager has been exceeded.
- isStoreRecordVersions() - Method in class com.apple.foundationdb.record.RecordMetaData
- isStoreRecordVersions() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- isStrict() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
- 
Whether this comparison should be strictly evaluated.
- isSynthetic() - Method in class com.apple.foundationdb.record.metadata.RecordType
- 
Get whether this record type represents synthetic records.
- isSynthetic() - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordType
- isTimedOut - Variable in class com.apple.foundationdb.record.TimeScanLimiter
- isTrackLastSeenVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- isTrackLastSeenVersionOnCommit() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- isTrackLastSeenVersionOnRead() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- isTrackOpen() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Get whether open context is tracked in the associatedFDBDatabase.
- isTrackOpen() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Get whether open context is tracked in the associatedFDBDatabase.
- isTupleField(Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Test whether a message field's descriptor is one of the special ones.
- isUnary() - Method in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
- isUnclosedWarning() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- isUnique() - Method in class com.apple.foundationdb.record.metadata.Index
- 
Whether this index should have the property that any two records with different primary keys should have different values for this index.
- isValid() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
- 
To be valid for covering index use, must set all required fields and not attempt to set repeated fields, for which the index only has a partial view.
- isValidId(String) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- 
Test if the ID candidate is a valid ID.
- isValidId(String) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GmlExporter
- 
Test if the ID candidate is a valid ID.
- isValidId(String) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- isVersionedInline() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- isVersionedInline() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- isVersionedInline() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- isVersionedInline() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBStoredSizes
- 
Get whether this record was stored with an associated version.
- isVersionedInline() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- isVersionedInline() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- isVisible(GraphExporter.ExporterContext) - Method in interface com.apple.foundationdb.record.query.plan.temp.explain.Attribute.CommonAttribute
- isVisible(GraphExporter.ExporterContext) - Method in interface com.apple.foundationdb.record.query.plan.temp.explain.Attribute.DotAttribute
- isVisible(GraphExporter.ExporterContext) - Method in interface com.apple.foundationdb.record.query.plan.temp.explain.Attribute.GmlAttribute
- isVisible(GraphExporter.ExporterContext) - Method in interface com.apple.foundationdb.record.query.plan.temp.explain.Attribute.InvisibleAttribute
- isVisible(GraphExporter.ExporterContext) - Method in interface com.apple.foundationdb.record.query.plan.temp.explain.Attribute
- 
Returns whether this method is visible in the given context.
- isWriteOnly(Index) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Determines whether the index provided is a write-only index.
- isWriteOnly(String) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Determines whether the index of the given name is a write-only index.
- iterablePlanHash(Iterable<?>) - Static method in interface com.apple.foundationdb.record.PlanHashable
- ITERATION - com.apple.foundationdb.record.logging.TestLogMessageKeys
- iterator() - Method in class com.apple.foundationdb.record.query.plan.temp.RelationalExpressionPointerSet
- iterator() - Method in interface com.apple.foundationdb.record.query.plan.temp.TopologicalSort.TopologicalOrderPermutationIterable
- ITERATOR - com.apple.foundationdb.record.CursorStreamingMode
- 
The client will process records one-at-a-time.
- IteratorCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that returns the elements of an ordinary synchronous iterator.
- IteratorCursor(Executor, Iterator<T>) - Constructor for class com.apple.foundationdb.record.cursors.IteratorCursor
- IV_SIZE - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
J
- JDK - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetHashFunctions
- join(CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Join a future, following the same logic thatasyncToSync()uses to validate that the operation isn't blocking in an asynchronous context.
- join(CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Join a future following the same logic thatasyncToSync()uses to validate that the operation isn't blocking in an asynchronous context.
- Join(JoinedRecordType.JoinConstituent, KeyExpression, JoinedRecordType.JoinConstituent, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.JoinedRecordType.Join
- Join(String, KeyExpression, String, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder.Join
- JoinConstituent(String, RecordTypeBuilder, boolean) - Constructor for class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder.JoinConstituent
- JoinConstituent(String, RecordType, boolean) - Constructor for class com.apple.foundationdb.record.metadata.JoinedRecordType.JoinConstituent
- JoinedRecordType - Class in com.apple.foundationdb.record.metadata
- 
A synthetic record type representing the indexable result of joining stored records.
- JoinedRecordType(RecordMetaData, Descriptors.Descriptor, KeyExpression, Object, List<Index>, List<Index>, List<JoinedRecordType.JoinConstituent>, List<JoinedRecordType.Join>) - Constructor for class com.apple.foundationdb.record.metadata.JoinedRecordType
- JoinedRecordType.Join - Class in com.apple.foundationdb.record.metadata
- 
An equi-join between constituent types.
- JoinedRecordType.JoinConstituent - Class in com.apple.foundationdb.record.metadata
- 
A constituent type within a joined record type.
- JoinedRecordTypeBuilder - Class in com.apple.foundationdb.record.metadata
- 
A builder forJoinedRecordType.
- JoinedRecordTypeBuilder(RecordMetaDataProto.JoinedRecordType, RecordMetaDataBuilder) - Constructor for class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder
- JoinedRecordTypeBuilder(String, Object, RecordMetaDataBuilder) - Constructor for class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder
- JoinedRecordTypeBuilder.Join - Class in com.apple.foundationdb.record.metadata
- 
An equi-join between constituent types.
- JoinedRecordTypeBuilder.JoinConstituent - Class in com.apple.foundationdb.record.metadata
- 
A constituent type within a joined record type.
- joinNow(CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Join a future but validate that the future is already completed.
- joinNow(CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Join a future but validate that the future is already completed.
- joinSession(Subspace, UUID, long, FDBDatabaseRunnerImpl) - Static method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- 
Produces a new runner, wrapping a given runner, which performs all work in the context of an existingSynchronizedSession.
- joinSynchronizedSession(Subspace, UUID, long) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Produces a new runner, wrapping this runner, which performs all work in the context of an existingSynchronizedSession.
- joinSynchronizedSession(Subspace, UUID, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- joinSynchronizedSession(Subspace, UUID, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- JSON - com.apple.foundationdb.record.provider.foundationdb.FDBTraceFormat
- 
Format the trace logs as JSON.
K
- key() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- Key - Class in com.apple.foundationdb.record.metadata
- 
Namespace for classes related toKeyExpressionconstruction and evaluation.
- KEY - com.apple.foundationdb.record.logging.LogMessageKeys
- KEY - com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.TupleSource
- KEY_COMPARATOR - Static variable in class com.apple.foundationdb.record.provider.foundationdb.cursors.KeyComparisons
- KEY_COUNT - com.apple.foundationdb.record.logging.LogMessageKeys
- KEY_EVALUATED - com.apple.foundationdb.record.logging.LogMessageKeys
- KEY_EXPRESSION - com.apple.foundationdb.record.logging.LogMessageKeys
- KEY_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
- KEY_SIZE_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- KEY_SPACE_PATH - com.apple.foundationdb.record.logging.LogMessageKeys
- KEY_TO_RECORD - Static variable in class com.apple.foundationdb.record.PipelineOperation
- KEY_TUPLE - com.apple.foundationdb.record.logging.LogMessageKeys
- Key.Evaluated - Class in com.apple.foundationdb.record.metadata
- 
Represents the list objects for a key in a secondary index or primary storage.
- Key.Evaluated.NullStandin - Enum in com.apple.foundationdb.record.metadata
- 
Values used in index keys in place of missing fields.
- Key.Expressions - Class in com.apple.foundationdb.record.metadata
- 
Holder class for the static methods for creating Key Expressions.
- KeyComparisons - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
- 
Comparators for key expressions.
- keyContainsNonUniqueNull() - Method in class com.apple.foundationdb.record.IndexEntry
- 
Returns true if the key expression contains a NULL value that is not aKey.Evaluated.NullStandin.NULL_UNIQUEvalue.
- keyExists(ReadTransaction, FDBTransactionContext, Subspace, Tuple, boolean, boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper
- 
Checks to see if a given key exists.
- keyExpression(KeyExpression) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
Build query components using a key expression.
- KeyExpression - Interface in com.apple.foundationdb.record.metadata.expressions
- 
Interface for expressions that evaluate to keys.
- KeyExpression.DeserializationException - Exception in com.apple.foundationdb.record.metadata.expressions
- 
Exception thrown when there is a problem deserializing a key expression.
- KeyExpression.FanType - Enum in com.apple.foundationdb.record.metadata.expressions
- 
How should repeated fields be handled.
- KeyExpression.InvalidExpressionException - Exception in com.apple.foundationdb.record.metadata.expressions
- 
Exception thrown when there is a problem with using a key expression in a certain context.
- KeyExpression.InvalidResultException - Exception in com.apple.foundationdb.record.metadata.expressions
- 
This is a runtime exception (i.e.
- KeyExpression.NoSuchArgumentException - Exception in com.apple.foundationdb.record.metadata.expressions
- 
Exception thrown when a function key expression does not have an argument.
- KeyExpression.SerializationException - Exception in com.apple.foundationdb.record.metadata.expressions
- 
Exception thrown when there is a problem serializing a key expression.
- KeyExpressionWithChild - Interface in com.apple.foundationdb.record.metadata.expressions
- 
AKeyExpressionwith exactly one child expression.
- KeyExpressionWithChildren - Interface in com.apple.foundationdb.record.metadata.expressions
- 
AKeyExpressionwith child expressions.
- KeyExpressionWithoutChildren - Interface in com.apple.foundationdb.record.metadata.expressions
- 
AKeyExpressionwith no children.
- KeyRange - Class in com.apple.foundationdb.record
- 
A range within a subspace specified by two byte value endpoints.
- KeyRange(byte[], byte[]) - Constructor for class com.apple.foundationdb.record.KeyRange
- 
Creates a key range.
- KeyRange(byte[], EndpointType, byte[], EndpointType) - Constructor for class com.apple.foundationdb.record.KeyRange
- 
Creates a key range.
- KeySpace - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
AKeySpacedefines a logical directory structure for keys that comprise an FDB row key.
- KeySpace(KeySpaceDirectory...) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- KeySpace(String, KeySpaceDirectory...) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- KeySpaceCountTree - Class in com.apple.foundationdb.record.provider.foundationdb.clientlog
- 
Count keys and resolve back to key space paths.
- KeySpaceCountTree(KeySpaceCountTree, byte[], Object) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- KeySpaceCountTree(KeySpace) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- KeySpaceCountTree.Resolved - Class in com.apple.foundationdb.record.provider.foundationdb.clientlog
- 
The resolved interpretation of the node value.
- KeySpaceCountTree.ResolvedIndexKeyspace - Class in com.apple.foundationdb.record.provider.foundationdb.clientlog
- 
A resolved index keyspace.
- KeySpaceCountTree.ResolvedKeyField - Class in com.apple.foundationdb.record.provider.foundationdb.clientlog
- 
A resolved field of a record primary key or index key.
- KeySpaceCountTree.ResolvedPath - Class in com.apple.foundationdb.record.provider.foundationdb.clientlog
- KeySpaceCountTree.ResolvedPrefixRoot - Class in com.apple.foundationdb.record.provider.foundationdb.clientlog
- 
KeySpaceCountTree.ResolvedRootwith a prefix object.
- KeySpaceCountTree.ResolvedRecordStoreKeyspace - Class in com.apple.foundationdb.record.provider.foundationdb.clientlog
- 
A resolved record store keyspace, such as records or indexes.
- KeySpaceCountTree.ResolvedRecordTypeKeyspace - Class in com.apple.foundationdb.record.provider.foundationdb.clientlog
- 
A resolved record type key prefix keyspace.
- KeySpaceCountTree.ResolvedRoot - Class in com.apple.foundationdb.record.provider.foundationdb.clientlog
- 
KeySpaceCountTree.Resolvedto aKeySpaceroot.
- KeySpaceDirectory - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
Defines a directory within aKeySpace.
- KeySpaceDirectory(String, KeySpaceDirectory.KeyType) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Creates a directory that can hold any value of a given type.
- KeySpaceDirectory(String, KeySpaceDirectory.KeyType, Object) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- KeySpaceDirectory(String, KeySpaceDirectory.KeyType, Object, Function<KeySpacePath, KeySpacePath>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Creates a directory.
- KeySpaceDirectory(String, KeySpaceDirectory.KeyType, Function<KeySpacePath, KeySpacePath>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Creates a directory that can hold any value of a given type.
- KeySpaceDirectory.KeyType - Enum in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
The available data types for directories.
- KeySpacePath - Interface in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
AKeySpacePathrepresents a discrete path through a directory tree defined by aKeySpace.
- KeySpacePathWrapper - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
Helper class to make it easy to createKeySpacePathwrapper implementations for use inKeySpaceDirectory(String, KeySpaceDirectory.KeyType, Object, java.util.function.Function)(String, KeySpaceDirectory.KeyType, Object, Function)}.
- KeySpacePathWrapper(KeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- keyType - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- KeyValueCursor - Class in com.apple.foundationdb.record.provider.foundationdb
- 
The basic cursor for scanning ranges of the FDB database.
- KeyValueCursor.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A builder forKeyValueCursor.
- KeyValueLogMessage - Class in com.apple.foundationdb.record.logging
- 
A formatter for log messages.
- KeyValueUnsplitter(FDBRecordContext, Subspace, RecordCursor<KeyValue>, boolean, SplitHelper.SizeInfo, boolean, CursorLimitManager) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- KeyValueUnsplitter(FDBRecordContext, Subspace, RecordCursor<KeyValue>, boolean, SplitHelper.SizeInfo, ScanProperties) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- keyWithValue(KeyExpression, int) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
AkeyWithValueexpression is a top level expression that takes as input an expression that produces more than one column, and indicates that all columns before the specifiedsplitPointshould be used in the key of an index and all of the values starting at thesplitPointare to be used as the value of the index.
- KeyWithValueExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
AKeyWithValueexpression is a top level expression that takes as input an expression that produces more than one column, and indicates that all columns before the specifiedsplitPointshould be used in the key of a covering index and all of the values starting at thesplitPointare to be used as the value of a covering index.
- KeyWithValueExpression(KeyExpression, int) - Constructor for class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- KeyWithValueExpression(RecordMetaDataProto.KeyWithValue) - Constructor for class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- KNOWN_LAST_KEY - com.apple.foundationdb.record.logging.LogMessageKeys
L
- lastInDBVersion(long) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Returns the lastFDBRecordVersionthat could have been written at the given database version.
- lastInGlobalVersion(byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Return the lastFDBRecordVersionthat could be written at the given global version.
- lastReset - Variable in class com.apple.foundationdb.record.provider.common.StoreTimer
- LATEST_ENTRY_TIMESTAMP - com.apple.foundationdb.record.logging.LogMessageKeys
- LazyCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
Wraps a future that supplies a record cursor.
- LazyCursor(CompletableFuture<RecordCursor<T>>) - Constructor for class com.apple.foundationdb.record.cursors.LazyCursor
- LazyCursor(CompletableFuture<RecordCursor<T>>, Executor) - Constructor for class com.apple.foundationdb.record.cursors.LazyCursor
- 
Creates a new lazy cursor.
- length - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.TransformState
- LESS_THAN - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- LESS_THAN_OR_EQUALS - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- lessThan(Object) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Checks if the field has a value less than the given comparand.
- lessThan(Object) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field is less than the given comparand.
- lessThan(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
- 
Checks if the key expression has a value less than the given comparand.
- lessThan(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- 
Checks if the calculated value has a value less than the given comparand.
- lessThanOrEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Checks if the field has a value less than or equal to the given comparand.
- lessThanOrEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field is less than or equal to the given comparand.
- lessThanOrEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
- 
Checks if the key expression has a value less than or equal to the given comparand.
- lessThanOrEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- 
Checks if the calculated value has a value less than or equal to the given comparand.
- limit - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- LIMIT - com.apple.foundationdb.record.logging.LogMessageKeys
- limitReached() - Method in class com.apple.foundationdb.record.cursors.RowLimitedCursor
- limitRowsTo(int) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that will only return records up to the given limit.
- limitTo(int) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Deprecated.UseRecordCursor.limitRowsTo(int)instead.
- list(KeyExpression...) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Combine multiple expressions into a list.
- list(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Deprecated.useKeySpace.listDirectory(FDBRecordContext, String)instead
- list(FDBRecordContext, String) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Deprecated.
- list(FDBRecordContext, String, ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Deprecated.
- list(FDBRecordContext, String, ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Deprecated.
- list(FDBRecordContext, String, ValueRange<?>, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Deprecated.
- list(List<KeyExpression>) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Combine multiple expressions into a list.
- LIST_EMPTY - Static variable in class com.apple.foundationdb.record.query.expressions.Comparisons
- LIST_FROM - com.apple.foundationdb.record.logging.LogMessageKeys
- listAsync(FDBRecordContext, String, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Deprecated.
- listAsync(FDBRecordContext, String, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Deprecated.
- listAsync(FDBRecordContext, String, ValueRange<?>, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Deprecated.
- listAsync(FDBRecordContext, String, ValueRange<?>, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- 
Deprecated.
- ListChildrenMatcher - Class in com.apple.foundationdb.record.query.plan.temp.matchers
- 
A matcher for a children that tries to match each child to a specified matcher.
- ListComparison(Comparisons.Type, List) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
- ListCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that returns the elements of a list.
- ListCursor(Executor, List<T>, int) - Constructor for class com.apple.foundationdb.record.cursors.ListCursor
- ListCursor(List<T>, byte[]) - Constructor for class com.apple.foundationdb.record.cursors.ListCursor
- listDirectory(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Synchronously list the available paths from a directory.
- listDirectory(FDBRecordContext, String, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Synchronously list the available paths from a directory.
- listDirectory(FDBRecordContext, String, ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Synchronously list the available paths from a directory.
- listDirectoryAsync(FDBRecordContext, String, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
List the available paths from a directory.
- ListKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
Combine keys from zero or more child keys.
- ListKeyExpression(RecordMetaDataProto.List) - Constructor for class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- ListKeyExpression(List<KeyExpression>) - Constructor for class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- listSubdirectory(FDBRecordContext, String) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Synchronous/blocking version oflistSubdirectoryAsync.
- listSubdirectory(FDBRecordContext, String, ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Synchronous/blocking version oflistSubdirectoryAsync.
- listSubdirectory(FDBRecordContext, String, ValueRange<?>, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Synchronous/blocking version oflistSubdirectoryAsync.
- listSubdirectory(FDBRecordContext, String, ValueRange<?>, ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Synchronous/blocking version oflistSubdirectoryAsync.
- listSubdirectoryAsync(FDBRecordContext, String, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
For a given subdirectory from this path element, return a list of paths for all available keys in the FDB keyspace for that directory.
- listSubdirectoryAsync(FDBRecordContext, String, ValueRange<?>, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
For a given subdirectory from this path element, return a list of paths for all available keys in the FDB keyspace for that directory.
- listSubdirectoryAsync(FDBRecordContext, String, ValueRange<?>, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- listSubdirectoryAsync(KeySpacePath, FDBRecordContext, String, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- listSubdirectoryAsync(KeySpacePath, FDBRecordContext, String, ValueRange<?>, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- LiteralElement<T> - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
A value representing a single, static value of typeT.
- LiteralElement(T) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- LiteralKeyExpression<T> - Class in com.apple.foundationdb.record.metadata.expressions
- 
Expression to allow a static value to be utilized in a key expression.
- LiteralKeyExpression(T) - Constructor for class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- LITTLE_ENDIAN_INT64_MINUS_ONE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- LITTLE_ENDIAN_INT64_ONE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- LOAD_BOUNDARY_KEYS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent loading boundary keys.
- LOAD_BY_KEYS_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- LOAD_INDEX_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of index key-value pairs loaded.
- LOAD_INDEX_KEY_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of keys for index key-value pairs loaded.
- LOAD_INDEX_VALUE_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of values for index key-value pairs loaded.
- LOAD_KEY_VALUE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of key-value pairs loaded by a range scan.
- LOAD_META_DATA - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken loading meta-data from aFDBMetaDataStore.
- LOAD_RECORD - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken loading records.
- LOAD_RECORD_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of record key-value pairs loaded.
- LOAD_RECORD_KEY_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of keys for record key-value pairs loaded.
- LOAD_RECORD_STORE_INDEX_META_DATA - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken loading a record store's index meta-data.
- LOAD_RECORD_STORE_INFO - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken loading a record store'sDataStoreInfoheader.
- LOAD_RECORD_STORE_STATE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken loading a record store'sRecordStoreStatelisting store-specific information.
- LOAD_RECORD_VALUE_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of values for record key-value pairs loaded.
- LOAD_RECORD_VERSION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
Deprecated.this is no longer published
- LOAD_SCAN_ENTRY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of entries (e.g., key-value pairs or text index entries) loaded by a scan.
- LOAD_STORE_STATE_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of index state key-value pairs loaded.
- LOAD_STORE_STATE_KEY_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of keys for index state key-value pairs loaded.
- LOAD_STORE_STATE_VALUE_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of values for index state key-value pairs loaded.
- LOAD_TEXT_ENTRY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of entries loaded when scanning a text index.
- loadAndSetCurrent(boolean, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Load current meta-data from store and set forgetRecordMetaData.
- loadBoundaryKeys(FDBTransactionContext, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- loadCurrentSerialized() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- loadDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- loadDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer.UpdateState
- loader - Variable in class com.apple.foundationdb.record.provider.common.MappedPool
- loadIndexBuildStateAsync(FDBRecordStoreBase<?>, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexBuildState
- 
Load the build progress (IndexBuildState) of the given index in the given record store asynchronously.
- loadIndexEntryRecord(IndexEntry, IndexOrphanBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Using the given index entry, resolve the primary key and asynchronously return the referenced record.
- loadIndexEntryRecord(IndexEntry, IndexOrphanBehavior, ExecuteState) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Using the given index entry, resolve the primary key and asynchronously return the referenced record.
- loadIndexEntryRecord(Index, IndexEntry, IndexOrphanBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Deprecated.
- loadIndexEntryRecord(Index, IndexEntry, IndexOrphanBehavior, ExecuteState) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Deprecated.
- loadRecord(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Load the record with the given primary key.
- loadRecord(Tuple, boolean) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Load the record with the given primary key.
- loadRecordAsync(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Asynchronously load a record.
- loadRecordAsync(Tuple, boolean) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Asynchronously load a record.
- loadRecordInternal(Tuple, ExecuteState, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- loadRecordInternal(Tuple, ExecuteState, boolean) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- loadRecordInternal(Tuple, ExecuteState, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- loadRecordsScannedAsync(FDBRecordStoreBase<?>, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexBuildState
- 
Load the number of records successfully scanned and processed during the online index build process asynchronously.
- loadRecordStoreStateAsync(FDBRecordStoreBase.StoreExistenceCheck) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Loads the current state of the record store within the given subspace asynchronously.
- loadRecordVersion(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Load the version of the last time a record with the given primary key was saved.
- loadRecordVersion(Tuple, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Overload ofFDBRecordStore.loadRecordVersion(Tuple)that supports snapshot reads.
- loadRecordVersionAsync(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Async version ofFDBRecordStore.loadRecordVersion(Tuple).
- loadRecordVersionAsync(Tuple, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Async version ofFDBRecordStore.loadRecordVersion(Tuple, boolean).
- loadSubDirectory(TimeWindowLeaderboardDirectory, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- loadSyntheticRecord(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Load asynthetic recordby loading its stored constituent records and synthesizing it from them.
- loadTypedRecord(RecordSerializer<M>, Tuple, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- loadTypedRecord(RecordSerializer<M>, Tuple, ExecuteState, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- loadVersion(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- loadWithSplit(ReadTransaction, FDBRecordContext, Subspace, Tuple, boolean, boolean, SplitHelper.SizeInfo) - Static method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper
- 
Load serialized byte array that may be split among several keys.
- LOCAL_VERSION - com.apple.foundationdb.record.logging.LogMessageKeys
- LocatableResolver - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
LocatableResolverrepresents the concept of a locatable bi-directional mapping between Strings and Longs that is rooted at some location in the FDB key space.
- LocatableResolver(FDBDatabase, KeySpacePath, CompletableFuture<ResolvedKeySpacePath>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Created a locatable resolver.
- LocatableResolver.LocatableResolverLockedException - Exception in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
Exception thrown when the locatable resolver is locked.
- location - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- LOG_KEY_SUFFIX_CACHE - Static variable in interface com.apple.foundationdb.record.provider.common.StoreTimer.Event
- LoggableTimeoutException - Exception in com.apple.foundationdb.record
- 
Subclass of TimeoutException with support for adding logging info in the form of keys and values.
- LoggableTimeoutException(Throwable, Object...) - Constructor for exception com.apple.foundationdb.record.LoggableTimeoutException
- 
Create an exception with the given sequence of key/value pairs.
- LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- LogicalDistinctExpression - Class in com.apple.foundationdb.record.query.plan.temp.expressions
- 
A relational planner expression representing a stream of unique records.
- LogicalDistinctExpression(ExpressionRef<RelationalExpression>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- LogicalDistinctExpression(Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- LogicalDistinctExpression(RelationalExpression) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- LogicalFilterExpression - Class in com.apple.foundationdb.record.query.plan.temp.expressions
- 
A relational planner expression that represents an unimplemented filter on the records produced by its inner relational planner expression.
- LogicalFilterExpression(Source, QueryPredicate, ExpressionRef<RelationalExpression>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- LogicalFilterExpression(Source, QueryPredicate, Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- LogicalOperatorNode(RelationalExpression, String, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNode
- LogicalOperatorNode(String) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNode
- LogicalOperatorNode(String, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNode
- LogicalOperatorNode(String, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNode
- LogicalOperatorNodeWithInfo(NodeInfo) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNodeWithInfo
- LogicalOperatorNodeWithInfo(NodeInfo, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNodeWithInfo
- LogicalOperatorNodeWithInfo(NodeInfo, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNodeWithInfo
- LogicalOperatorNodeWithInfo(RelationalExpression, NodeInfo, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.LogicalOperatorNodeWithInfo
- LogicalSortExpression - Class in com.apple.foundationdb.record.query.plan.temp.expressions
- 
A relational planner expression that represents an unimplemented sort on the records produced by its inner relational planner expression.
- LogicalSortExpression(List<Element>, List<Element>, boolean, Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- LogicalSortExpression(List<Element>, List<Element>, boolean, RelationalExpression) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- LogicalToPhysicalScanRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule that converts a logical index scan expression to aRecordQueryIndexPlan.
- LogicalToPhysicalScanRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.LogicalToPhysicalScanRule
- LogicalTypeFilterExpression - Class in com.apple.foundationdb.record.query.plan.temp.expressions
- 
A relational planner expression that represents an unimplemented type filter on the records produced by its inner relational planner expression.
- LogicalTypeFilterExpression(Set<String>, Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalTypeFilterExpression
- LogicalTypeFilterExpression(Set<String>, RelationalExpression) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalTypeFilterExpression
- LogicalUnorderedUnionExpression - Class in com.apple.foundationdb.record.query.plan.temp.expressions
- 
A relational planner expression that represents an unimplemented unordered union of its children.
- LogicalUnorderedUnionExpression(List<? extends Quantifier>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalUnorderedUnionExpression
- logKey() - Method in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Counts
- logKey() - Method in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Events
- logKey() - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Event
- 
Get the key of this event for logging.
- logKey() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.CountAggregates
- logKey() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- logKey() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- logKey() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- logKey() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- logKey() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.Events
- logKey() - Method in interface com.apple.foundationdb.record.provider.foundationdb.SubspaceProvider
- logKey() - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderByKeySpacePath
- logKey() - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderBySubspace
- logKeyWithSuffix(String) - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Event
- 
Return the log key with a specified suffix appended.
- LogMessageKeys - Enum in com.apple.foundationdb.record.logging
- 
CommonKeyValueLogMessagekeys logged by the Record Layer core.
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- logPlanStructure(StoreTimer) - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
- 
Adds one to an appropriateStoreTimercounter for each plan and subplan of this plan, allowing tracking of which plans are being chosen (e.g.
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- logTransaction() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Write the details of this transaction to the FoundationDB client logs.
- LONG - com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- LOW_BYTES - com.apple.foundationdb.record.logging.LogMessageKeys
M
- maintainIndex(Index, MessageOrBuilder) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter
- maintainIndexValue(Index, MessageOrBuilder, IndexEntry) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter
- 
Get whether a specific index entry should be maintained.
- makeImmutable() - Method in class com.apple.foundationdb.record.provider.common.StoreTimer.Counter
- 
For internal use during aggregate event computation; the counter can remain mutable until the computation is completed, then the counter is made immutable, ensuring that other code doesn't accidentally think it is updating a regular counter.
- makeMutable(List<T>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- MANUAL_RESULT_COUNT - com.apple.foundationdb.record.logging.TestLogMessageKeys
- map(Function<? super T, ? extends U>) - Method in class com.apple.foundationdb.record.RecordCursorResult
- 
Apply a function to the value inside this result, likeOptional.map(Function).
- map(Function<T, U>) - Method in interface com.apple.foundationdb.record.query.plan.temp.ExpressionRef
- map(Function<T, U>) - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- map(Function<T, U>) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- map(Function<T, V>) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor by applying the given function to the records in this cursor.
- MAP_KEY_FIELD - Static variable in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
The name of the key field in Protobufmapmessages.
- MAP_VALUE_FIELD - Static variable in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
The name of the value field in Protobufmapmessages.
- mapAsync(Function<? super T, ? extends CompletableFuture<? extends U>>) - Method in class com.apple.foundationdb.record.RecordCursorResult
- 
Apply an asynchronous function inside this result and return a future for the result containing the future's value.
- mapAsyncToSyncException(Throwable) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- MapCursor<T,V> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that applies a function to the elements of another cursor.
- MapCursor(RecordCursor<T>, Function<T, V>) - Constructor for class com.apple.foundationdb.record.cursors.MapCursor
- mapEffect(Runnable) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that runs the given runnable every time a record arrives, without modifying the cursor records.
- mapEffect(Consumer<T>) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that applies the given consumer to the records in this cursor, without modifying the cursor records.
- mapFuture(Executor, CompletableFuture<V>, byte[], BiFunction<V, byte[], ? extends RecordCursor<T>>) - Static method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor by applying the contents of the given future to the given function, with proper continuation handling.
- mapKeys(String) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Index key from amap.
- mapKeyValues(String) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Index key and value from amap.
- mapMatches(Function<Field, QueryComponent>, Function<Field, QueryComponent>) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Matchmapfield entries.
- MAPPED_POOL - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
- MappedPool<K,V,E extends Exception> - Class in com.apple.foundationdb.record.provider.common
- 
MappedPool Class Attempts to reuse objects organized by keys.
- MappedPool(MappedPool.MappedPoolProvider<K, V, E>) - Constructor for class com.apple.foundationdb.record.provider.common.MappedPool
- MappedPool(MappedPool.MappedPoolProvider<K, V, E>, int) - Constructor for class com.apple.foundationdb.record.provider.common.MappedPool
- MappedPool(MappedPool.MappedPoolProvider<K, V, E>, int, int) - Constructor for class com.apple.foundationdb.record.provider.common.MappedPool
- MappedPool.MappedPoolProvider<K,V,E extends Exception> - Interface in com.apple.foundationdb.record.provider.common
- 
Function with Exceptions to provide the pool.
- mapPipelined(Function<T, CompletableFuture<V>>, int) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor by applying the given asynchronous function to the records in this cursor.
- MapPipelinedCursor<T,V> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that applies an asynchronous function to the elements of another cursor.
- MapPipelinedCursor(RecordCursor<T>, Function<T, CompletableFuture<V>>, int) - Constructor for class com.apple.foundationdb.record.cursors.MapPipelinedCursor
- MapUtils - Class in com.apple.foundationdb.record.util
- 
Utility functions for manipulating maps.
- mapValueKeys(String) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Index value and key from amap.
- mapValues(String) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Index value from amap.
- MapWhileCursor<T,V> - Class in com.apple.foundationdb.record.cursors
- 
ARecordCursorthat calls a function that maps the value and can stop the cursor.
- MapWhileCursor(RecordCursor<T>, Function<T, Optional<V>>, MapWhileCursor.StopContinuation, byte[], RecordCursor.NoNextReason) - Constructor for class com.apple.foundationdb.record.cursors.MapWhileCursor
- MapWhileCursor.StopContinuation - Enum in com.apple.foundationdb.record.cursors
- 
What to return forMapWhileCursor.getContinuation()after stopping.
- markIndexDisabled(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Adds the index to the list of disabled indexes stored within the store.
- markIndexDisabled(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Adds the index of the given name to the list of disabled indexes stored within the store.
- markIndexReadable(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Marks an index as readable.
- markIndexReadable(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Marks the index with the given name as readable.
- markIndexWriteOnly(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Adds the given index to the list of write-only indexes stored within the store.
- markIndexWriteOnly(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Adds the index of the given name to the list of write-only indexes stored within the store.
- markReadable() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Mark the index as readable.
- markReadableIfBuilt() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Mark the index as readable if it is built.
- match(Collection<? extends Quantifier>, Collection<? extends Quantifier>, boolean, AliasMap, Quantifiers.MatchingPredicate) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifiers
- 
Method to match up the quantifiers this expression owns with the given set of other quantifiers using an equivalence map.
- match(Set<CorrelationIdentifier>, Function<CorrelationIdentifier, Set<CorrelationIdentifier>>, Set<CorrelationIdentifier>, Function<CorrelationIdentifier, Set<CorrelationIdentifier>>, boolean, AliasMap.MatchingIdPredicate) - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- 
Method to match up the given sets of correlation identifiers (using an already given equivalence map).
- Match(Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
- Match(List<Comparisons.Comparison>) - Constructor for class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
- matches(KeyExpression) - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher
- 
Deprecated.
- matches(QueryComponent) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
If the associated field is a submessage, this allows you to match against the fields within that submessage.
- matches(QueryComponent) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
If the associated field is a submessage, this allows you to match against the fields within that submessage.
- matches(List<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.AllChildrenMatcher
- matches(List<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.AnyChildMatcher
- matches(List<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.AnyChildrenMatcher
- matches(List<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.AnyChildWithRestMatcher
- matches(List<? extends Bindable>) - Method in interface com.apple.foundationdb.record.query.plan.temp.matchers.ExpressionChildrenMatcher
- 
Apply this matcher to the children provided by the given iterator and produce a stream of possible bindings.
- matches(List<? extends Bindable>) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.ListChildrenMatcher
- matchesAggregateFunction(IndexAggregateFunction) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- matchesCoveringKey(KeyExpression) - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher
- 
Attempt to match the expression to this matcher's root query and use every column in the key.
- matchesCoveringKey(KeyExpression, FilterSatisfiedMask) - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher
- 
Attempt to match the expression to this matcher's root query and use every column in the key.
- matchesSatisfyingQuery(KeyExpression) - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher
- 
Attempt to match the expression to this matcher's root query and satisfy every filter.
- matchesSatisfyingQuery(KeyExpression, FilterSatisfiedMask) - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher
- 
Attempt to match the expression to this matcher's root query and satisfy every filter.
- matchesSort(GroupingKeyExpression, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons
- matchSourcesWith(ViewExpressionComparisons, Element) - Method in interface com.apple.foundationdb.record.query.plan.temp.view.Element
- 
Determine whether this element is the same as the givenElementwhen unused sources are combined with each other.
- matchSourcesWith(ViewExpressionComparisons, Element) - Method in class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- matchSourcesWith(ViewExpressionComparisons, Element) - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- matchSourcesWith(ViewExpressionComparisons, Element) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeElement
- matchSourcesWith(ViewExpressionComparisons, Element) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ValueElement
- matchSourcesWith(ViewExpressionComparisons, Element) - Method in class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- matchWith(ComparisonRange, ElementPredicate) - Method in interface com.apple.foundationdb.record.query.plan.temp.view.Element
- 
Determine whether this element can be used to satisfy the givenElementPredicate, under the assumption that this element is already being used to satisfy the givenComparisonRange.
- matchWith(ComparisonRange, ElementPredicate) - Method in class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- matchWith(ComparisonRange, ElementPredicate) - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- matchWith(ComparisonRange, ElementPredicate) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeElement
- matchWith(ComparisonRange, ElementPredicate) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ValueElement
- matchWith(ComparisonRange, ElementPredicate) - Method in class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- matchWith(ExpressionRef<? extends RelationalExpression>) - Method in interface com.apple.foundationdb.record.query.plan.temp.matchers.ExpressionMatcher
- 
Attempt to match this matcher against the given expression reference.
- matchWith(ExpressionRef<? extends RelationalExpression>) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.ReferenceMatcher
- matchWith(ExpressionRef<? extends RelationalExpression>) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeMatcher
- matchWith(Quantifier) - Method in interface com.apple.foundationdb.record.query.plan.temp.matchers.ExpressionMatcher
- 
Attempt to match this matcher against the givenQuantifier.
- matchWith(Quantifier) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.ReferenceMatcher
- matchWith(Quantifier) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeMatcher
- matchWith(RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.temp.matchers.ExpressionMatcher
- 
Attempt to match this matcher against the givenExpressionMatcher.
- matchWith(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.ReferenceMatcher
- matchWith(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeMatcher
- matchWith(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeWithPredicateMatcher
- matchWith(ElementPredicate) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpressionComparisons
- matchWith(QueryPredicate) - Method in interface com.apple.foundationdb.record.query.plan.temp.matchers.ExpressionMatcher
- 
Attempt to match this matcher against the givenQueryPredicate.
- matchWith(QueryPredicate) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.ReferenceMatcher
- matchWith(QueryPredicate) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeMatcher
- matchWithSort(List<Element>) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpressionComparisons
- MAX - Static variable in class com.apple.foundationdb.record.FunctionNames
- MAX_ATTEMPTS - com.apple.foundationdb.record.logging.LogMessageKeys
- MAX_COMPRESSION_VERSION - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- MAX_ENTRY_SIZE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainer
- MAX_EVER - Static variable in class com.apple.foundationdb.record.FunctionNames
- MAX_EVER - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
Deprecated.useIndexTypes.MAX_EVER_LONGfor compatibility with existing data orIndexTypes.MAX_EVER_TUPLEfor more flexibility
- MAX_EVER_LONG - com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- MAX_EVER_LONG - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
An index remembering the smallest nonnegative integer ever stored.
- MAX_EVER_TUPLE - com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- MAX_EVER_TUPLE - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
An index remembering the greatest value(s) ever stored.
- MAX_EVER_VERSION - com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- MAX_EVER_VERSION - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
An index remembering the maximum ever value stored where one column is the record version.
- MAX_LIMIT - com.apple.foundationdb.record.logging.LogMessageKeys
- MAX_MILLIS_PER_TRANSACTION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
The maximum number of milliseconds we'll spend scanning the directory during a lookup within the context of a single transaction, when this limit is hit, a new one will be started before continuing.
- MAX_PARALLEL_INDEX_REBUILD - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- MAX_POSITIONS - com.apple.foundationdb.record.logging.LogMessageKeys
- MAX_RECORDS_FOR_REBUILD - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- MAX_ROWS_PER_TRANSACTION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
The default maximum number of directory entries that will be scanned during a lookup within the context of a single transaction, when this limit is hit, a new one will be started before continuing.
- MAX_SUPPORTED_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- MAX_TOKEN_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
- MAX_TR_ID_SIZE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
The maximum size for a transaction ID in bytes when serialized as UTF-8.
- MAX_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Maximum possible completeFDBRecordVersionvalue.
- maxRetries - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- maxWriteLimitBytes - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- merge(ScanComparisons) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- MergeCursor<T,U,S extends MergeCursorState<T>> - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
- 
An abstract class that corresponds to some kind of cursor merging multiple children together.
- MergeCursor(List<S>, FDBStoreTimer) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- MergeCursorContinuation<B extends Message.Builder,C extends RecordCursorContinuation> - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
- 
Common code for handling the continuations ofMergeCursors.
- MergeCursorContinuation(List<C>, Message) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorContinuation
- MergeCursorState<T> - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
- 
A holder for mutable state needed to track one of the children cursors of some merge operation.
- MergeCursorState(RecordCursor<T>, RecordCursorContinuation) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
- mergedComparisonKey(List<RecordQueryPlanner.ScoredPlan>, KeyExpression, boolean) - Static method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
- 
Get a key to be evaluated on record results to drive a merge.
- mergedWith(PlannerBindings) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.PlannerBindings
- 
Combine this set of bindings with the given set of bindings.
- mergeNoNextReason() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- mergeNoNextReasons() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Merge theRecordCursor.NoNextReasons for child cursors.
- mergeNoNextReasons() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ProbableIntersectionCursor
- mergeRecordTypeAndComponent(String, QueryComponent) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- mergeWith(FilterSatisfiedMask) - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Merge in another mask over the same filter.
- MESSAGE - com.apple.foundationdb.record.logging.LogMessageKeys
- MessageBuilderRecordSerializer - Class in com.apple.foundationdb.record.provider.common
- 
Serialize records using default Protobuf serialization using the supplied message builder for the union message type.
- MessageBuilderRecordSerializer(Supplier<Message.Builder>) - Constructor for class com.apple.foundationdb.record.provider.common.MessageBuilderRecordSerializer
- MessageBuilderRecordSerializerBase<M extends Message,U extends Message,B extends Message.Builder> - Class in com.apple.foundationdb.record.provider.common
- 
Base class for record serializers that use a supplied union message builder method reference to reconstruct records.
- MessageBuilderRecordSerializerBase(Supplier<B>) - Constructor for class com.apple.foundationdb.record.provider.common.MessageBuilderRecordSerializerBase
- MessageValue - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
A utility class for extracting data and meta-data from Protocol BufferMessages, as used in the Record Layer.
- META_DATA_VERSION - com.apple.foundationdb.record.logging.LogMessageKeys
- metaData - Variable in class com.apple.foundationdb.record.metadata.MetaDataValidator
- MetaDataCache - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
A caching hook forFDBMetaDataStore.
- MetaDataEvolutionValidator - Class in com.apple.foundationdb.record.metadata
- 
This class can be used to validate that the new meta-data for a record store is responsibly evolved from its existing meta-data.
- MetaDataEvolutionValidator.Builder - Class in com.apple.foundationdb.record.metadata
- 
A builder class for theMetaDataEvolutionValidator.
- MetaDataException - Exception in com.apple.foundationdb.record.metadata
- 
Exception thrown when there is a problem with something in theRecordMetaDataProto.MetaData.
- MetaDataException(String, Object...) - Constructor for exception com.apple.foundationdb.record.metadata.MetaDataException
- MetaDataException(String, Throwable) - Constructor for exception com.apple.foundationdb.record.metadata.MetaDataException
- MetaDataException(Throwable) - Constructor for exception com.apple.foundationdb.record.metadata.MetaDataException
- MetaDataPlanContext - Class in com.apple.foundationdb.record.query.plan.temp
- 
APlanContextwhere the underlying meta-data comes fromRecordMetaDataandRecordStoreStateobjects, as is generally the case when planning actual queries.
- MetaDataPlanContext(RecordMetaData, RecordStoreState, RecordQuery) - Constructor for class com.apple.foundationdb.record.query.plan.temp.MetaDataPlanContext
- MetaDataProtoDeserializationException(Throwable) - Constructor for exception com.apple.foundationdb.record.RecordMetaDataBuilder.MetaDataProtoDeserializationException
- MetaDataProtoEditor - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A helper class for mutating the meta-data proto.
- MetaDataProtoEditor() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
- MetaDataProtoEditor.AmbiguousTypeNameException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
An exception that is thrown if the type of a field is ambiguous.
- metaDataProvider - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- MetaDataValidator - Class in com.apple.foundationdb.record.metadata
- 
Validator forRecordMetaData.
- MetaDataValidator(RecordMetaDataProvider, IndexValidatorRegistry) - Constructor for class com.apple.foundationdb.record.metadata.MetaDataValidator
- MetaDataVersionStampStoreStateCache - Class in com.apple.foundationdb.record.provider.foundationdb.storestate
- 
An implementation of theFDBRecordStoreStateCachethat uses the database's meta-data version-stamp key as the cache invalidation key.
- MetaDataVersionStampStoreStateCacheFactory - Class in com.apple.foundationdb.record.provider.foundationdb.storestate
- 
A factory for creatingMetaDataVersionStampStoreStateCaches.
- MetaDataVersionStampStoreStateCacheFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCacheFactory
- mightHaveNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
- 
Return whether this cursor may return a result in the future.
- MIN - Static variable in class com.apple.foundationdb.record.FunctionNames
- MIN_COMPRESSION_VERSION - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- MIN_EVER - Static variable in class com.apple.foundationdb.record.FunctionNames
- MIN_EVER - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
Deprecated.useIndexTypes.MIN_EVER_LONGfor compatibility with existing data orIndexTypes.MIN_EVER_TUPLEfor more flexibility
- MIN_EVER_LONG - com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- MIN_EVER_LONG - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
An index remembering the smallest nonnegative integer ever stored.
- MIN_EVER_TUPLE - com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- MIN_EVER_TUPLE - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
An index remembering the least value(s) ever stored.
- MIN_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Minimum possible completeFDBRecordVersionvalue.
- MISSING - com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry.Reasons
- MissingMetaDataException(String) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore.MissingMetaDataException
- morphFrom(Quantifier.ForEach) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical.PhysicalBuilder
- 
Build a new physical quantifier from a for-each quantifier with the same alias.
- MultiColumnComparison(Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- multiTypeIndexes - Variable in class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
- MURMUR3 - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetHashFunctions
- mustResolve(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Lookup the mapping fornamewithin the scope of the path that this object was constructed with.
- mustResolveWithMetadata(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Lookup the mapping and metadata fornamewithin the scope of the path that this object was constructed with.
- MutableRecordStoreState - Class in com.apple.foundationdb.record
- 
A record store that can be modified to reflect changes made to the database.
- MutableRecordStoreState(RecordMetaDataProto.DataStoreInfo, Map<String, IndexState>) - Constructor for class com.apple.foundationdb.record.MutableRecordStoreState
- MutableRecordStoreState(Map<String, IndexState>) - Constructor for class com.apple.foundationdb.record.MutableRecordStoreState
- 
Deprecated.
- mutate(MutationType, byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- MUTATE_INDEX_ENTRY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent updating an entry in an atomic mutation index.
- mutateMetaData(Consumer<RecordMetaDataProto.MetaData.Builder>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Mutate the stored meta-data proto using a mutation callback.
- mutateMetaData(Consumer<RecordMetaDataProto.MetaData.Builder>, Consumer<RecordMetaDataBuilder>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Mutate the stored meta-data proto and record meta-data builder using mutation callbacks.
- mutateMetaDataAsync(Consumer<RecordMetaDataProto.MetaData.Builder>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Mutate the stored meta-data proto using a mutation callback asynchronously.
- mutateMetaDataAsync(Consumer<RecordMetaDataProto.MetaData.Builder>, Consumer<RecordMetaDataBuilder>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Mutate the stored meta-data proto and record meta-data builder using mutation callbacks asynchronously.
- mutation - Variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- MUTATIONS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
Total number of mutation operations.
N
- name - Variable in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- name - Variable in class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
- name - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- name() - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Event
- 
Get the name of this event for machine processing.
- name() - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry.Reason
- 
Get the name of the reason.
- NAME - Static variable in class com.apple.foundationdb.record.provider.common.text.DefaultTextTokenizer
- 
The name of the default tokenizer.
- narrow(Class<Q>) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- narrow(Class<Q>, List<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifiers
- narrow(Class<Q>, Set<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifiers
- needRebuildIndex(Index, long, boolean) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.UserVersionChecker
- 
Determine what to do about an index needing to be built.
- needsRebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- 
Helper to determine if anything that this quantifier ranges over is correlated to something that needs to be rebased.
- negateScoreForHighScoreFirst(Tuple, int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- 
Negate the score element so that it sorts in reverse order to support high score first.
- negateScoreRange(TupleRange) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- 
Negate the score part of the given range, which is after the group prefix and before the timestamp and any other tiebreakers.
- nest(KeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- 
Nest another expression inside this one.
- nest(KeyExpression, KeyExpression, KeyExpression...) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- 
Shorthand fornest(concat(first, second, rest)).
- nest(String) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- 
Nest a single scalar field inside of this one.
- nest(String, KeyExpression.FanType) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- 
Nest a single field inside of this one, optionally setting the handling for a repeated field.
- NESTED_LOOP_JOIN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- NestedField - Class in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentthat evaluates a nested component against aMessage-valued field.
- NestedField(String, QueryComponent) - Constructor for class com.apple.foundationdb.record.query.expressions.NestedField
- NestingKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
A key expression within a nested subrecord.
- NestingKeyExpression(FieldKeyExpression, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- NestingKeyExpression(RecordMetaDataProto.Nesting) - Constructor for class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- NEVER - com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.Rebuild
- NEW - com.apple.foundationdb.record.logging.LogMessageKeys
- NEW_FIELD_NAME - com.apple.foundationdb.record.logging.LogMessageKeys
- NEW_FIELD_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- NEW_FORMAT_VERSION - com.apple.foundationdb.record.logging.LogMessageKeys
- NEW_INDEX_NAME - com.apple.foundationdb.record.logging.LogMessageKeys
- NEW_INDEX_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- NEW_KEY_EXPRESSION - com.apple.foundationdb.record.logging.LogMessageKeys
- NEW_OPTION - com.apple.foundationdb.record.logging.LogMessageKeys
- NEW_RECORD_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- NEW_STORE - com.apple.foundationdb.record.logging.LogMessageKeys
- NEW_STORE - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
- NEW_VERSION - com.apple.foundationdb.record.logging.LogMessageKeys
- newBuilder() - Static method in class com.apple.foundationdb.record.Bindings
- newBuilder() - Static method in class com.apple.foundationdb.record.EvaluationContext
- 
Construct a new builder from this context.
- newBuilder() - Static method in class com.apple.foundationdb.record.ExecuteProperties
- newBuilder() - Static method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Create a new builder.
- newBuilder() - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Get a new builder for this class.
- newBuilder() - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- newBuilder() - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- 
Get a builder for a stored record.
- newBuilder() - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- 
Create a new typed record store builder.
- newBuilder() - Static method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config
- newBuilder() - Static method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Create an online indexer builder.
- newBuilder() - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.PlannerBindings
- 
Return a new builder.
- newBuilder() - Static method in class com.apple.foundationdb.record.query.RecordQuery
- newBuilder() - Static method in class com.apple.foundationdb.record.RecordMetaData
- 
Creates an instance ofRecordMetaDataBuilder.
- newBuilder(RecordType) - Static method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
- newBuilder(RecordSerializer<M>) - Static method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- 
Creates a newTransformedRecordSerializer.Builderinstance around the given serializer.
- newBuilder(RecordSerializer<M>) - Static method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
- 
Creates a newTransformedRecordSerializerJCE.Builderinstance around the given serializer.
- newBuilder(RecordSerializer<M>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- 
Create a new typed record store builder.
- newBuilder(Descriptors.FieldDescriptor, Supplier<B>, Predicate<U>, Function<U, M>, BiConsumer<B, M>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- 
Create a new typed record store builder.
- newBuilder(Descriptors.FileDescriptor, Descriptors.FieldDescriptor, Supplier<B>, Predicate<U>, Function<U, M>, BiConsumer<B, M>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- 
Create a new typed record store builder.
- newBuilder(M) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- 
Get a builder for a stored record.
- newChild(byte[], Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- newConstituent(String, RecordTypeBuilder) - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder
- newConstituent(String, RecordTypeBuilder) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- newContextExecutor(Map<String, String>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- newContextExecutor(Map<String, String>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Creates a newExecutorfor use by a specificFDBRecordContext.
- newDefaultBuilder() - Static method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- 
Creates a newTransformedRecordSerializer.Builderinstance that is backed by the default serializer forMessages, namely aDynamicMessageRecordSerializer.
- newDefaultBuilder() - Static method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
- 
Creates a newTransformedRecordSerializerJCE.Builderinstance that is backed by the default serializer forMessages, namely aDynamicMessageRecordSerializer.
- newInstance() - Static method in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCacheFactory
- 
Create a new factory.
- newInstance() - Static method in class com.apple.foundationdb.record.provider.foundationdb.storestate.ReadVersionRecordStoreStateCacheFactory
- 
Create a new factory.
- newMissing(IndexEntry, FDBStoredRecord<Message>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry
- newOrphan(IndexEntry) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry
- newPrefixChild(byte[], Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- newProtoBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorContinuation
- 
Get a new builder instance for the Protobuf message associated with this continuation.
- newRunner() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Create anFDBDatabaseRunnerfor use against this database.
- newRunner() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Get a newFDBDatabaseRunnerthat will run contexts similar to this one.
- newRunner(FDBRecordContextConfig.Builder) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Create anFDBDatabaseRunnerfor use against this database.
- newRunner(FDBStoreTimer, Map<String, String>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Create anFDBDatabaseRunnerfor use against this database.
- newRunner(FDBStoreTimer, Map<String, String>, FDBDatabase.WeakReadSemantics) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Create anFDBDatabaseRunnerfor use against this database.
- next() - Method in class com.apple.foundationdb.record.cursors.AutoContinuingCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.ChainedCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.ConcatCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.EmptyCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.FilterCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.FlatMapPipelinedCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.FutureCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.LazyCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.ListCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.MapCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.MapWhileCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.OrElseCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.RowLimitedCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.cursors.SkipCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- 
Deprecated.
- next() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Returns an incremented version of the currentFDBRecordVersion.
- next() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- 
Deprecated.
- next() - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Deprecated.in favor of theRecordCursor.onNext()method or advancing the cursorRecordCursor.asIterator()
- next() - Method in class com.apple.foundationdb.record.RecordCursorIterator
- 
Return the next value.
- NEXT_CONTINUATION - com.apple.foundationdb.record.logging.LogMessageKeys
- nextChildForKey(int, FDBRecordContext, ResolvedKeySpacePath, Tuple, int, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- nextLookup(RankedSet.Lookup, ReadTransaction) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.InstrumentedRankedSet
- nextLookupKey(long, boolean, boolean, int, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.InstrumentedRankedSet
- nextResult - Variable in class com.apple.foundationdb.record.cursors.RowLimitedCursor
- NO_FIELDS - Static variable in class com.apple.foundationdb.record.query.plan.AvailableFields
- NO_LIMITS - Static variable in class com.apple.foundationdb.record.ExecuteState
- 
An execute state with no scan limits.
- NO_MATCH - com.apple.foundationdb.record.query.QueryToKeyMatcher.MatchType
- NO_NEXT_REASON - com.apple.foundationdb.record.logging.LogMessageKeys
- NO_NULLS - Static variable in interface com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter
- 
Do not putnullvalues into the index.
- NO_SCANNED_RECORDS_LIMIT - Static variable in class com.apple.foundationdb.record.ExecuteState
- 
Deprecated.in favor of NO_LIMITS when the byte scan limit was added
- NO_VERSION - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.VersionstampSaveBehavior
- Node(Object, String) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Node
- Node(Object, String, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Node
- Node(Object, String, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.Node
- NodeIcon - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
NodeIcon Ids.
- NodeIcon(String) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.NodeIcon
- NodeInfo - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Explanatory information about the Record Layer's plan operators and storage objects.
- NodeInfo(String, NodeIcon, String, String) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- NodeWithInfo(Object, NodeInfo) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.NodeWithInfo
- NodeWithInfo(Object, NodeInfo, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.NodeWithInfo
- NodeWithInfo(Object, NodeInfo, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.NodeWithInfo
- NonbuildableException(String) - Constructor for exception com.apple.foundationdb.record.metadata.RecordTypeBuilder.NonbuildableException
- None - com.apple.foundationdb.record.metadata.expressions.KeyExpression.FanType
- 
Nothing, only allowed with scalar fields.
- NONE - com.apple.foundationdb.record.cursors.MapWhileCursor.StopContinuation
- 
Returnnull.
- NONE - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
- 
No special action.
- NONE - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.StoreExistenceCheck
- 
No special action.
- NONE - com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter.IndexValues
- NONE - com.apple.foundationdb.record.query.plan.ScanComparisons.ComparisonType
- NoOpIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
An index maintainer that doesn't do anything.
- NoOpIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- NoOpIndexMaintainerFactory - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
A factory forNoOpIndexMaintainerindexes.
- NoOpIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainerFactory
- NORMAL - Static variable in interface com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter
- 
All records should be added to the index.
- normalize(QueryComponent) - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
- 
Convert the given predicate to disjunctive normal form, if necessary.
- normalizeChildrenForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.AndOrComponent
- normalizeForPlanner(Source) - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
- 
Convert this query component into an equivalentQueryPredicateby pushing all information about nested and repeated fields toElements inside ofElementPredicates.
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Normalize this key expression into another key expression that pushes all nesting and fan-out toElementKeyExpressions at the leaves.
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.AndComponent
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.EmptyComparison
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.NestedField
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.OrComponent
- normalizeForPlanner(Source, List<String>) - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
- 
Convert this query component into an equivalentQueryPredicateby pushing all information about nested and repeated fields toElements inside ofElementPredicates.
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- normalizeForPlanner(Source, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- normalizeIfPossible(QueryComponent) - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
- 
Convert the given predicate to disjunctive normal form, if necessary.
- normalizeKeyForPositions() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- normalizeKeyForPositions() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Get key in normalized form for comparing field-by-field.
- normalizeKeyForPositions() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- normalizeKeyForPositions() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- normalizeKeyForPositions() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- normalizeKeyForPositions() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- normalizeKeyForPositions() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- NoSuchArgumentException(String) - Constructor for exception com.apple.foundationdb.record.metadata.expressions.KeyExpression.NoSuchArgumentException
- NoSuchDirectoryException - Exception in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
Exception thrown when aKeySpaceDirectorydoes not have the named directory component.
- NoSuchDirectoryException(KeySpaceDirectory, String) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.keyspace.NoSuchDirectoryException
- not(QueryComponent) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
Negate a component test.
- NOT_ALLOWED_FOR_QUERY_OPTIONS - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
Options to set to disableIndexOptions.ALLOWED_FOR_QUERY_OPTION.
- NOT_EQUALS - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- NOT_NULL - com.apple.foundationdb.record.metadata.Key.Evaluated.NullStandin
- NOT_NULL - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- NotComponent - Class in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentthat is satisfied when its child component is not satisfied.
- NotComponent(QueryComponent) - Constructor for class com.apple.foundationdb.record.query.expressions.NotComponent
- notEmpty() - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Returns true if the repeated field has occurrences.
- notEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Checks if the field has a value not equal to the given comparand.
- notEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field is not equal to the given comparand.
- notEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
- 
Checks if the key expression has a value not equal to the given comparand.
- notEquals(Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- 
Checks if the calculated value has a value not equal to the given comparand.
- notNull() - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Returns true if the field does not use the default value.
- notNull() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
- 
Returns true if the key expression does not evaluate tonull.
- NotPredicate - Class in com.apple.foundationdb.record.query.predicates
- 
AQueryPredicatethat is satisfied when its child component is not satisfied.
- NotPredicate(QueryPredicate) - Constructor for class com.apple.foundationdb.record.query.predicates.NotPredicate
- NULL - com.apple.foundationdb.record.metadata.Key.Evaluated.NullStandin
- NULL - com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- NULL - Static variable in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
A key containing just the null element.
- NULL_UNIQUE - com.apple.foundationdb.record.metadata.Key.Evaluated.NullStandin
- NullComparison(Comparisons.Type) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
O
- objectPlanHash(Object) - Static method in interface com.apple.foundationdb.record.PlanHashable
- objectsPlanHash(Object...) - Static method in interface com.apple.foundationdb.record.PlanHashable
- of(KeyExpression, KeyExpression, KeyExpression...) - Static method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- of(SyntheticRecordType<?>, Map<String, FDBStoredRecord<? extends Message>>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- of(QueryComponent) - Static method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Create a mask around aQueryComponent.
- of(IndexKeyValueToPartialRecord.TupleSource, int) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields.FieldData
- of(CorrelationIdentifier, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- of(BiMap<CorrelationIdentifier, CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- of(Class<? extends U>) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeMatcher
- of(Class<? extends U>, ExpressionChildrenMatcher) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeMatcher
- of(Class<? extends U>, ExpressionMatcher<? extends Bindable>...) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeMatcher
- of(String) - Static method in class com.apple.foundationdb.record.query.plan.temp.CorrelationIdentifier
- 
Create a new correlation identifier using the given string.
- of(String, Object...) - Static method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- of(List<ExpressionMatcher<? extends Bindable>>) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.ListChildrenMatcher
- 
Get a matcher that tries to match the planner expression children, in order, to the given list ofExpressionMatchers.
- of(T) - Static method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- of(T...) - Static method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- offer(K, V) - Method in class com.apple.foundationdb.record.provider.common.MappedPool
- 
Offer a key with a value knowing that the queue is bounded and might not accept the offer.
- offset - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.TransformState
- ofIndex(FDBRecordStore, Index, FDBRecordContext, ScanProperties, byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- 
Create a statistics collector cursor of all keys used by index within a givenFDBRecordStore.
- ofIndex(FDBRecordStore, String, FDBRecordContext, ScanProperties, byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- 
Create a statistics collector cursor of all keys used by index within a givenFDBRecordStore.
- ofKind(Class<? extends Q>, ExpressionMatcher<? extends Bindable>) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.QuantifierMatcher
- 
Matches a subclass ofQuantifiertogether with the given matcher for itsrangesOver().
- ofPredicate(Class<? extends U>, ExpressionMatcher<? extends QueryPredicate>) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeWithPredicateMatcher
- ofPredicate(Class<? extends U>, ExpressionMatcher<? extends QueryPredicate>, ExpressionChildrenMatcher) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeWithPredicateMatcher
- ofPredicate(Class<? extends U>, ExpressionMatcher<? extends QueryPredicate>, ExpressionMatcher<? extends Bindable>...) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.TypeWithPredicateMatcher
- ofRecords(FDBRecordStore, FDBRecordContext, ScanProperties, byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- 
Create a statistics collector cursor of all records stored within a givenFDBRecordStore.
- ofStore(FDBRecordStore, FDBRecordContext, ScanProperties, byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- 
Create a statistics collector cursor of all keys used by a givenFDBRecordStore.
- ofSubspace(Subspace, FDBRecordContext, ScanProperties, byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- 
Create a statistics collector cursor of all keys used by index within a givenSubspace.
- OLD - com.apple.foundationdb.record.logging.LogMessageKeys
- OLD_FIELD_NAME - com.apple.foundationdb.record.logging.LogMessageKeys
- OLD_FIELD_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- OLD_FORMAT_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- OLD_INDEX_NAME - com.apple.foundationdb.record.logging.LogMessageKeys
- OLD_INDEX_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- OLD_KEY_EXPRESSION - com.apple.foundationdb.record.logging.LogMessageKeys
- OLD_OPTION - com.apple.foundationdb.record.logging.LogMessageKeys
- OLD_RECORD_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- OLD_VERSION - com.apple.foundationdb.record.logging.LogMessageKeys
- oldestLeaderboardMatching(int, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- oldestLeaderboardMatching(int, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- oneOfThem() - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
If the associated field is a repeated one, this allows you to match against one of the repeated values.
- oneOfThem(Field.OneOfThemEmptyMode) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
If the associated field is a repeated one, this allows you to match against one of the repeated values.
- OneOfThem - Class in com.apple.foundationdb.record.query.expressions
- 
Class for matching any value of a repeated field.
- OneOfThem(String) - Constructor for class com.apple.foundationdb.record.query.expressions.OneOfThem
- OneOfThem(String, Field.OneOfThemEmptyMode) - Constructor for class com.apple.foundationdb.record.query.expressions.OneOfThem
- OneOfThemWithComparison - Class in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentthat evaluates aComparisons.Comparisonagainst each of the values of a repeated field and is satisfied if any of those are.
- OneOfThemWithComparison(String, Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
- OneOfThemWithComparison(String, Field.OneOfThemEmptyMode, Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
- OneOfThemWithComponent - Class in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentthat evaluates a nested component against each of the values of a repeated field and is satisfied if any of those are.
- OneOfThemWithComponent(String, Field.OneOfThemEmptyMode, QueryComponent) - Constructor for class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
- OneOfThemWithComponent(String, QueryComponent) - Constructor for class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
- onError(Throwable) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.AutoContinuingCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.ChainedCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.ConcatCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.EmptyCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.FilterCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.FlatMapPipelinedCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.FutureCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.LazyCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.ListCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.MapCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.MapWhileCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.OrElseCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.RowLimitedCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.cursors.SkipCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- 
Deprecated.
- onHasNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- 
Deprecated.
- onHasNext() - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Deprecated.in favor of theRecordCursor.onNext()method or advancing the cursorRecordCursor.asIterator()
- onHasNext() - Method in class com.apple.foundationdb.record.RecordCursorIterator
- 
Asynchronously check whether there are more records available from the cursor.
- ONLINE_INDEX_BUILDER_RANGES_BY_COUNT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number ofOnlineIndexerrange scans terminated after hitting the scan limit.
- ONLINE_INDEX_BUILDER_RANGES_BY_SIZE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number ofOnlineIndexerrange scans terminated after hitting the size limit.
- ONLINE_INDEX_BUILDER_RECORDS_INDEXED - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of records indexed byOnlineIndexer.
- ONLINE_INDEX_BUILDER_RECORDS_SCANNED - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of records scanned byOnlineIndexer.
- OnlineIndexer - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Builds an index online, i.e., concurrently with other database operations.
- OnlineIndexer.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Builder forOnlineIndexer.
- OnlineIndexer.Config - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A holder for the mutable configuration parameters needed to rebuild an online index.
- OnlineIndexer.Config.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A builder forOnlineIndexer.Config.
- OnlineIndexer.IndexStatePrecondition - Enum in com.apple.foundationdb.record.provider.foundationdb
- 
This defines in which situations the index should be built.
- OnlineIndexer.RecordBuiltRangeException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
ThisExceptioncan be thrown in the case that one calls one of the methods that explicitly state that they are building an unbuilt range, i.e., a range of keys that contains no keys which have yet been processed by theOnlineIndexerduring an index build.
- ONLY_MANUAL_COUNT - com.apple.foundationdb.record.logging.TestLogMessageKeys
- ONLY_QUERY_COUNT - com.apple.foundationdb.record.logging.TestLogMessageKeys
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.PlannerRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.CombineFilterRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.FilterWithElementWithComparisonRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.FindPossibleIndexForAndPredicateRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.FlattenNestedAndPredicateRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.FullUnorderedExpressionToScanPlanRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.ImplementDistinctRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.ImplementFilterRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.ImplementTypeFilterRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.ImplementUnorderedUnionRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.LogicalToPhysicalScanRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.OrToUnorderedUnionRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.PushConjunctElementWithComparisonIntoExistingScanRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.PushDistinctFilterBelowFilterRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.PushElementWithComparisonIntoExistingScanRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.PushSortIntoExistingIndexRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.PushTypeFilterBelowFilterRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.RemoveRedundantTypeFilterRule
- onMatch(PlannerRuleCall) - Method in class com.apple.foundationdb.record.query.plan.temp.rules.SortToIndexRule
- onNext() - Method in class com.apple.foundationdb.record.cursors.AsyncIteratorCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.AutoContinuingCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.ChainedCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.ConcatCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.EmptyCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.FilterCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.FlatMapPipelinedCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.FutureCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.IteratorCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.LazyCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.ListCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.MapCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.MapWhileCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.OrElseCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.RowLimitedCursor
- onNext() - Method in class com.apple.foundationdb.record.cursors.SkipCursor
- onNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- onNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
- onNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor
- onNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
- onNext() - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Asynchronously return the next result from this cursor.
- open() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Synchronous version ofFDBRecordStoreBase.BaseBuilder.openAsync().
- OPEN_CONTEXT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of times a record context is opened.
- openAsync() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Opens an existingFDBRecordStoreinstance in the given path with the given meta-data.
- openContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Open a new record context with a new transaction begun on the underlying FDB database.
- openContext() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Open a new record context.
- openContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- openContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- openContext(FDBRecordContextConfig) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Open a new record context with a new transaction begun on the underlying FDB database.
- openContext(Map<String, String>, FDBStoreTimer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Open a new record context with a new transaction begun on the underlying FDB database.
- openContext(Map<String, String>, FDBStoreTimer, FDBDatabase.WeakReadSemantics) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Open a new record context with a new transaction begun on the underlying FDB database.
- openContext(Map<String, String>, FDBStoreTimer, FDBDatabase.WeakReadSemantics, FDBTransactionPriority) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Open a new record context with a new transaction begun on the underlying FDB database.
- openContext(Map<String, String>, FDBStoreTimer, FDBDatabase.WeakReadSemantics, FDBTransactionPriority, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Open a new record context with a new transaction begun on the underlying FDB database.
- openFDB() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- OperatorNodeWithInfo(RecordQueryPlan, NodeInfo) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.OperatorNodeWithInfo
- OperatorNodeWithInfo(RecordQueryPlan, NodeInfo, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.OperatorNodeWithInfo
- OperatorNodeWithInfo(RecordQueryPlan, NodeInfo, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph.OperatorNodeWithInfo
- or(QueryComponent, QueryComponent, QueryComponent...) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
Check that any of a set of components evaluate to true for a given record.
- or(List<QueryComponent>) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
Check that a set of components all evaluate to true for a given record.
- OrComponent - Class in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentthat is satisfied when any of its child components is satisfied.
- OrComponent(List<QueryComponent>) - Constructor for class com.apple.foundationdb.record.query.expressions.OrComponent
- orElse(Function<byte[], ? extends RecordCursor<T>>, BiFunction<Executor, byte[], ? extends RecordCursor<T>>, byte[]) - Static method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that substitutes another cursor if a given inner cursor is empty.
- orElse(Function<Executor, RecordCursor<T>>) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Deprecated.because it does not support continuations and is easy to misuse. UseRecordCursor.flatMapPipelined(Function, BiFunction, byte[], int)instead.
- OrElseCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that returns the elements of one cursor followed by the elements of another cursor if the first was empty.
- OrElseCursor(RecordCursor<T>, Function<Executor, RecordCursor<T>>) - Constructor for class com.apple.foundationdb.record.cursors.OrElseCursor
- 
Deprecated.in favor of the a constructor that does support continuations
- OrElseCursor(Function<byte[], ? extends RecordCursor<T>>, BiFunction<Executor, byte[], ? extends RecordCursor<T>>, byte[]) - Constructor for class com.apple.foundationdb.record.cursors.OrElseCursor
- orElseGet(K, Supplier<CompletableFuture<V>>) - Method in class com.apple.foundationdb.record.AsyncLoadingCache
- 
If the cache does not contain an entry forkey, retrieve the value using the provided asynchronousSupplier.
- ORIGINAL_RANGE - com.apple.foundationdb.record.logging.LogMessageKeys
- ORPHAN - com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry.Reasons
- OrPredicate - Class in com.apple.foundationdb.record.query.predicates
- 
AQueryPredicatethat is satisfied when any of its child components is satisfied.
- OrPredicate(List<QueryPredicate>) - Constructor for class com.apple.foundationdb.record.query.predicates.OrPredicate
- OrToUnorderedUnionRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
Convert a filter on an or expression into a plan on the union.
- OrToUnorderedUnionRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.OrToUnorderedUnionRule
- OTHER_FILTER - com.apple.foundationdb.record.logging.LogMessageKeys
- OVERLAP - com.apple.foundationdb.record.logging.TestLogMessageKeys
P
- parameter - Variable in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- ParameterComparison(Comparisons.Type, String) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- ParameterComparison(Comparisons.Type, String, Bindings.Internal) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- parent - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- PARENT_DIR - com.apple.foundationdb.record.logging.LogMessageKeys
- PARENT_FILTER - com.apple.foundationdb.record.logging.LogMessageKeys
- parseMetaDataProto(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- PassThroughRecordStoreStateCache - Class in com.apple.foundationdb.record.provider.foundationdb.storestate
- 
An implementation of theFDBRecordStoreStateCacheinterface that does not actually cache anything.
- PassThroughRecordStoreStateCacheFactory - Class in com.apple.foundationdb.record.provider.foundationdb.storestate
- 
A factory for creatingPassThroughRecordStoreStateCaches.
- path(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Begin a path traversal from a root directory.
- path(String, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Begin a path traversal from a root directory.
- pathFromKey(FDBRecordContext, ResolvedKeySpacePath, Tuple, int, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
- pathFromKey(FDBRecordContext, ResolvedKeySpacePath, Tuple, int, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Given a position in a tuple, checks to see if this directory is compatible with the value at the position, returning either a path indicating that it was compatible or nothing if it was not compatible.
- pathFromKey(FDBRecordContext, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Deprecated.useKeySpace.resolveFromKey(FDBRecordContext, Tuple)instead
- pathFromKeyAsync(FDBRecordContext, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Deprecated.
- PathValue - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
A class to represent the value stored at a particular element of aKeySpacePath.
- PERFORM_NO_OP - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken performing a no-op.
- performIndexOperation(String, IndexOperation) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- performIndexOperationAsync(String, IndexOperation) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- performNoOp() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Perform a no-op against FDB to check network thread liveness.
- performNoOp(FDBStoreTimer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Perform a no-op against FDB to check network thread liveness.
- performNoOp(Map<String, String>, FDBStoreTimer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Perform a no-op against FDB to check network thread liveness.
- performNoOpAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Perform a no-op against FDB to check network thread liveness.
- performNoOpAsync(FDBStoreTimer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Perform a no-op against FDB to check network thread liveness.
- performNoOpAsync(Map<String, String>, FDBStoreTimer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Perform a no-op against FDB to check network thread liveness.
- performOperation(IndexOperation) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- performOperation(IndexOperation) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- performOperation(IndexOperation) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Perform a type-specific operation on index.
- performOperation(IndexOperation) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- physical(ExpressionRef<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- physical(ExpressionRef<? extends RecordQueryPlan>, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- physical(ExpressionMatcher<? extends Bindable>) - Static method in class com.apple.foundationdb.record.query.plan.temp.matchers.QuantifierMatcher
- 
Matches aQuantifier.Physicalquantifier together with the given matcher for itsrangesOver().
- physicalBuilder() - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- 
Create a builder for a physical quantifier containing record query plans.
- PhysicalBuilder() - Constructor for class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical.PhysicalBuilder
- PipelineOperation - Class in com.apple.foundationdb.record
- 
Kind of asynchronous pipelined operation being performed.
- PipelineOperation(String) - Constructor for class com.apple.foundationdb.record.PipelineOperation
- pipelineSizer - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- plan(RecordQuery) - Method in interface com.apple.foundationdb.record.query.plan.QueryPlanner
- 
Create a plan to get the results of the provided query.
- plan(RecordQuery) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- 
Create a plan to get the results of the provided query.
- plan(RecordQuery) - Method in class com.apple.foundationdb.record.query.plan.temp.CascadesPlanner
- PLAN - com.apple.foundationdb.record.logging.LogMessageKeys
- PLAN_COMPOSED_BITMAP_INDEX - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include aComposedBitmapIndexQueryPlan.
- PLAN_COVERING_INDEX - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that use a covering index.
- PLAN_DISTINCT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include aRecordQueryUnorderedDistinctPlan.
- PLAN_FETCH - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include aRecordQueryFetchFromPartialRecordPlan.
- PLAN_FILTER - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include aRecordQueryFilterPlan.
- PLAN_HASH - com.apple.foundationdb.record.logging.TestLogMessageKeys
- PLAN_IN_PARAMETER - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include anINwith parameters.
- PLAN_IN_VALUES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include anINwith literal values.
- PLAN_INDEX - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include an index.
- PLAN_INTERSECTION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include anRecordQueryIntersectionPlan.
- PLAN_LOAD_BY_KEYS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include a loading records directly by their primary keys.
- PLAN_PK_DISTINCT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include aRecordQueryUnorderedPrimaryKeyDistinctPlan.
- PLAN_QUERY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent planning a query.
- PLAN_SCAN - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include a record scan without an index.
- PLAN_SCORE_FOR_RANK - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include translating a rank range into a score range.
- PLAN_TYPE_FILTER - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include aRecordQueryTypeFilterPlan.
- PLAN_UNION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include aRecordQueryUnionPlan.
- PLAN_UNORDERED_UNION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of query plans that include aRecordQueryUnorderedUnionPlan.
- planComparisonSubsitutes(List<QueryComponent>) - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons
- planComparisonSubstitute(QueryComponent) - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons
- PlanContext - Interface in com.apple.foundationdb.record.query.plan.temp
- 
A basic context object that stores all of the metadata about a record store, such as the available indexes.
- planCoveringAggregateIndex(RecordQuery, Index, KeyExpression) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- planCoveringAggregateIndex(RecordQuery, String) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- planHash() - Method in class com.apple.foundationdb.record.IndexScanType
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- planHash() - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- planHash() - Method in interface com.apple.foundationdb.record.PlanHashable
- 
Return a hash similar tohashCode, but with the additional guarantee that is is stable across JVMs.
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.AndComponent
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.BaseField
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextWithMaxDistanceComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.EmptyComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.NestedField
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.OrComponent
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- planHash() - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- planHash() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.ScoreForRank
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- planHash() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- planHash() - Method in class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- planHash() - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- planHash() - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeElement
- planHash() - Method in class com.apple.foundationdb.record.query.plan.temp.view.ValueElement
- planHash() - Method in class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- planHash() - Method in class com.apple.foundationdb.record.query.plan.TextScan
- planHash() - Method in class com.apple.foundationdb.record.query.predicates.AndPredicate
- planHash() - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- planHash() - Method in class com.apple.foundationdb.record.query.predicates.NotPredicate
- planHash() - Method in class com.apple.foundationdb.record.query.predicates.OrPredicate
- planHash() - Method in class com.apple.foundationdb.record.RecordFunction
- planHash(PlanHashable...) - Static method in interface com.apple.foundationdb.record.PlanHashable
- planHash(Iterable<? extends PlanHashable>) - Static method in interface com.apple.foundationdb.record.PlanHashable
- PlanHashable - Interface in com.apple.foundationdb.record
- 
A more stable version ofObject.hashCode().
- planHashUnordered(Iterable<? extends PlanHashable>) - Static method in interface com.apple.foundationdb.record.PlanHashable
- PlannableIndexTypes - Class in com.apple.foundationdb.record.query.plan
- 
A wrapper class to identify groups of that behave the same way from the perspective of the planner.
- PlannableIndexTypes(Set<String>, Set<String>, Set<String>) - Constructor for class com.apple.foundationdb.record.query.plan.PlannableIndexTypes
- PlannerBindings - Class in com.apple.foundationdb.record.query.plan.temp.matchers
- 
A map-like structure that supports a map from a binding to a collection ofBindables, such asRelationalExpressions andExpressionRefs.
- PlannerBindings.Builder - Class in com.apple.foundationdb.record.query.plan.temp.matchers
- 
A mutable builder for a set ofPlannerBindingswhich can be used to incrementally build up a set of bindings without repeatedly callingPlannerBindings.mergedWith(PlannerBindings), which is less efficient.
- PlannerGraph - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Lightweight class to save some boilerplate.
- PlannerGraph(PlannerGraph.Node, Network<PlannerGraph.Node, PlannerGraph.Edge>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraph
- PlannerGraph.DataNodeWithInfo - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Node class for data objects.
- PlannerGraph.Edge - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Edge class.
- PlannerGraph.ExpressionRefHeadNode - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Node class for GroupExpressionRefs -- head.
- PlannerGraph.ExpressionRefMemberNode - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Node class for GroupExpressionRefs - member.
- PlannerGraph.GroupExpressionRefEdge - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Edge class for GroupExpressionRefs.
- PlannerGraph.GroupExpressionRefInternalEdge - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Edge class for GroupExpressionRefs.
- PlannerGraph.InternalPlannerGraphBuilder - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Specific builder for explain planner graph building.
- PlannerGraph.LogicalOperatorNode - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Node class for logical operators.
- PlannerGraph.LogicalOperatorNodeWithInfo - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Node class for logical operators that also have aNodeInfo.
- PlannerGraph.Node - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Node class functioning as parent for any nodes in the network.
- PlannerGraph.NodeWithInfo - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Node class that additionally captures a reference to aNodeInfo.
- PlannerGraph.OperatorNodeWithInfo - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Node class for actual plan operators.
- PlannerGraph.WithInfoId - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Interface to be implemented by all node classes that need to externalize an info id for exporting global information such as names and descriptions.
- PlannerGraphBuilder(N) - Constructor for class com.apple.foundationdb.record.query.plan.temp.explain.AbstractPlannerGraph.PlannerGraphBuilder
- PlannerGraphProperty - Class in com.apple.foundationdb.record.query.plan.temp.explain
- 
Class to hold a graph for explain, optimization, and rewrite purposes.
- PlannerGraphRewritable - Interface in com.apple.foundationdb.record.query.plan.temp.explain
- 
Interface to allowRelationalExpressions to rewrite their own graph representation.
- PlannerProperty<T> - Interface in com.apple.foundationdb.record.query.plan.temp
- 
An interface for certain Cascades-style properties, which are measurable features of an expression other than the structure of the expression tree.
- PlannerRule<T extends Bindable> - Class in com.apple.foundationdb.record.query.plan.temp
- 
Classes that inherit fromPlannerRuleform the base of the Cascades planning system.
- PlannerRule(ExpressionMatcher<T>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.PlannerRule
- PlannerRuleCall - Interface in com.apple.foundationdb.record.query.plan.temp
- 
APlannerRuleCallis a context object that supports a single application of a rule to a particular expression.
- PlannerRuleSet - Class in com.apple.foundationdb.record.query.plan.temp
- 
A set of rules for use by a planner that supports quickly finding rules that could match a given planner expression.
- PlanOrderingKey - Class in com.apple.foundationdb.record.query.plan
- 
The keys that order the results from a plan.
- PlanOrderingKey(List<KeyExpression>, int, int, int) - Constructor for class com.apple.foundationdb.record.query.plan.PlanOrderingKey
- planQuery(RecordQuery) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- planQuery(RecordQuery) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Plan a query.
- planQuery(RecordQuery) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- poll(K) - Method in class com.apple.foundationdb.record.provider.common.MappedPool
- pool - Variable in class com.apple.foundationdb.record.provider.common.MappedPool
- possibleEvents() - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer
- postVisit(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.visitor.FilterVisitor
- postVisit(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.visitor.IntersectionVisitor
- postVisit(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.visitor.RecordQueryPlannerSubstitutionVisitor
- postVisit(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.visitor.UnionVisitor
- postVisit(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.visitor.UnorderedPrimaryKeyDistinctVisitor
- PREDICATE_FILTER_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- PREFER_INDEX - com.apple.foundationdb.record.query.plan.QueryPlanner.IndexScanPreference
- 
Prefer index scan over full scan.
- PREFER_PRIMARY_KEY_INDEX - com.apple.foundationdb.record.query.plan.QueryPlanner.IndexScanPreference
- 
Prefer a scan using an index for exactly the primary key.
- PREFER_SCAN - com.apple.foundationdb.record.query.plan.QueryPlanner.IndexScanPreference
- 
Prefer a full scan over an index scan.
- PREFIX - Static variable in enum com.apple.foundationdb.record.Bindings.Internal
- PREFIX_STRING - com.apple.foundationdb.record.EndpointType
- prefixedBy(String) - Static method in class com.apple.foundationdb.record.TupleRange
- 
Create aTupleRangeover all keys prefixed by someString.
- preloadMetaData(RecordMetaDataProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Prepare a meta-data store for use by loading any existingRecordMetaDataor storing an initial seed from the given provider.
- preloadRecordAsync(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- preloadRecordAsync(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get record into FDB RYW cache.
- preloadRecordAsync(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- preloadRecordStoreStateAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Loads the current state of the record store asynchronously and caches it in memory so thatFDBRecordStore.getRecordStoreState()requires no i/o.
- preloadRecordStoreStateAsync(FDBRecordStoreBase.StoreExistenceCheck, IsolationLevel, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Loads the current state of the record store asynchronously and setsrecordStoreStateRef.
- preloadSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Ensure that subspace provider has cachedSubspaceso that callingFDBStoreBase.getSubspace()will not block.
- prepend(Tuple) - Method in class com.apple.foundationdb.record.TupleRange
- 
Create aTupleRangeover the same keys as this range but prepended by the suppliedTuple.
- prependLeaderboardKeys(EvaluationContext, TupleRange) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- prependLeaderboardKeys(ScanComparisons) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- prev() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Returns a decremented version of the currentFDBRecordVersion.
- PRIMARY - Static variable in class com.apple.foundationdb.record.provider.common.text.TextCollator.Strength
- 
Respect primary differences, which normally means base form.
- PRIMARY_KEY - com.apple.foundationdb.record.logging.LogMessageKeys
- primaryKeyHasRecordTypePrefix() - Method in class com.apple.foundationdb.record.metadata.RecordType
- 
Determine whether this record type has aRecordTypeKeyExpressionprefix in the primary key.
- primaryKeyHasRecordTypePrefix() - Method in class com.apple.foundationdb.record.RecordMetaData
- 
Determine whether every record type in this meta-data hasRecordType.primaryKeyHasRecordTypePrefix().
- ProbableIntersectionCursor<T> - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
- 
A cursor that returns all results that are probably in all of its children.
- PROVIDED_KEY - com.apple.foundationdb.record.logging.LogMessageKeys
- PROVIDED_VALUE - com.apple.foundationdb.record.logging.LogMessageKeys
- PushConjunctElementWithComparisonIntoExistingScanRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule that selects one of theComponentWithComparisonconjuncts from an AND and tries to push it into an existing logical scan.
- PushConjunctElementWithComparisonIntoExistingScanRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.PushConjunctElementWithComparisonIntoExistingScanRule
- PushDistinctFilterBelowFilterRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule that moves aRecordQueryUnorderedPrimaryKeyDistinctPlanbelow aRecordQueryFilterPlan.
- PushDistinctFilterBelowFilterRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.PushDistinctFilterBelowFilterRule
- PushElementWithComparisonIntoExistingScanRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A simple rule that looks for aComponentWithComparisonpredicate and a compatibly ordered index scan comparison down to the index scan.
- PushElementWithComparisonIntoExistingScanRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.PushElementWithComparisonIntoExistingScanRule
- PushSortIntoExistingIndexRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule that pushes a sort into a compatibly-ordered index scan, including one with existing comparisons (from filters or other sort orders) that might affect whether the index is compatibly ordered.
- PushSortIntoExistingIndexRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.PushSortIntoExistingIndexRule
- PushTypeFilterBelowFilterRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule that moves aRecordQueryTypeFilterPlanbelow aRecordQueryFilterPlan.
- PushTypeFilterBelowFilterRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.PushTypeFilterBelowFilterRule
- put(FDBRecordContext, ScopedValue<String>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
Explicitly add a new entry to the reverse directory cache.
- put(CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap.Builder
- put(ExpressionMatcher<? extends Bindable>, Bindable) - Method in class com.apple.foundationdb.record.query.plan.temp.matchers.PlannerBindings.Builder
- putAll(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap.Builder
- putIfNotExists(FDBRecordContext, ScopedValue<String>, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
Add a new entry to the reverse directory cache if it does not already exist.
Q
- Quantifier - Class in com.apple.foundationdb.record.query.plan.temp
- 
Models the concept of quantification.
- Quantifier(CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.query.plan.temp.Quantifier
- Quantifier.Builder<Q extends Quantifier,B extends Quantifier.Builder<Q,B>> - Class in com.apple.foundationdb.record.query.plan.temp
- 
Builder class for quantifiers.
- Quantifier.Existential - Class in com.apple.foundationdb.record.query.plan.temp
- 
A quantifier that conceptually flows exactly one item containing a boolean to the owning expression indicating whether the sub-graph that the quantifier ranges over produced a non-empty or an empty result.
- Quantifier.Existential.ExistentialBuilder - Class in com.apple.foundationdb.record.query.plan.temp
- 
Builder subclass for existential quantifiers.
- Quantifier.ForEach - Class in com.apple.foundationdb.record.query.plan.temp
- 
A quantifier that conceptually flows one item at a time from the expression it ranges over to the owning expression.
- Quantifier.ForEach.ForEachBuilder - Class in com.apple.foundationdb.record.query.plan.temp
- 
Builder subclass to build for-each quantifiers..
- Quantifier.Physical - Class in com.apple.foundationdb.record.query.plan.temp
- 
Physical quantifier.
- Quantifier.Physical.PhysicalBuilder - Class in com.apple.foundationdb.record.query.plan.temp
- 
Builder subclass for physical quantifiers.
- QuantifierMatcher<T extends Quantifier> - Class in com.apple.foundationdb.record.query.plan.temp.matchers
- 
Matches a subclass ofQuantifierand a given matcher against the children.
- Quantifiers - Class in com.apple.foundationdb.record.query.plan.temp
- 
Auxiliary class containing factory methods and helpers forQuantifier.
- Quantifiers.MatchingPredicate - Interface in com.apple.foundationdb.record.query.plan.temp
- 
An predicate that tests for a match between quantifiers also taking into account an equivalence maps betweenCorrelationIdentifiers.
- queriedRecord(FDBIndexedRecord<M>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get a query result record from an indexed record.
- queriedRecord(FDBStoredRecord<M>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Get a query result record from a stored record.
- Query - Class in com.apple.foundationdb.record.query.expressions
- 
Holder class for creating querying expressions.
- QUERY - com.apple.foundationdb.record.logging.TestLogMessageKeys
- QUERY - com.apple.foundationdb.record.provider.common.text.TextTokenizer.TokenizerMode
- 
Tokenize aStringas if it were about to be used as the arguments to a query.
- QUERY_DISCARDED - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of records filtered out as not matching or duplicate.
- QUERY_DISTINCT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent inRecordQueryUnorderedDistinctPlanas part of executing a query.
- QUERY_DISTINCT_PLAN_DUPLICATES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of duplicate records found byRecordQueryUnorderedDistinctPlan.
- QUERY_DISTINCT_PLAN_UNIQUES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of unique records found byRecordQueryUnorderedDistinctPlan.
- QUERY_FILTER - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent inRecordQueryFilterPlanas part of executing a query.
- QUERY_FILTER_GIVEN - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of records given given to any filter within any plan.
- QUERY_FILTER_PASSED - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of records passed by any filter within any plan.
- QUERY_FILTER_PLAN_GIVEN - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of records given toRecordQueryFilterPlan.
- QUERY_FILTER_PLAN_PASSED - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of records passed byRecordQueryFilterPlan.
- QUERY_INTERSECTION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent inRecordQueryIntersectionPlanas part of executing a query.
- QUERY_INTERSECTION_PLAN_MATCHES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of matching records found byRecordQueryIntersectionPlan.
- QUERY_INTERSECTION_PLAN_NONMATCHES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of non-matching records found byRecordQueryIntersectionPlan.
- QUERY_PK_DISTINCT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent inRecordQueryUnorderedPrimaryKeyDistinctPlanas part of executing a query.
- QUERY_PK_DISTINCT_PLAN_DUPLICATES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of duplicate records found byRecordQueryUnorderedPrimaryKeyDistinctPlan.
- QUERY_PK_DISTINCT_PLAN_UNIQUES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of unique records found byRecordQueryUnorderedPrimaryKeyDistinctPlan.
- QUERY_RESULT_COUNT - com.apple.foundationdb.record.logging.TestLogMessageKeys
- QUERY_TEXT_FILTER - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent filtering by text contents inRecordQueryTextIndexPlanas part of executing a query.
- QUERY_TEXT_FILTER_PLAN_GIVEN - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of records given to a filter within aRecordQueryTextIndexPlan
- QUERY_TEXT_FILTER_PLAN_PASSED - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of records passed by a filter within aRecordQueryTextIndexPlan
- QUERY_TYPE_FILTER - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent inRecordQueryTypeFilterPlanas part of executing a query.
- QUERY_TYPE_FILTER_PLAN_GIVEN - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of records given toRecordQueryTypeFilterPlan.
- QUERY_TYPE_FILTER_PLAN_PASSED - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of records passed byRecordQueryTypeFilterPlan.
- QUERY_UNION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent inRecordQueryUnionPlanas part of executing a query.
- QUERY_UNION_PLAN_DUPLICATES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of duplicate records found byRecordQueryUnorderedDistinctPlan.
- QUERY_UNION_PLAN_UNIQUES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of unique records found byRecordQueryUnorderedDistinctPlan.
- Query.InvalidExpressionException - Exception in com.apple.foundationdb.record.query.expressions
- 
Exception thrown when a query expression is not valid in some context.
- QueryableKeyExpression - Interface in com.apple.foundationdb.record.metadata.expressions
- 
AKeyExpressionthat can be used with aQueryKeyExpressionWithComparison.
- QueryComponent - Interface in com.apple.foundationdb.record.query.expressions
- 
Base component interface for checking whether a given record matches a query.
- QueryKeyExpression - Class in com.apple.foundationdb.record.query.expressions
- 
Allow use of aQueryableKeyExpressionin a query.
- QueryKeyExpression(QueryableKeyExpression) - Constructor for class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
- QueryKeyExpressionWithComparison - Class in com.apple.foundationdb.record.query.expressions
- QueryKeyExpressionWithComparison(QueryableKeyExpression, Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- QueryPlan<T> - Interface in com.apple.foundationdb.record.query.plan.plans
- 
An executable query plan.
- QueryPlanner - Interface in com.apple.foundationdb.record.query.plan
- 
A common interface for classes that can plan aRecordQueryinto aRecordQueryPlan.
- QueryPlanner.IndexScanPreference - Enum in com.apple.foundationdb.record.query.plan
- 
Preference between index scan and record scan.
- QueryPredicate - Interface in com.apple.foundationdb.record.query.predicates
- 
An interface describing a predicate that can be evaluated on aSourceEntry(usually derived from a record).
- QueryRecordFunction<T> - Class in com.apple.foundationdb.record.query.expressions
- 
Class that provides context for asserting about a specially calculated value.
- QueryRecordFunction(RecordFunction<T>) - Constructor for class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- QueryRecordFunctionWithComparison - Class in com.apple.foundationdb.record.query.expressions
- 
AComparisons.Comparisonwhose value from the record, to be compared with the comparison's value, is the result of applying aRecordFunctionto the record.
- QueryRecordFunctionWithComparison(RecordFunction<?>, Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- QueryToKeyMatcher - Class in com.apple.foundationdb.record.query
- 
Match a query filter, represented by aQueryComponent, to aKeyExpression.
- QueryToKeyMatcher(QueryComponent) - Constructor for class com.apple.foundationdb.record.query.QueryToKeyMatcher
- QueryToKeyMatcher.Match - Class in com.apple.foundationdb.record.query
- 
The result of matching a particularKeyExpression.
- QueryToKeyMatcher.MatchType - Enum in com.apple.foundationdb.record.query
- 
Whether a match was a successful, and if it was, whether the resulting keys have a single value.
R
- random() - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator.AllocationWindow
- RANDOM - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetHashFunctions
- randomID() - Static method in class com.apple.foundationdb.record.query.plan.temp.CorrelationIdentifier
- 
Create a new correlation identifier using a random string.
- RANGE - com.apple.foundationdb.record.logging.LogMessageKeys
- RANGE_BYTES - com.apple.foundationdb.record.logging.LogMessageKeys
- RANGE_END - com.apple.foundationdb.record.logging.LogMessageKeys
- RANGE_EXCLUSIVE - com.apple.foundationdb.record.EndpointType
- RANGE_INCLUSIVE - com.apple.foundationdb.record.EndpointType
- RANGE_START - com.apple.foundationdb.record.logging.LogMessageKeys
- RANGE_VALUE_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- rank(GroupingKeyExpression) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
A record function that can be used to determine or compare the rank value for a record.
- rank(FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainer
- rank(String) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
A record function that can be used to determine or compare the rank value for a record.
- RANK - com.apple.foundationdb.record.Bindings.Internal
- RANK - Static variable in class com.apple.foundationdb.record.FunctionNames
- RANK - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
A ranked set index, allowing efficient rank and select operations.
- RANK_COUNT_DUPLICATES - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
Whether duplicate keys count separtely in theIndexTypes.RANKskip listRankedSet.
- RANK_FOR_SCORE - Static variable in class com.apple.foundationdb.record.FunctionNames
- RANK_HASH_FUNCTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
The hash function to use in theIndexTypes.RANKskip listRankedSet.
- RANK_NLEVELS - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
The number of levels in theIndexTypes.RANKskip listRankedSet.
- RankComparison(QueryRecordFunctionWithComparison, Index, List<QueryComponent>, List<Comparisons.Comparison>, QueryComponent, String) - Constructor for class com.apple.foundationdb.record.query.plan.planning.RankComparisons.RankComparison
- RankComparisons - Class in com.apple.foundationdb.record.query.plan.planning
- 
Track comparisons involving rank-type functions.
- RankComparisons(QueryComponent, List<Index>) - Constructor for class com.apple.foundationdb.record.query.plan.planning.RankComparisons
- RankComparisons.RankComparison - Class in com.apple.foundationdb.record.query.plan.planning
- 
A single rank function comparison.
- RANKED_SET_ADD_INCREMENT_LEVEL_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent incrementing an existing level key of aRankedSetskip list.
- RANKED_SET_ADD_INSERT_LEVEL_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent incrementing an splitting a level of aRankedSetskip list by inserting another key.
- RANKED_SET_ADD_LEVEL_ZERO_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent adding to the finest level of aRankedSetskip list.
- RANKED_SET_CONTAINS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent checking for a key in aRankedSetskip list.
- RANKED_SET_INIT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent initializing aRankedSetskip list.
- RANKED_SET_NEXT_LOOKUP - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent looking up the next level of aRankedSetskip list.
- RANKED_SET_NEXT_LOOKUP_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent looking up the next entry of aRankedSetskip list.
- RANKED_SET_RANK_FOR_SCORE - com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.Events
- RANKED_SET_SCORE_FOR_RANK - com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.Events
- RANKED_SET_UPDATE - com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.Events
- RankedSetHashFunctions - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
Known hash functions available as index options.
- RankedSetIndexHelper - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
Helper functions for index maintainers that use aRankedSet.
- RankedSetIndexHelper.Events - Enum in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
Instrumentation events specific to rank index maintenance.
- RankedSetIndexHelper.InstrumentedRankedSet - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
ARankedSetthat addsStoreTimerinstrumentation.
- rankForScore(IndexMaintainerState, RankedSet, Tuple, boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper
- RankIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
An index maintainer for keeping aRankedSetof record field values.
- RankIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainer
- RankIndexMaintainerFactory - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
A factory forRankIndexMaintainerindexes.
- RankIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainerFactory
- rankRangeToScoreRange(IndexMaintainerState, int, Subspace, RankedSet.Config, TupleRange) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper
- RAW_BYTES - com.apple.foundationdb.record.logging.LogMessageKeys
- RD_CACHE_DIRECTORY_SCAN - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent scanning the directory subspace after a hard miss inFDBReverseDirectoryCache.
- read(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- read(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- read(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- read(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- read(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- READ_CHILD_COUNT - com.apple.foundationdb.record.logging.LogMessageKeys
- READ_LAST_KEY_MICROS - com.apple.foundationdb.record.logging.LogMessageKeys
- READ_SAMPLE_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent reading a sample key to measure read latency.
- READ_STATE - com.apple.foundationdb.record.logging.LogMessageKeys
- READ_VERSION - com.apple.foundationdb.record.logging.LogMessageKeys
- READABLE - com.apple.foundationdb.record.IndexState
- 
This is the default state for an index.
- readReverse(FDBRecordContext, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- readReverse(FDBStoreTimer, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- readReverse(FDBStoreTimer, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- readReverse(FDBStoreTimer, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- readReverse(FDBStoreTimer, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- READS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
Total number of delete (clear) operations.
- readTransaction(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- ReadVersionRecordStoreStateCache - Class in com.apple.foundationdb.record.provider.foundationdb.storestate
- 
An implementation of theFDBRecordStoreStateCachethat uses the read-version of the associated transaction as the cache invalidation key.
- ReadVersionRecordStoreStateCacheFactory - Class in com.apple.foundationdb.record.provider.foundationdb.storestate
- 
A factory for creatingReadVersionRecordStoreStateCaches.
- REAL_END - com.apple.foundationdb.record.logging.LogMessageKeys
- REASON - com.apple.foundationdb.record.logging.LogMessageKeys
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- rebase(AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.temp.Correlated
- 
Rebases this and all other objects this objects is composed of using a given translation map.
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.FullUnorderedScanExpression
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalTypeFilterExpression
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalUnorderedUnionExpression
- rebase(AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.temp.expressions.RelationalExpressionWithChildren
- rebase(AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.temp.expressions.TypeFilterExpression
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Existential
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.ForEach
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeElement
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ValueElement
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.predicates.AndOrPredicate
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.predicates.NotPredicate
- rebaseWithRebasedChildren(AliasMap, List<QueryPredicate>) - Method in class com.apple.foundationdb.record.query.predicates.AndOrPredicate
- rebaseWithRebasedChildren(AliasMap, List<QueryPredicate>) - Method in class com.apple.foundationdb.record.query.predicates.AndPredicate
- rebaseWithRebasedChildren(AliasMap, List<QueryPredicate>) - Method in class com.apple.foundationdb.record.query.predicates.OrPredicate
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalDistinctExpression
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalSortExpression
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalTypeFilterExpression
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalUnorderedUnionExpression
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in interface com.apple.foundationdb.record.query.plan.temp.expressions.RelationalExpressionWithChildren
- rebaseWithRebasedQuantifiers(AliasMap, List<Quantifier>) - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpressionWithPredicate
- rebuild(LocatableResolver) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
Clears out the persistent reverse directory cache, repopulates it, clears out the in-memory cache and resets cache miss statistics.
- REBUILD_ALL - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
- REBUILD_INDEX - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent deleting an entry from a secondary index.
- REBUILD_RECORD_COUNTS - com.apple.foundationdb.record.logging.LogMessageKeys
- rebuildAllIndexes() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Rebuild all of this store's indexes.
- rebuildIndex(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Rebuild an index.
- rebuildIndex(Index, Collection<RecordType>, FDBRecordStore.RebuildIndexReason) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- rebuildIndex(FDBRecordStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Transactionally rebuild an entire index.
- rebuildIndexAsync(FDBRecordStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Transactionally rebuild an entire index.
- rebuildIndexes(Map<Index, List<RecordType>>, Map<Index, IndexState>, List<CompletableFuture<Void>>, FDBRecordStore.RebuildIndexReason, Integer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- rebuildOrMarkIndex(Index, IndexState, List<RecordType>, FDBRecordStore.RebuildIndexReason, Integer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- record(long) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer.Counter
- 
Add additional time spent performing the associated event.
- record(StoreTimer.Count) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Deprecated.replaced withStoreTimer.increment(Count)
- record(StoreTimer.Count) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- 
Deprecated.useFDBStoreBase.increment(StoreTimer.Count)instead
- record(StoreTimer.Count) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- 
Deprecated.
- record(StoreTimer.Event, long) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Record the amount of time an event took to run.
- record(StoreTimer.Event, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- 
Record the amount of time an event took to run.
- record(StoreTimer.Event, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- 
Record the amount of time an event took to run.
- record(Set<StoreTimer.Event>, long) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Record the amount of time each element in a set of events took to run.
- RECORD - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- RECORD_ASYNC_FILTER - Static variable in class com.apple.foundationdb.record.PipelineOperation
- RECORD_COUNT - com.apple.foundationdb.record.logging.LogMessageKeys
- RECORD_COUNT - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- RECORD_COUNT_ADDED_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- RECORD_COUNT_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- RECORD_COUNT_KEY_ADDED_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- RECORD_FUNCTION - Static variable in class com.apple.foundationdb.record.PipelineOperation
- RECORD_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- RECORD_TYPE - com.apple.foundationdb.record.logging.LogMessageKeys
- RECORD_TYPE_KEY - Static variable in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- RECORD_TYPE_KEY_PROTO - Static variable in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- RECORD_TYPES - com.apple.foundationdb.record.logging.TestLogMessageKeys
- RECORD_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper
- 
Special split point added to end of the key when a record is associated with a version.
- RECORD_VERSION_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- RECORD_VERSION_SPACE - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- RecordAlreadyExistsException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown whenFDBRecordStoreBase.insertRecord(M)is called, but the record already exists.
- RecordAlreadyExistsException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.RecordAlreadyExistsException
- RecordBuiltRangeException(Tuple, Tuple) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.RecordBuiltRangeException
- RecordCoreArgumentException - Exception in com.apple.foundationdb.record
- 
Functional equivalent ofIllegalArgumentException.
- RecordCoreArgumentException(String, IllegalArgumentException) - Constructor for exception com.apple.foundationdb.record.RecordCoreArgumentException
- RecordCoreArgumentException(String, Object...) - Constructor for exception com.apple.foundationdb.record.RecordCoreArgumentException
- RecordCoreException - Exception in com.apple.foundationdb.record
- 
An exception thrown by the core of the Record Layer.
- RecordCoreException(String, Object...) - Constructor for exception com.apple.foundationdb.record.RecordCoreException
- RecordCoreException(String, Throwable) - Constructor for exception com.apple.foundationdb.record.RecordCoreException
- RecordCoreException(Throwable) - Constructor for exception com.apple.foundationdb.record.RecordCoreException
- RecordCoreInterruptedException - Exception in com.apple.foundationdb.record
- 
Functional equivalent ofInterruptedException.
- RecordCoreInterruptedException(String, InterruptedException) - Constructor for exception com.apple.foundationdb.record.RecordCoreInterruptedException
- RecordCoreInterruptedException(String, Object...) - Constructor for exception com.apple.foundationdb.record.RecordCoreInterruptedException
- RecordCoreRetriableTransactionException - Exception in com.apple.foundationdb.record
- 
An exception from transaction processing that ought to be retried.
- RecordCoreRetriableTransactionException(String) - Constructor for exception com.apple.foundationdb.record.RecordCoreRetriableTransactionException
- RecordCoreRetriableTransactionException(String, Throwable) - Constructor for exception com.apple.foundationdb.record.RecordCoreRetriableTransactionException
- RecordCoreStorageException - Exception in com.apple.foundationdb.record
- 
Exceptions due to problems with the state of or connection to a particular record store.
- RecordCoreStorageException(String) - Constructor for exception com.apple.foundationdb.record.RecordCoreStorageException
- RecordCoreStorageException(String, Object...) - Constructor for exception com.apple.foundationdb.record.RecordCoreStorageException
- RecordCoreStorageException(String, Throwable) - Constructor for exception com.apple.foundationdb.record.RecordCoreStorageException
- RecordCursor<T> - Interface in com.apple.foundationdb.record
- 
An asynchronous iterator that supports continuations.
- RecordCursor.NoNextReason - Enum in com.apple.foundationdb.record
- 
The reason thatRecordCursor.hasNext()returnedfalse.
- RecordCursorContinuation - Interface in com.apple.foundationdb.record
- 
An interface for types that represent the continuation of aRecordCursor.
- RecordCursorEndContinuation - Class in com.apple.foundationdb.record
- 
A concrete continuation representing that aRecordCursorhas returned all of the records that it ever will.
- RecordCursorIterator<T> - Class in com.apple.foundationdb.record
- 
An asynchronous iterator that wraps aRecordCursorand presents an iterator-style interface for advancing the cursor.
- RecordCursorResult<T> - Class in com.apple.foundationdb.record
- 
A result obtained when aRecordCursoradvances.
- RecordCursorResult.IllegalResultNoNextReasonAccessException - Exception in com.apple.foundationdb.record
- 
An exception thrown whenRecordCursorResult.getNoNextReason()is called on a result that has a next value.
- RecordCursorResult.IllegalResultValueAccessException - Exception in com.apple.foundationdb.record
- 
An exception thrown whenRecordCursorResult.get()is called on a result without a next value.
- RecordCursorStartContinuation - Class in com.apple.foundationdb.record
- 
A continuation representing the start of a cursor's execution.
- RecordCursorVisitor - Interface in com.apple.foundationdb.record
- 
A hierarchical visitor for record cursor trees designed mostly to allow tests to gather information without adding invasive query methods to theRecordCursorinterface.
- RecordDoesNotExistException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown whenFDBRecordStoreBase.updateRecord(M)is called, but the record does not exist yet.
- RecordDoesNotExistException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.RecordDoesNotExistException
- recordExists(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Check if a record exists in the record store with the given primary key.
- recordExists(Tuple, IsolationLevel) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Check if a record exists in the record store with the given primary key.
- recordExistsAsync(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Check if a record exists in the record store with the given primary key.
- recordExistsAsync(Tuple, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- recordExistsAsync(Tuple, IsolationLevel) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Check if a record exists in the record store with the given primary key.
- recordExistsAsync(Tuple, IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- RecordFunction<T> - Class in com.apple.foundationdb.record
- 
A function to be applied to a record as part of query execution.
- RecordFunction(String) - Constructor for class com.apple.foundationdb.record.RecordFunction
- RecordIndexUniquenessViolation - Exception in com.apple.foundationdb.record
- 
An exception thrown when there is an attempt to store a duplicate value in a unique index.
- RecordIndexUniquenessViolation(Index, IndexEntry, Tuple, Tuple) - Constructor for exception com.apple.foundationdb.record.RecordIndexUniquenessViolation
- RecordIndexUniquenessViolation(String, RecordIndexUniquenessViolation) - Constructor for exception com.apple.foundationdb.record.RecordIndexUniquenessViolation
- recordMetadata - Variable in class com.apple.foundationdb.record.query.plan.visitor.RecordQueryPlannerSubstitutionVisitor
- RecordMetaData - Class in com.apple.foundationdb.record
- 
Meta-data for Record Layer record stores.
- RecordMetaData(Descriptors.FileDescriptor, Descriptors.Descriptor, Map<Descriptors.Descriptor, Descriptors.FieldDescriptor>, Map<String, RecordType>, Map<String, SyntheticRecordType<?>>, Map<String, Index>, Map<String, Index>, List<FormerIndex>, boolean, boolean, int, long, boolean, KeyExpression, boolean) - Constructor for class com.apple.foundationdb.record.RecordMetaData
- RecordMetaDataBuilder - Class in com.apple.foundationdb.record
- 
A builder forRecordMetaData.
- RecordMetaDataBuilder(RecordMetaDataProto.MetaData) - Constructor for class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Deprecated.useRecordMetaData.newBuilder()instead
- RecordMetaDataBuilder(RecordMetaDataProto.MetaData, boolean) - Constructor for class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Deprecated.useRecordMetaData.newBuilder()instead
- RecordMetaDataBuilder(RecordMetaDataProto.MetaData, Descriptors.FileDescriptor[]) - Constructor for class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Deprecated.useRecordMetaData.newBuilder()instead
- RecordMetaDataBuilder(RecordMetaDataProto.MetaData, Descriptors.FileDescriptor[], boolean) - Constructor for class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Deprecated.useRecordMetaData.newBuilder()instead
- RecordMetaDataBuilder(Descriptors.FileDescriptor) - Constructor for class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Deprecated.useRecordMetaData.newBuilder()instead
- RecordMetaDataBuilder(Descriptors.FileDescriptor, boolean) - Constructor for class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Deprecated.useRecordMetaData.newBuilder()instead
- RecordMetaDataBuilder.MetaDataProtoDeserializationException - Exception in com.apple.foundationdb.record
- 
Exception thrown when meta-data cannot be loaded from serialized form.
- RecordMetaDataProvider - Interface in com.apple.foundationdb.record
- 
A source ofRecordMetaData.
- RecordQuery - Class in com.apple.foundationdb.record.query
- 
The logical form of a query.
- RecordQuery.Builder - Class in com.apple.foundationdb.record.query
- 
A builder forRecordQuery.
- RecordQueryCoveringIndexPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that reconstructs records from the entries in a covering index.
- RecordQueryCoveringIndexPlan(RecordQueryPlanWithIndex, String, AvailableFields, IndexKeyValueToPartialRecord) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- RecordQueryFetchFromPartialRecordPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that transforms a stream of partial records (derived from index entries, as in theRecordQueryCoveringIndexPlan) into full records by fetching the records by primary key.
- RecordQueryFetchFromPartialRecordPlan(RecordQueryPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- RecordQueryFilterPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that filters out records from a child plan that do not satisfy a filter component.
- RecordQueryFilterPlan(RecordQueryPlan, QueryComponent) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- RecordQueryFilterPlan(RecordQueryPlan, List<QueryComponent>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- RecordQueryFilterPlan(Quantifier.Physical, QueryComponent) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- RecordQueryIndexPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that outputs records pointed to by entries in a secondary index within some range.
- RecordQueryIndexPlan(String, IndexScanType, ScanComparisons, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- RecordQueryInJoinPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that executes a child plan once for each of the elements of someINlist.
- RecordQueryInJoinPlan(Quantifier.Physical, String, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- RecordQueryInParameterJoinPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that executes a child plan once for each of the elements of anINlist taken from a parameter.
- RecordQueryInParameterJoinPlan(RecordQueryPlan, String, String, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- RecordQueryInParameterJoinPlan(Quantifier.Physical, String, String, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- RecordQueryIntersectionPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that executes by taking the union of records from two or more compatibly-sorted child plans.
- RecordQueryIntersectionPlan(RecordQueryPlan, RecordQueryPlan, KeyExpression, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- 
Deprecated.
- RecordQueryIntersectionPlan(List<RecordQueryPlan>, KeyExpression, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- 
Deprecated.
- RecordQueryInValuesJoinPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that executes a child plan once for each of the elements of a constantINlist.
- RecordQueryInValuesJoinPlan(RecordQueryPlan, String, List<Object>, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
- RecordQueryInValuesJoinPlan(Quantifier.Physical, String, List<Object>, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
- RecordQueryLoadByKeysPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that returns records whose primary keys are taken from some list.
- RecordQueryLoadByKeysPlan(RecordQueryLoadByKeysPlan.KeysSource) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- RecordQueryLoadByKeysPlan(String) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- RecordQueryLoadByKeysPlan(List<Tuple>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- RecordQueryLoadByKeysPlan.KeysSource - Interface in com.apple.foundationdb.record.query.plan.plans
- 
A source for the primary keys for records.
- RecordQueryPlan - Interface in com.apple.foundationdb.record.query.plan.plans
- 
An executable query plan for producing records.
- RecordQueryPlanComplexityException - Exception in com.apple.foundationdb.record.query.plan
- 
Exception thrown when a query plan is more complex than the configured limit.
- RecordQueryPlanComplexityException(RecordQueryPlan) - Constructor for exception com.apple.foundationdb.record.query.plan.RecordQueryPlanComplexityException
- RecordQueryPlanComplexityException(String) - Constructor for exception com.apple.foundationdb.record.query.plan.RecordQueryPlanComplexityException
- RecordQueryPlanComplexityException(String, Throwable) - Constructor for exception com.apple.foundationdb.record.query.plan.RecordQueryPlanComplexityException
- RecordQueryPlanner - Class in com.apple.foundationdb.record.query.plan
- 
The query planner.
- RecordQueryPlanner(RecordMetaData, RecordStoreState) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- RecordQueryPlanner(RecordMetaData, RecordStoreState, StoreTimer) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- RecordQueryPlanner(RecordMetaData, RecordStoreState, StoreTimer, int) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- RecordQueryPlanner(RecordMetaData, RecordStoreState, PlannableIndexTypes, StoreTimer) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- RecordQueryPlanner(RecordMetaData, RecordStoreState, PlannableIndexTypes, StoreTimer, int) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- RecordQueryPlanner.ScoredPlan - Class in com.apple.foundationdb.record.query.plan
- RecordQueryPlannerConfiguration - Class in com.apple.foundationdb.record.query.plan
- 
A set of configuration options for theRecordQueryPlanner.
- RecordQueryPlannerConfiguration.Builder - Class in com.apple.foundationdb.record.query.plan
- 
A builder forRecordQueryPlannerConfiguration.
- RecordQueryPlannerSubstitutionVisitor - Class in com.apple.foundationdb.record.query.plan.visitor
- 
Visitor interface for performing substitution-type rules onRecordQueryPlans.
- RecordQueryPlannerSubstitutionVisitor(RecordMetaData, PlannableIndexTypes, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.visitor.RecordQueryPlannerSubstitutionVisitor
- RecordQueryPlanWithChild - Interface in com.apple.foundationdb.record.query.plan.plans
- 
A query plan with a single child plan.
- RecordQueryPlanWithChildren - Interface in com.apple.foundationdb.record.query.plan.plans
- 
A query plan with child plans.
- RecordQueryPlanWithComparisons - Interface in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that usesScanComparisonsto drive some scan of the record store.
- RecordQueryPlanWithIndex - Interface in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that uses a single index.
- RecordQueryPlanWithNoChildren - Interface in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that does not have any child plans.
- RecordQueryPlanWithRequiredFields - Interface in com.apple.foundationdb.record.query.plan.plans
- 
Interface for query plans that have fields that must be present for successful execution.
- RecordQueryPredicateFilterPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that filters out records from a child plan that do not satisfy aQueryPredicate.
- RecordQueryPredicateFilterPlan(Quantifier.Physical, Source, QueryPredicate) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- RecordQueryScanPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that scans records directly from the main tree within a range of primary keys.
- RecordQueryScanPlan(ScanComparisons, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- 
Overloaded constructor.
- RecordQueryScanPlan(Set<String>, ScanComparisons, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- 
Overloaded constructor.
- RecordQueryScoreForRankPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that converts ranks to scores and executes a child plan with the conversion results bound in named parameters.
- RecordQueryScoreForRankPlan(RecordQueryPlan, List<RecordQueryScoreForRankPlan.ScoreForRank>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- RecordQueryScoreForRankPlan.ScoreForRank - Class in com.apple.foundationdb.record.query.plan.plans
- 
A single conversion of a rank to a score to be bound to some name.
- RecordQueryTextIndexPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that can scan text indexes.
- RecordQueryTextIndexPlan(String, TextScan, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- RecordQueryTypeFilterPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that filters out records from a child plan that are not of the designated record type(s).
- RecordQueryTypeFilterPlan(RecordQueryPlan, Collection<String>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- RecordQueryTypeFilterPlan(Quantifier.Physical, Collection<String>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- RecordQueryUnionPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that executes by taking the union of records from two or more compatibly-sorted child plans.
- RecordQueryUnionPlan(RecordQueryPlan, RecordQueryPlan, KeyExpression, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- 
Deprecated.
- RecordQueryUnionPlan(List<RecordQueryPlan>, KeyExpression, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- 
Deprecated.
- RecordQueryUnionPlanBase - Class in com.apple.foundationdb.record.query.plan.plans
- 
Common base class for plans that perform stream union operations.
- RecordQueryUnionPlanBase(RecordQueryPlan, RecordQueryPlan, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- RecordQueryUnionPlanBase(List<Quantifier.Physical>, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- RecordQueryUnorderedDistinctPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that removes duplicates by means of a hash table of previously seen values.
- RecordQueryUnorderedDistinctPlan(RecordQueryPlan, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- RecordQueryUnorderedPrimaryKeyDistinctPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that removes duplicates by means of a hash table of primary keys already seen.
- RecordQueryUnorderedPrimaryKeyDistinctPlan(RecordQueryPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- RecordQueryUnorderedPrimaryKeyDistinctPlan(Quantifier.Physical) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- RecordQueryUnorderedUnionPlan - Class in com.apple.foundationdb.record.query.plan.plans
- 
A query plan that returns results from two-or-more cursors as they as ready.
- RECORDS - com.apple.foundationdb.record.logging.TestLogMessageKeys
- RECORDS_PER_SECOND - com.apple.foundationdb.record.logging.TestLogMessageKeys
- RECORDS_SCANNED - com.apple.foundationdb.record.logging.LogMessageKeys
- RECORDS_WHILE_BUILDING - com.apple.foundationdb.record.logging.LogMessageKeys
- RecordScanLimiter - Interface in com.apple.foundationdb.record
- 
Track number of records scanned up to some limit, after which record scans should not be allowed.
- RecordScanLimiterFactory - Class in com.apple.foundationdb.record
- 
A factory that produces implementations ofRecordScanLimiters.
- RecordScanLimiterFactory() - Constructor for class com.apple.foundationdb.record.RecordScanLimiterFactory
- RecordSerializationException - Exception in com.apple.foundationdb.record.provider.common
- 
Exception thrown when there is a problem serializing or deserializing a record.
- RecordSerializationException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.common.RecordSerializationException
- RecordSerializationException(String, Throwable) - Constructor for exception com.apple.foundationdb.record.provider.common.RecordSerializationException
- RecordSerializationException(Throwable) - Constructor for exception com.apple.foundationdb.record.provider.common.RecordSerializationException
- RecordSerializer<M extends Message> - Interface in com.apple.foundationdb.record.provider.common
- 
A converter between a Protobuf record and a byte string stored in one or more values in the FDB key-value store.
- RecordSerializer.Counts - Enum in com.apple.foundationdb.record.provider.common
- 
Instrumentation counts related to record serialization.
- RecordSerializer.Events - Enum in com.apple.foundationdb.record.provider.common
- 
Instrumentation events related to record serialization.
- recordSinceNanoTime(StoreTimer.Event, long) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Record time since given time.
- recordsPerSecond - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- recordsSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- RecordStoreAlreadyExistsException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown whenFDBRecordStoreBase.BaseBuilder.create()is called, but the record store already exists.
- RecordStoreAlreadyExistsException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.RecordStoreAlreadyExistsException
- recordStoreBuilder - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- RecordStoreDoesNotExistException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown whenFDBRecordStoreBase.BaseBuilder.open()is called, but the record store does not exist yet.
- RecordStoreDoesNotExistException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.RecordStoreDoesNotExistException
- RecordStoreNoInfoAndNotEmptyException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown whenFDBRecordStoreBase.BaseBuilder.createOrOpen()is called, and the record store does not have a store info header, but does have something else.
- RecordStoreNoInfoAndNotEmptyException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.RecordStoreNoInfoAndNotEmptyException
- RecordStoreStaleMetaDataVersionException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown when the record store has a newer meta-data version than the one from the givenRecordMetaDataProvider.
- RecordStoreStaleMetaDataVersionException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.RecordStoreStaleMetaDataVersionException
- RecordStoreStaleUserVersionException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown when the record store has a newer user version than the one from the givenFDBRecordStoreBase.UserVersionChecker.
- RecordStoreStaleUserVersionException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.RecordStoreStaleUserVersionException
- RecordStoreState - Class in com.apple.foundationdb.record
- 
TheRecordStoreStateinterface handles information that might differ between otherwise identical record stores.
- RecordStoreState() - Constructor for class com.apple.foundationdb.record.RecordStoreState
- 
Deprecated.as the default store header is incorrect for most record stores
- RecordStoreState(RecordMetaDataProto.DataStoreInfo, Map<String, IndexState>) - Constructor for class com.apple.foundationdb.record.RecordStoreState
- 
Creates aRecordStoreStatewith the given index states.
- RecordStoreState(Map<String, IndexState>) - Constructor for class com.apple.foundationdb.record.RecordStoreState
- 
Deprecated.as the default store header is incorrect for most record stores
- recordStoreStateRef - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- recordTimeout(StoreTimer.Wait, long) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Record that some operation timed out.
- recordTimeout(StoreTimer.Wait, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer
- recordType() - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
The record type key expression, which indicates that a unique record type identifier should be contained within the key.
- RecordType - Class in com.apple.foundationdb.record.metadata
- 
Record type meta-data.
- RecordType(RecordMetaData, Descriptors.Descriptor, KeyExpression, List<Index>, List<Index>, Integer, Object) - Constructor for class com.apple.foundationdb.record.metadata.RecordType
- RecordTypeBuilder - Class in com.apple.foundationdb.record.metadata
- 
A builder forRecordType.
- RecordTypeBuilder(Descriptors.Descriptor) - Constructor for class com.apple.foundationdb.record.metadata.RecordTypeBuilder
- RecordTypeBuilder(Descriptors.Descriptor, RecordTypeBuilder) - Constructor for class com.apple.foundationdb.record.metadata.RecordTypeBuilder
- 
Copy constructor forRecordTypeBuilderthat copies all fields except the descriptor.
- RecordTypeBuilder.NonbuildableException - Exception in com.apple.foundationdb.record.metadata
- 
Exception thrown when aRecordTypeBuilderis not yet in a state where it can be built.
- RecordTypeChangedException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown whenFDBRecordStoreBase.updateRecord(M)is called, but the existing record has a different record type.
- RecordTypeChangedException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.RecordTypeChangedException
- RecordTypeElement - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
An element representing the record type of each entry generated by the source.
- RecordTypeElement(Source) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeElement
- RecordTypeIndexesBuilder - Class in com.apple.foundationdb.record.metadata
- 
A base builder forRecordType.
- RecordTypeIndexesBuilder(String) - Constructor for class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
- RecordTypeIndexesBuilder(String, RecordTypeIndexesBuilder) - Constructor for class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
- recordTypeKey - Variable in class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
- RecordTypeKeyComparison - Class in com.apple.foundationdb.record.query.expressions
- 
AQueryComponentthat implements checking for a given record type.
- RecordTypeKeyComparison(String) - Constructor for class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- recordTypeKeyComparisonTypes(ScanComparisons) - Static method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- RecordTypeKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
A key expression that indicates that a unique record type identifier should be contained within the key.
- recordTypeKeys - Variable in class com.apple.foundationdb.record.metadata.MetaDataValidator
- RecordTypeOrBuilder - Interface in com.apple.foundationdb.record.metadata
- 
Common interface implemented by theRecordTypeandRecordTypeBuilderclasses that contains accessors that they are both expected to have.
- recordTypes - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- recordTypesForIndex(Index) - Method in class com.apple.foundationdb.record.RecordMetaData
- RecordTypeSource - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
ASourcerepresenting the stream of all records of a particular type or types.
- RecordTypeSource(String) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeSource
- RecordTypeSource(Set<String>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeSource
- RecordTypesProperty - Class in com.apple.foundationdb.record.query.plan.temp.properties
- 
A property visitor that determines the set of record type names (as Strings) that aRelationalExpressioncould produce.
- RECOUNT_RECORDS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent counting records for the deprecated record count key.
- reduce(U, BiFunction<U, ? super T, U>) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Reduce contents of cursor to single value.
- ref(U) - Method in class com.apple.foundationdb.record.query.plan.temp.CascadesRuleCall
- ref(U) - Method in interface com.apple.foundationdb.record.query.plan.temp.PlannerRuleCall
- 
Wrap the given planner expression in an implementation ofExpressionRefsuitable for the planner associated with this rule.
- ReferenceMatcher<T extends RelationalExpression> - Class in com.apple.foundationdb.record.query.plan.temp.matchers
- 
An expression matcher that matches against any reference at all.
- ReferenceMatcher() - Constructor for class com.apple.foundationdb.record.query.plan.temp.matchers.ReferenceMatcher
- RefPath(RelationalExpression, Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.temp.ExpressionRefTraversal.RefPath
- register(TextTokenizerFactory) - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizerRegistry
- 
Registers a new tokenizer in this registry.
- register(TextTokenizerFactory) - Method in class com.apple.foundationdb.record.provider.common.text.TextTokenizerRegistryImpl
- registerScannedBytes(long) - Method in interface com.apple.foundationdb.record.ByteScanLimiter
- 
Atomically decrement the number of remaining bytes by the given number of bytes.
- RelationalExpression - Interface in com.apple.foundationdb.record.query.plan.temp
- 
A relational expression is aRelationalExpressionthat represents a stream of records.
- RelationalExpressionDepthProperty - Class in com.apple.foundationdb.record.query.plan.temp.properties
- 
A property representing the minimum depth of any of a set of relational planner expression types in a relational planner expression: that is, the smallest integer such that one of those types is exactly that many relational planner expressions away from the root expression.
- RelationalExpressionDepthProperty(Set<Class<? extends RelationalExpression>>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.properties.RelationalExpressionDepthProperty
- RelationalExpressionPointerSet<T extends RelationalExpression> - Class in com.apple.foundationdb.record.query.plan.temp
- 
A set ofRelationalExpressions that uses reference ("pointer") equality to determine equivalence for the purposes of set membership, rather than theObject.equals(Object)method used by the JavaSetinterface.
- RelationalExpressionPointerSet() - Constructor for class com.apple.foundationdb.record.query.plan.temp.RelationalExpressionPointerSet
- RelationalExpressionWithChildren - Interface in com.apple.foundationdb.record.query.plan.temp.expressions
- 
A parent interface forRelationalExpressions that have relational children (as opposed to non-relation children, such asQueryComponents).
- RelationalExpressionWithPredicate - Interface in com.apple.foundationdb.record.query.plan.temp
- 
A (relational) expression that has a predicate on it.
- remove(T) - Method in class com.apple.foundationdb.record.query.plan.temp.RelationalExpressionPointerSet
- REMOVE - com.apple.foundationdb.record.logging.LogMessageKeys
- REMOVE_FORMER_INDEX - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent clearing the space taken by an index that has been removed from the meta-data.
- removeFormerIndex(FormerIndex) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- removeIndex(String) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- removeIndexFetch(RecordQueryPlan, Set<KeyExpression>) - Method in class com.apple.foundationdb.record.query.plan.visitor.RecordQueryPlannerSubstitutionVisitor
- removeIndexFetch(RecordMetaData, PlannableIndexTypes, KeyExpression, RecordQueryPlan, Set<KeyExpression>) - Static method in class com.apple.foundationdb.record.query.plan.visitor.RecordQueryPlannerSubstitutionVisitor
- removePostCommit(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Remove a previously installed post-commit hook.
- RemoveRedundantTypeFilterRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule that eliminates logical type filters that are completely redundant; that is, when the child of the logical type filter is guaranteed to return records of types included in the filter.
- RemoveRedundantTypeFilterRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.RemoveRedundantTypeFilterRule
- removesDuplicates() - Method in class com.apple.foundationdb.record.query.RecordQuery
- removeUniquenessViolationsAsync(Tuple, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Remove a uniqueness violation within the database.
- removeVersionMutation(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Remove aSET_VERSIONSTAMPED_KEYmutation that would have been run at commit time.
- renameRecordType(RecordMetaDataProto.MetaData.Builder, String, String) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
- 
Rename a record type.
- renderCluster(GraphExporter.ExporterContext, String, N, Set<N>, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- renderCluster(GraphExporter.ExporterContext, String, N, Set<N>, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GmlExporter
- renderCluster(GraphExporter.ExporterContext, String, N, Set<N>, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Render a sub cluster.
- renderClusters(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Render all sub clusters in a given network.
- renderEdge(GraphExporter.ExporterContext, boolean, N, N, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- renderEdge(GraphExporter.ExporterContext, boolean, N, N, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GmlExporter
- renderEdge(GraphExporter.ExporterContext, boolean, N, N, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Render an edge.
- renderEdges(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Render all edges in a given network.
- renderFooter(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- 
Compute the footer.
- renderFooter(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GmlExporter
- renderFooter(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Render the footer.
- renderGraphAttributes(GraphExporter.ExporterContext, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- renderGraphAttributes(GraphExporter.ExporterContext, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GmlExporter
- renderGraphAttributes(GraphExporter.ExporterContext, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Render the global graph attributes.
- renderHeader(GraphExporter.ExporterContext, ImmutableNetwork<N, E>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- renderHeader(GraphExporter.ExporterContext, ImmutableNetwork<N, E>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GmlExporter
- renderHeader(GraphExporter.ExporterContext, ImmutableNetwork<N, E>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Render the header.
- renderNode(GraphExporter.ExporterContext, N, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- renderNode(GraphExporter.ExporterContext, N, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GmlExporter
- renderNode(GraphExporter.ExporterContext, N, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Render a node.
- renderNodes(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.DotExporter
- renderNodes(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.temp.explain.GraphExporter
- 
Render all nodes in the given network.
- REPAIR_RECORD_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of record keys repaired byFDBRecordStore.repairRecordKeys(byte[], com.apple.foundationdb.record.ScanProperties).
- repairRecordKeys(byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- repairRecordKeys(byte[], ScanProperties, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Validate and repair known potential issues with record keys.
- RepeatedFieldSource - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
ASourcerepresenting the stream of the zero or more values of a repeated field.
- RepeatedFieldSource(Source, String) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.RepeatedFieldSource
- RepeatedFieldSource(Source, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.RepeatedFieldSource
- replace(T) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- REPLACE_RECORD_VALUE_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The previous size of values for record key-value pairs that are updated.
- reportScannedBytes(long) - Method in class com.apple.foundationdb.record.cursors.CursorLimitManager
- 
Record that the specified number of bytes have been scanned and update the relevant limiters with this information.
- REQUESTED_END - com.apple.foundationdb.record.logging.LogMessageKeys
- REQUESTED_START - com.apple.foundationdb.record.logging.LogMessageKeys
- requireMessageField(Descriptors.FieldDescriptor) - Method in class com.apple.foundationdb.record.query.expressions.BaseField
- requirePrimitiveField(Descriptors.FieldDescriptor) - Method in class com.apple.foundationdb.record.query.expressions.BaseField
- requireScalarField(Descriptors.FieldDescriptor) - Method in class com.apple.foundationdb.record.query.expressions.BaseField
- reset() - Method in interface com.apple.foundationdb.record.ByteScanLimiter
- 
Create a newByteScanLimiterwith this limiter's original limit, ignoring any calls toByteScanLimiter.hasBytesRemaining()andByteScanLimiter.registerScannedBytes(long).
- reset() - Method in class com.apple.foundationdb.record.ExecuteState
- 
Create a newExecuteStatethat represents the same properties of the execution that this state represented when it was first created, but with an independent set of mutable objects.
- reset() - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
- 
Clear all recorded timing information.
- reset() - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizerRegistry
- 
Clears the registry and reloads tokenizers from the classpath.
- reset() - Method in class com.apple.foundationdb.record.provider.common.text.TextTokenizerRegistryImpl
- reset() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- reset() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Reset this mask so all filters are marked as unsatisfied.
- reset() - Method in interface com.apple.foundationdb.record.RecordScanLimiter
- 
Create a newRecordScanLimiterwith this limiter's original limit, ignoring any calls toRecordScanLimiter.tryRecordScan().
- resetState() - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Reset the stateful parts of the properties to their "original" values, creating an independent mutable state.
- resolve(FDBRecordContext, KeySpaceCountTree.Resolved) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- resolve(FDBRecordContext, KeySpaceCountTree.Resolved, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- resolve(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Map the Stringnameto a Long within the scope of the path that this object was constructed with.
- resolve(FDBRecordContext, String, ResolverCreateHooks) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Map the Stringnameto a Long within the scope of the path that this object was constructed with.
- resolve(FDBStoreTimer, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Map the Stringnameto a Long within the scope of the path that this object was constructed with.
- resolve(FDBStoreTimer, String, ResolverCreateHooks) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Map the Stringnameto a Long within the scope of the path that this object was constructed with.
- resolve(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Map the Stringnameto a Long within the scope of the path that this object was constructed with.
- resolve(String, ResolverCreateHooks) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Map the Stringnameto a Long within the scope of the path that this object was constructed with.
- RESOLVE_UNIQUENESS - Static variable in class com.apple.foundationdb.record.PipelineOperation
- resolveAsync(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Retrieve the value that is to be stored for this directory entry.
- resolveAsync(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- Resolved(KeySpaceCountTree.Resolved) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.Resolved
- ResolvedIndexKeyspace(KeySpaceCountTree.Resolved, Index) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedIndexKeyspace
- ResolvedKeyField(KeySpaceCountTree.Resolved, String, Object, Object) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedKeyField
- ResolvedKeySpacePath - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
AKeySpacePaththat has been resolved into the value that will be physically stored to represent the path element in the FDB keyspace.
- ResolvedKeySpacePath(ResolvedKeySpacePath, KeySpacePath, PathValue, Tuple) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Create a resolved keyspace path.
- ResolvedPath(KeySpaceCountTree.Resolved, ResolvedKeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedPath
- ResolvedPrefixRoot(KeySpaceCountTree.Resolved, Object) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedPrefixRoot
- ResolvedRecordStoreKeyspace(KeySpaceCountTree.Resolved, FDBRecordStoreKeyspace, RecordMetaData, Object) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRecordStoreKeyspace
- ResolvedRecordTypeKeyspace(KeySpaceCountTree.Resolved, RecordType) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRecordTypeKeyspace
- ResolvedRoot(KeySpaceCountTree.Resolved, KeySpaceDirectory) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRoot
- ResolvedRoot(KeySpace) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedRoot
- resolveFromKey(FDBRecordContext, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Synchronous/blocking version ofresolveFromKeyAsync.
- resolveFromKeyAsync(FDBRecordContext, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Given a tuple from an FDB key, attempts to determine what path through this directory the tuple represents, returning aResolvedKeySpacePathrepresenting the leaf-most directory in the path.
- resolveIndexField(FDBRecordContext, KeySpaceCountTree.Resolved, Object, Index, KeyExpression, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- resolveKeyField(FDBRecordContext, KeySpaceCountTree.Resolved, Object, KeyExpression) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- resolveNonDirectory(FDBRecordContext, KeySpaceCountTree.Resolved, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- 
Resolve something other than aKeySpaceDirectorynode.
- resolvePrimaryKeyField(FDBRecordContext, KeySpaceCountTree.Resolved, Object, KeyExpression, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- RESOLVER_KEY - com.apple.foundationdb.record.logging.LogMessageKeys
- RESOLVER_PATH - com.apple.foundationdb.record.logging.LogMessageKeys
- RESOLVER_STATE_READ - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
The amount of time spent reading the lock state of aLocatableResolver.
- ResolverCreateHooks - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
Set of hooks to be run only when creating a mapping in aLocatableResolver.
- ResolverCreateHooks(ResolverCreateHooks.PreWriteCheck, ResolverCreateHooks.MetadataHook) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverCreateHooks
- ResolverCreateHooks(List<ResolverCreateHooks.PreWriteCheck>, ResolverCreateHooks.MetadataHook) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverCreateHooks
- ResolverCreateHooks.MetadataHook - Interface in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
Functional interface for the safety check that will be run before writing a mapping in theLocatableResolver.
- ResolverCreateHooks.PreWriteCheck - Interface in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
Functional interface for the safety check that will be run before writing a mapping in theLocatableResolver.
- ResolverMappingDigest - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
Computes a message digest for all of the string to integer mappings in the providedLocatableResolver.
- ResolverMappingDigest(LocatableResolver) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingDigest
- ResolverMappingDigest(LocatableResolver, int) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingDigest
- ResolverMappingReplicator - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
Copies the contents of oneLocatableResolverto another.
- ResolverMappingReplicator(LocatableResolver) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingReplicator
- ResolverMappingReplicator(LocatableResolver, int) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingReplicator
- ResolverMappingReplicator(LocatableResolver, int, long) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingReplicator
- ResolverResult - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
A class containing the result of resolving a key withLocatableResolver.
- ResolverResult(long) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverResult
- ResolverResult(long, byte[]) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverResult
- resolveUniquenessViolation(Index, Key.Evaluated, Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Removes all of the records that have the given value set as their index index value (are thus causing a uniqueness violation) except for the one that has the given primary key (if the key is notnull).
- resolveUniquenessViolation(Index, Tuple, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- resolveUniquenessViolation(Index, Tuple, Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Removes all of the records that have the given value set as their index value (and are thus causing a uniqueness violation) except for the one that has the given primary key (if the key is notnull).
- resolveUniquenessViolation(Index, Tuple, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- resolveVisibleChildren(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- resolveWithMetadata(FDBRecordContext, String, ResolverCreateHooks) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Map the Stringnameto aResolverResultwithin the scope of the path that this object was constructed with.
- resolveWithMetadata(FDBStoreTimer, String, ResolverCreateHooks) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Map the Stringnameto aResolverResultwithin the scope of the path that this object was constructed with.
- resolveWithMetadata(String, ResolverCreateHooks) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Map the Stringnameto aResolverResultwithin the scope of the path that this object was constructed with.
- RESULT - com.apple.foundationdb.record.logging.LogMessageKeys
- RESULT_COUNT - com.apple.foundationdb.record.logging.TestLogMessageKeys
- retired(FDBStoreTimer) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Check whether this resolver has been retired.
- retiredSkipCache(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Check whether this resolver has been retired.
- retireLayer() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Retire thisLocatableResolver, indicating that it should not be used for any future resolve operations.
- RETURN - com.apple.foundationdb.record.provider.foundationdb.IndexOrphanBehavior
- 
Return the index entry but with no record associated with it.
- RETURN_LIMIT_REACHED - com.apple.foundationdb.record.RecordCursor.NoNextReason
- 
The limit on the number record to return was reached.
- reverse - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- REVERSE_DIR_PERSISTENT_CACHE_HIT_COUNT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of reverse directory cache hits.
- REVERSE_DIR_PERSISTENT_CACHE_MISS_COUNT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of reverse directory cache misses.
- REVERSE_DIRECTORY_CACHE_ENTRY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- REVERSE_SCAN - Static variable in class com.apple.foundationdb.record.ScanProperties
- reverseLookup(FDBStoreTimer, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Lookup the String that maps to the provided value within the scope of the path that this object was constructed with.
- rewriteExplainPlannerGraph(List<? extends PlannerGraph>) - Method in interface com.apple.foundationdb.record.query.plan.temp.explain.ExplainPlannerGraphRewritable
- 
Method to rewrite the planner graph.
- rewriteInternalPlannerGraph(List<? extends PlannerGraph>) - Method in interface com.apple.foundationdb.record.query.plan.temp.explain.InternalPlannerGraphRewritable
- 
Method to rewrite the planner graph.
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- 
Rewrite the planner graph for better visualization of a query index plan.
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
- 
Rewrite the planner graph for better visualization of a query index plan.
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithIndex
- 
Rewrite the planner graph for better visualization of a query index plan.
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- 
Rewrite the planner graph for better visualization of a query scan plan.
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- 
Rewrite the planner graph for better visualization of a query index plan.
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- 
Rewrite the planner graph for better visualization of a query index plan.
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in interface com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraphRewritable
- 
Method to rewrite the planner graph.
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.FullUnorderedScanExpression
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalFilterExpression
- rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.LogicalTypeFilterExpression
- rowLimit - Variable in class com.apple.foundationdb.record.ExecuteProperties
- RowLimitedCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that limits the number of elements that it allows through.
- RowLimitedCursor(RecordCursor<T>, int) - Constructor for class com.apple.foundationdb.record.cursors.RowLimitedCursor
- run() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext.AfterCommit
- run() - Method in class com.apple.foundationdb.record.query.plan.temp.CascadesRuleCall
- run(FDBStoreTimer, Map<String, String>, FDBDatabase.WeakReadSemantics, Function<? super FDBRecordContext, ? extends T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Runs a transactional function against thisFDBDatabasewith retry logic.
- run(FDBStoreTimer, Map<String, String>, Function<? super FDBRecordContext, ? extends T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Runs a transactional function against thisFDBDatabasewith retry logic.
- run(Executor) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SingleKeyUnsplitter
- 
Unsplit a record in the database.
- run(Function<? super FDBRecordContext, ? extends T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Runs a transactional function against thisFDBDatabasewith retry logic.
- run(Function<? super FDBRecordContext, ? extends T>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Runs a transactional function against with retry logic.
- run(Function<? super FDBRecordContext, ? extends T>, List<Object>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Runs a transactional function against with retry logic.
- run(Function<? super FDBRecordContext, ? extends T>, List<Object>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- run(Function<? super FDBRecordContext, ? extends T>, List<Object>) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- run(Function<? super Transaction, T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- runAfterCommits() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Deprecated.this method probably should never have been public
- runAsync(FDBStoreTimer, Map<String, String>, FDBDatabase.WeakReadSemantics, Function<? super FDBRecordContext, CompletableFuture<? extends T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Runs a transactional function asynchronously against thisFDBDatabasewith retry logic.
- runAsync(FDBStoreTimer, Map<String, String>, Function<? super FDBRecordContext, CompletableFuture<? extends T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Runs a transactional function asynchronously against thisFDBDatabasewith retry logic.
- runAsync(Function<? super FDBRecordContext, CompletableFuture<? extends T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Runs a transactional function asynchronously against thisFDBDatabasewith retry logic.
- runAsync(Function<? super FDBRecordContext, CompletableFuture<? extends T>>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Runs a transactional function asynchronously with retry logic.
- runAsync(Function<? super FDBRecordContext, CompletableFuture<? extends T>>, BiFunction<? super T, Throwable, ? extends Pair<? extends T, ? extends Throwable>>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Runs a transactional function asynchronously with retry logic.
- runAsync(Function<? super FDBRecordContext, CompletableFuture<? extends T>>, BiFunction<? super T, Throwable, ? extends Pair<? extends T, ? extends Throwable>>, List<Object>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Runs a transactional function asynchronously with retry logic.
- runAsync(Function<? super FDBRecordContext, CompletableFuture<? extends T>>, BiFunction<? super T, Throwable, ? extends Pair<? extends T, ? extends Throwable>>, List<Object>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- runAsync(Function<? super FDBRecordContext, CompletableFuture<? extends T>>, BiFunction<? super T, Throwable, ? extends Pair<? extends T, ? extends Throwable>>, List<Object>) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- runAsync(Function<? super Transaction, ? extends CompletableFuture<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- runCommitChecks() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Run anyFDBRecordContext.CommitCheckAsyncs that are still outstanding.
- runner - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- RunnerClosed() - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner.RunnerClosed
S
- save() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer.UpdateState
- SAVE_INDEX_ENTRY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent saving an entry to a secondary index.
- SAVE_INDEX_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of index key-value pairs saved.
- SAVE_INDEX_KEY_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of keys for index key-value pairs saved.
- SAVE_INDEX_VALUE_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of values for index key-value pairs saved.
- SAVE_META_DATA - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken persisting meta-data to aFDBMetaDataStore.
- SAVE_RECORD - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken saving records.
- SAVE_RECORD_KEY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of record key-value pairs saved.
- SAVE_RECORD_KEY_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of keys for record key-value pairs saved.
- SAVE_RECORD_VALUE_BYTES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The size of values for record key-value pairs saved.
- SAVE_UNSPLIT_WITH_SUFFIX_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- SAVE_VERSION_WITH_RECORD_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- saveAndSetCurrent(RecordMetaDataProto.MetaData) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Build meta-data to use from Protobuf and save.
- saveDirectory(TimeWindowLeaderboardDirectory) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- saveIndexEntryAsKeyValue(IndexEntry) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Manually save an index entry, for example when rebuilding in place with a different storage format.
- saveRecord(M) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Save the given record.
- saveRecord(M, FDBRecordStoreBase.RecordExistenceCheck) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Save the given record.
- saveRecord(M, FDBRecordStoreBase.RecordExistenceCheck, FDBRecordVersion, FDBRecordStoreBase.VersionstampSaveBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Save the given record with a specific version.
- saveRecord(M, FDBRecordVersion) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Save the given record with a specific version.
- saveRecord(M, FDBRecordVersion, FDBRecordStoreBase.VersionstampSaveBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Save the given record with a specific version.
- saveRecordAsync(Message, FDBRecordStoreBase.RecordExistenceCheck, FDBRecordVersion, FDBRecordStoreBase.VersionstampSaveBehavior) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- saveRecordAsync(M) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Async version ofFDBRecordStoreBase.saveRecord(Message).
- saveRecordAsync(M, FDBRecordStoreBase.RecordExistenceCheck) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Async version ofFDBRecordStoreBase.saveRecord(Message, RecordExistenceCheck).
- saveRecordAsync(M, FDBRecordStoreBase.RecordExistenceCheck, FDBRecordVersion, FDBRecordStoreBase.VersionstampSaveBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- saveRecordAsync(M, FDBRecordStoreBase.RecordExistenceCheck, FDBRecordVersion, FDBRecordStoreBase.VersionstampSaveBehavior) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- saveRecordAsync(M, FDBRecordVersion) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Async version ofFDBRecordStoreBase.saveRecord(Message, FDBRecordVersion).
- saveRecordAsync(M, FDBRecordVersion, FDBRecordStoreBase.VersionstampSaveBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- saveRecordMetaData(RecordMetaDataProto.MetaData) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Save the record meta-data into the meta-data store.
- saveRecordMetaData(RecordMetaDataProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Save the record meta-data into the meta-data store.
- saveRecordMetaData(Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Save the record meta-data into the meta-data store.
- saveRecordMetaDataAsync(Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Save the record meta-data into the meta-data store.
- saveStoreHeader(RecordMetaDataProto.DataStoreInfo) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- saveSubDirectory(TimeWindowLeaderboardSubDirectory) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- saveTypedRecord(RecordSerializer<M>, M, FDBRecordStoreBase.RecordExistenceCheck, FDBRecordVersion, FDBRecordStoreBase.VersionstampSaveBehavior) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- saveWithSplit(FDBRecordContext, Subspace, Tuple, byte[], FDBRecordVersion) - Static method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper
- 
Save serialized representation using multiple keys if necessary.
- saveWithSplit(FDBRecordContext, Subspace, Tuple, byte[], FDBRecordVersion, boolean, boolean, boolean, FDBStoredSizes, SplitHelper.SizeInfo) - Static method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper
- 
Save serialized representation using multiple keys if necessary, clearing only as much as needed.
- scalar(Object) - Static method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
Creates a new key with just a single value.
- scan(IndexScanType, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- scan(IndexScanType, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainer
- scan(IndexScanType, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- scan(IndexScanType, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainer
- scan(IndexScanType, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexMaintainer
- 
Scan this index between a range of tokens.
- scan(IndexScanType, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainer
- scan(IndexScanType, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.VersionIndexMaintainer
- scan(IndexScanType, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Scan entries in the index.
- scan(IndexScanType, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- scan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.query.plan.TextScan
- 
Scan the store to produce a cursor of index entries that all satisfy the comparison.
- scan(TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Scan the primary index tree for the given range.
- SCAN_INDEX_KEYS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken scanning the entries of an index.
- SCAN_LIMIT_REACHED - com.apple.foundationdb.record.RecordCursor.NoNextReason
- 
The limit on the number of records to scan was reached.
- SCAN_MILLIS - com.apple.foundationdb.record.logging.TestLogMessageKeys
- SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- SCAN_PROPERTIES - com.apple.foundationdb.record.logging.LogMessageKeys
- SCAN_RECORDS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time taken scanning records directly without any index.
- ScanComparisons - Class in com.apple.foundationdb.record.query.plan
- 
A set ofComparisons.Comparisonfor scanning an index.
- ScanComparisons(List<Comparisons.Comparison>, Set<Comparisons.Comparison>) - Constructor for class com.apple.foundationdb.record.query.plan.ScanComparisons
- ScanComparisons.Builder - Class in com.apple.foundationdb.record.query.plan
- 
A builder forScanComparisons.
- ScanComparisons.ComparisonType - Enum in com.apple.foundationdb.record.query.plan
- 
The type of a comparison.
- scanForType(SyntheticRecordType<?>) - Method in class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
- 
Construct a plan for generating all synthetic records of a given type.
- scanIndex(Index, IndexScanType, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- scanIndex(Index, IndexScanType, TupleRange, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the entries in an index.
- scanIndex(Index, IndexScanType, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- scanIndex(Index, IndexScanType, TupleRange, byte[], ScanProperties, RecordScanLimiter) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Deprecated.because theRecordScanLimitershould be specified as part of theScanPropertiesinstead
- scanIndexRecords(String) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the records pointed to by an index.
- scanIndexRecords(String, IndexScanType, TupleRange, byte[], IndexOrphanBehavior, ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the records pointed to by an index.
- scanIndexRecords(String, IndexScanType, TupleRange, byte[], IndexOrphanBehavior, ScanProperties, RecordScanLimiter) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Deprecated.because theRecordScanLimitershould be specified as part of theScanPropertiesinstead
- scanIndexRecords(String, IndexScanType, TupleRange, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the records pointed to by an index.
- scanIndexRecords(String, IndexScanType, TupleRange, byte[], ScanProperties, RecordScanLimiter) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Deprecated.because theRecordScanLimitershould be specified as part of theScanPropertiesinstead
- scanIndexRecords(String, IsolationLevel) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the records pointed to by an index.
- scanIndexRecordsBetween(String, Object, Object) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the records pointed to by an index between two indexed values.
- scanIndexRecordsEqual(String, Object...) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the records pointed to by an index equal to indexed values.
- scanLeaderboard(TimeWindowLeaderboard, boolean, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- scanLeaderboard(TimeWindowLeaderboard, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- ScanLimitReachedException - Exception in com.apple.foundationdb.record
- 
Exception thrown when a transaction tries to scan more than the allowed number of key-value pairs.
- ScanLimitReachedException(String) - Constructor for exception com.apple.foundationdb.record.ScanLimitReachedException
- SCANNED_SO_FAR - com.apple.foundationdb.record.logging.LogMessageKeys
- ScanNonReadableIndexException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
An exception that can be thrown byFDBRecordStores if they are scanning non-readable indexes.
- ScanProperties - Class in com.apple.foundationdb.record
- 
A group of properties that pertain to a single scan.
- ScanProperties(ExecuteProperties) - Constructor for class com.apple.foundationdb.record.ScanProperties
- 
Creates scan properties.
- ScanProperties(ExecuteProperties, boolean) - Constructor for class com.apple.foundationdb.record.ScanProperties
- 
Creates scan properties.
- ScanProperties(ExecuteProperties, boolean, CursorStreamingMode) - Constructor for class com.apple.foundationdb.record.ScanProperties
- 
Creates scan properties.
- scanRecords(byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the records in the database.
- scanRecords(TupleRange, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the records in the database in a range.
- scanRecords(Tuple, Tuple, EndpointType, EndpointType, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- scanRecords(Tuple, Tuple, EndpointType, EndpointType, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the records in the database in a range.
- scanRecords(Tuple, Tuple, EndpointType, EndpointType, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- scanType - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- scanTypedRecords(RecordSerializer<M>, Tuple, Tuple, EndpointType, EndpointType, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- scanUniquenessViolations(Index) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the list of uniqueness violations for an index for violations with a specific value.
- scanUniquenessViolations(Index, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the list of uniqueness violations for an index for violations with a specific value.
- scanUniquenessViolations(Index, int) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the list of uniqueness violations for an index for violations with a specific value.
- scanUniquenessViolations(Index, Key.Evaluated) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the list of uniqueness violations for an index for violations with a specific value.
- scanUniquenessViolations(Index, Key.Evaluated, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the list of uniqueness violations for an index for violations with a specific value.
- scanUniquenessViolations(Index, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- scanUniquenessViolations(Index, TupleRange, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the list of uniqueness violations identified for an index.
- scanUniquenessViolations(Index, TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
- scanUniquenessViolations(Index, Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the list of uniqueness violations for an index for violations with a specific value.
- scanUniquenessViolations(Index, Tuple, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Scan the list of uniqueness violations for an index for violations with a specific value.
- scanUniquenessViolations(TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- scanUniquenessViolations(TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- scanUniquenessViolations(TupleRange, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Scans through the list of uniqueness violations within the database.
- SCOPED_DIRECTORY_LAYER_CREATE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent adding a new entry to aScopedDirectoryLayer.
- SCOPED_DIRECTORY_LAYER_READ - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent reading an entry from aScopedDirectoryLayer.
- ScopedDirectoryLayer - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
An implementation ofLocatableResolverthat uses the FDB directory layer to keep track of the allocation of strings to integers.
- ScopedDirectoryLayer(FDBDatabase, ResolvedKeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- 
Create a scoped directory layer.
- ScopedDirectoryLayer(FDBRecordContext, KeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- 
Deprecated.
- ScopedInterningLayer - Class in com.apple.foundationdb.record.provider.foundationdb.layers.interning
- 
An implementation ofLocatableResolverthat is backed by theStringInterningLayer.
- ScopedInterningLayer(FDBDatabase, ResolvedKeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- 
Creates a resolver rooted at the providedKeySpacePath.
- ScopedInterningLayer(FDBRecordContext, KeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- 
Deprecated.
- ScopedValue<T> - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
- 
Object to key the forward and reverse directory caches by, two entries should be treated as identical if they attempt to resolve the same string with directory layers that are located at the same path.
- SCORE_FOR_RANK - Static variable in class com.apple.foundationdb.record.FunctionNames
- SCORE_FOR_RANK_ELSE_SKIP - Static variable in class com.apple.foundationdb.record.FunctionNames
- SCORE_FOR_RANK_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- SCORE_FOR_TIME_WINDOW_RANK - Static variable in class com.apple.foundationdb.record.FunctionNames
- SCORE_FOR_TIME_WINDOW_RANK_ELSE_SKIP - Static variable in class com.apple.foundationdb.record.FunctionNames
- ScoredPlan(int, RecordQueryPlan) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
- ScoredPlan(int, RecordQueryPlan, List<QueryComponent>) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
- ScoredPlan(int, RecordQueryPlan, List<QueryComponent>, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
- ScoredPlan(int, RecordQueryPlan, List<QueryComponent>, boolean, Set<RankComparisons.RankComparison>) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
- scoreForRank(IndexMaintainerState, RankedSet, Number, Tuple) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper
- ScoreForRank(String, Function<Tuple, Object>, IndexAggregateFunction, List<Comparisons.Comparison>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.ScoreForRank
- scoreForRankFunction(QueryRecordFunctionWithComparison) - Static method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons
- SECOND_PREFIX - com.apple.foundationdb.record.logging.LogMessageKeys
- SECONDARY - Static variable in class com.apple.foundationdb.record.provider.common.text.TextCollator.Strength
- 
Respect secondary differences, which normally means accents.
- secureRandom - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- secureRandom - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
- SEED - com.apple.foundationdb.record.logging.TestLogMessageKeys
- semanticEquals(Object) - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpression
- 
Overloaded method to callRelationalExpression.semanticEquals(java.lang.Object)with an empty alias map.
- semanticEquals(Object, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.temp.Correlated
- 
Determine equality with respect to an equivalence map betweenCorrelationIdentifiers based on semantic equality: equality of the plan fragments implementing under the given correlation bindings.
- semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- semanticEquals(Object, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpression
- semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.predicates.AndOrPredicate
- semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.predicates.NotPredicate
- semanticHashCode() - Method in interface com.apple.foundationdb.record.query.plan.temp.Correlated
- 
Return a semantic hash code for this object.
- semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefDelegate
- semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- semanticHashCode() - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpression
- semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeElement
- semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.view.ValueElement
- semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- semanticHashCode() - Method in class com.apple.foundationdb.record.query.predicates.AndOrPredicate
- semanticHashCode() - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- semanticHashCode() - Method in class com.apple.foundationdb.record.query.predicates.NotPredicate
- SERIAL_EXECUTE - Static variable in class com.apple.foundationdb.record.ExecuteProperties
- 
A basic set of properties for an unlimited query/scan execution with serializable isolation.
- SERIALIZABLE - com.apple.foundationdb.record.IsolationLevel
- SerializationException(String) - Constructor for exception com.apple.foundationdb.record.metadata.expressions.KeyExpression.SerializationException
- SerializationException(String, Exception) - Constructor for exception com.apple.foundationdb.record.metadata.expressions.KeyExpression.SerializationException
- serialize(RecordMetaData, RecordType, Message, StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.DynamicMessageRecordSerializer
- serialize(RecordMetaData, RecordType, M, StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.MessageBuilderRecordSerializerBase
- serialize(RecordMetaData, RecordType, M, StoreTimer) - Method in interface com.apple.foundationdb.record.provider.common.RecordSerializer
- 
Convert a Protobuf record to bytes.
- serialize(RecordMetaData, RecordType, M, StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- SERIALIZE_PROTOBUF_RECORD - com.apple.foundationdb.record.provider.common.RecordSerializer.Events
- 
The amount of time spent serializing a Protobuf record to bytes.
- serializeEntries(List<Map.Entry<Tuple, List<Integer>>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexBunchedSerializer
- 
Packs an entry list into a single byte array.
- serializeEntry(Tuple, List<Integer>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexBunchedSerializer
- 
Packs a key and value into a byte array.
- serializeKey(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexBunchedSerializer
- 
Packs a key using standardTupleencoding.
- serializer - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- serializeToBytes(Message) - Method in class com.apple.foundationdb.record.provider.common.DynamicMessageRecordSerializer
- serialVersionUID - Static variable in exception com.apple.foundationdb.record.metadata.expressions.BaseKeyExpression.IllegalSubKeyException
- serialVersionUID - Static variable in exception com.apple.foundationdb.record.metadata.expressions.BaseKeyExpression.UnsplittableKeyExpressionException
- SESSION_ID - com.apple.foundationdb.record.logging.LogMessageKeys
- set(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- set(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- set(KeyValue) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- set(String, Object) - Method in class com.apple.foundationdb.record.Bindings.Builder
- SET_READ_VERSION_TO_LAST_SEEN - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of times the read version was taken from the cache of the last seen version.
- setAddedVersion(int) - Method in class com.apple.foundationdb.record.metadata.Index
- 
Set the version at which the index was first added.
- setAddSuppressed(boolean) - Static method in class com.apple.foundationdb.record.logging.CompletionExceptionLogHelper
- 
Change whetherThrowable.addSuppressed(java.lang.Throwable)is used.
- setAllowedIndex(String) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- setAllowedIndexes(Collection<String>) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- 
Define the indexes that the planner can consider when planning the query.
- setAllowIndexRebuilds(boolean) - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Set whether the validator will allow changes to indexes that require rebuilds.
- setAllowMissingFormerIndexNames(boolean) - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Set whether the validator will allow former indexes to drop the name of the index they replace.
- setAllowNoSinceVersion(boolean) - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Set whether the validator will allow new record types to not declare a "since version".
- setAllowNoVersionChange(boolean) - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Set whether the validator will allow the evolved meta-data to have the same version as the old meta-data.
- setAllowOlderFormerIndexAddedVerions(boolean) - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Set whether the validator will allow former indexes to set their added version to something that is older than necessary.
- setAllowUnsplitToSplit(boolean) - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Set whether the validator will allow the meta-data to begin to split long records.
- setAsyncToSyncExceptionMapper(FDBDatabase.ExceptionMapper) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- setAsyncToSyncTimeout(long, TimeUnit) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- setAsyncToSyncTimeout(Function<StoreTimer.Wait, Pair<Long, TimeUnit>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- setAttemptFailedInJoinAsOr(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
- setBinding(String, Object) - Method in class com.apple.foundationdb.record.EvaluationContextBuilder
- 
Bind one name to a value.
- setBlockingInAsyncDetection(BlockingInAsyncDetection) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Controls if calls toFDBDatabase#asyncToSync(FDBStoreTimer, FDBStoreTimer.Wait, CompletableFuture)orFDBRecordContext#asyncToSync(FDBStoreTimer.Wait, CompletableFuture)will attempt to detect when they are being called from within an asynchronous context and how they should react to this fact when they are.
- setBlockingInAsyncDetection(Supplier<BlockingInAsyncDetection>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Provides a supplier that controls if calls toFDBDatabase#asyncToSync(FDBStoreTimer, FDBStoreTimer.Wait, CompletableFuture)orFDBRecordContext#asyncToSync(FDBStoreTimer.Wait, CompletableFuture)will attempt to detect when they are being called from within an asynchronous context and how they should react to this fact when they are.
- setCachedMetaData(RecordMetaData) - Method in interface com.apple.foundationdb.record.provider.foundationdb.MetaDataCache
- 
Cache meta-data object.
- setCachedSerialized(byte[]) - Method in interface com.apple.foundationdb.record.provider.foundationdb.MetaDataCache
- 
Cache serialized meta-data.
- setCheckForDuplicateConditions(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
- setCipherName(String) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- 
Specifies the cipher algorithm used to encrypt or decrypt a record.
- setComplexityThreshold(int) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
- setCompressionLevel(int) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
- 
Compression level to use if compressing.
- setCompressionLevel(int) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- setCompressWhenSerializing(boolean) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
- 
Whether to compress records after serializing.
- setCompressWhenSerializing(boolean) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- setConfigLoader(Function<OnlineIndexer.Config, OnlineIndexer.Config>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the function used by the online indexer to load the mutable configuration parameters on fly.
- setConfiguration(RecordQueryPlannerConfiguration) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- 
Set theRecordQueryPlannerConfigurationfor this planner.
- setContext(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setContext(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set the record context (transaction) to use for the record store.
- setContext(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setContext(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
- setContextConfigBuilder(FDBRecordContextConfig.Builder) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Set the configuration used in record contexts opened by this runner.
- setContextConfigBuilder(FDBRecordContextConfig.Builder) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- setContextConfigBuilder(FDBRecordContextConfig.Builder) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- setContextExecutor(Function<Executor, Executor>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Provides a function that will be invoked when aFDBRecordContextis created, taking as input theExecutorthat is configured for the database, returning theExecutorthat will be used to execute all asynchronous completions produced from theFDBRecordContext.
- setContinuation(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
- setCurrentVersion(FDBRecordContext, int) - Method in interface com.apple.foundationdb.record.provider.foundationdb.MetaDataCache
- 
Update the version used for cache validation.
- setDataArray(byte[]) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.TransformState
- setDataArray(byte[], int, int) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.TransformState
- setDatabase(FDBDatabase) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the database in which to run the indexing.
- setDatacenterId(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- setDatacenterId(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- setDeadlineTimeMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.ReadVersionRecordStoreStateCacheFactory
- 
Set the maximum amount of time to wait for an entry to be loaded.
- setDefaultCursorStreamingMode(CursorStreamingMode) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- 
Set the defaultCursorStreamingModefor newScanProperties.
- setDefaultCursorStreamingMode(CursorStreamingMode) - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Set the defaultCursorStreamingModefor newScanProperties.
- setDeferFetchAfterUnionAndIntersection(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
- setDependencies(Descriptors.FileDescriptor[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Set dependencies upon which record descriptors may depend.
- setDirectory(TimeWindowLeaderboardDirectory) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer.UpdateState
- setDirectoryCacheSize(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- setDirectoryCacheSize(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Sets the number of directory layer entries that will be cached for each database that is produced by the factory.
- setDirtyStoreState(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- setDisallowTypeRenames(boolean) - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Set whether the validator will disallow record types from being renamed.
- setEnableAssertions(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Enables or disables internal correctness assertions for the context, such as validating maximum key and value lengths for all database requests.
- setEncryptionKey(Key) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- 
Specifies the encryption key used to encrypt or decrypt a record.
- setEncryptWhenSerializing(boolean) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
- 
Whether to encrypt records after serializing.
- setEncryptWhenSerializing(boolean) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- 
Whether to encrypt records after serializing.
- setEvolutionValidator(MetaDataEvolutionValidator) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Set the validator used when saving a new version of the meta-data to ensure the new meta-data is a valid evolution of the old meta-data.
- setEvolutionValidator(MetaDataEvolutionValidator) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Set the validator used to compare the local file descriptor to the descriptor included in the meta-data proto.
- setExecutor(Executor) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Sets the executor that will be used for all asynchronous tasks that are produced from operations initiated from databases produced from this factory.
- setExpireAfterAccessMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCacheFactory
- 
Set the number of milliseconds to keep an item in produced caches after it has been accessed.
- setExplored() - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- setExpression(KeyExpression) - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Set the expression that satisfied this filter.
- setExtensionRegistry(ExtensionRegistry) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Set the extension registry used when deserializing meta-data proto messages.
- setFailOnScanLimitReached(boolean) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- 
Set how scan limit reached is handled.
- setFailOnScanLimitReached(boolean) - Method in class com.apple.foundationdb.record.ExecuteProperties
- setFilter(QueryComponent) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- setFirstChild(B, C) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorContinuation
- 
Fill in the Protobuf builder with the information from the first child.
- setFormatVersion(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setFormatVersion(int) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set the storage format version for this store.
- setFormatVersion(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setFormatVersion(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the store format version to use while building the index.
- setHeaderUserField(String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Set the value of a user-settable field in the store header.
- setHeaderUserField(String, ByteString) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Set the value of a user-settable field in the store header.
- setHeaderUserFieldAsync(String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Set the value of a user-settable field in the store header.
- setHeaderUserFieldAsync(String, ByteString) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Set the value of a user-settable field in the store header.
- setHigh(byte[], EndpointType) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
- setHigh(Tuple, EndpointType) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
- setHookForAsyncToSync(Consumer<StoreTimer.Wait>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- setIncreaseLimitAfter(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the number of successful range builds before re-increasing the number of records to process in a single transaction.
- setIncreaseLimitAfter(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config.Builder
- 
Set the number of successful range builds before re-increasing the number of records to process in a single transaction.
- setIndex(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the index to be built.
- setIndex(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the index to be built.
- setIndexMaintainerRegistry(IndexMaintainerRegistry) - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
- 
Set the registry of index maintainers used to validate indexes.
- setIndexMaintainerRegistry(IndexMaintainerRegistry) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setIndexMaintainerRegistry(IndexMaintainerRegistry) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set the registry of index maintainers to be used by the record store.
- setIndexMaintainerRegistry(IndexMaintainerRegistry) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setIndexMaintainerRegistry(IndexMaintainerRegistry) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Set the index registry used for validation.
- setIndexMaintenanceFilter(IndexMaintenanceFilter) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setIndexMaintenanceFilter(IndexMaintenanceFilter) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set theindex filterto be used by the record store.
- setIndexMaintenanceFilter(IndexMaintenanceFilter) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setIndexMaintenanceFilter(IndexMaintenanceFilter) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set theIndexMaintenanceFilterto use while building the index.
- setIndexQueryabilityFilter(IndexQueryabilityFilter) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- 
Set a function that defines whether each index should be used by the query planner.
- setIndexScanPreference(QueryPlanner.IndexScanPreference) - Method in interface com.apple.foundationdb.record.query.plan.QueryPlanner
- 
Set whetherRecordQueryIndexPlanis preferred overRecordQueryScanPlaneven when it does not satisfy any additional conditions.
- setIndexScanPreference(QueryPlanner.IndexScanPreference) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
- 
Set whetherRecordQueryIndexPlanis preferred overRecordQueryScanPlaneven when it does not satisfy any additional conditions.
- setIndexScanPreference(QueryPlanner.IndexScanPreference) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
- setIndexScanPreference(QueryPlanner.IndexScanPreference) - Method in class com.apple.foundationdb.record.query.plan.temp.CascadesPlanner
- setIndexStatePrecondition(OnlineIndexer.IndexStatePrecondition) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set how shouldOnlineIndexer.buildIndexAsync()(or its variations) build the index based on its state.
- setInitialDelayMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Sets the delay ceiling (in milliseconds) that will be applied between attempts to run a transactional database operation.
- setInitialDelayMillis(long) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Sets the delay ceiling (in milliseconds) that will be applied between attempts to run a transactional database operation.
- setInitialDelayMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- setInitialDelayMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the initial delay between transaction retry attempts.
- setInitialDelayMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- setIsolationLevel(IsolationLevel) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- setKeyCount(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- setKeyCount(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- setKeySize(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- setKeySize(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- setKeySpacePath(KeySpacePath) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- 
Sets theKeySpacePathlocation of theFDBRecordStore.
- setKeySpacePath(KeySpacePath) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set the key space path to use for the record store.
- setKeySpacePath(KeySpacePath) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setLastModifiedVersion(int) - Method in class com.apple.foundationdb.record.metadata.Index
- 
Set the version at which the index was changed.
- setLatencyInjector(Function<FDBLatencySource, Long>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Provides a function that computes a latency that should be injected into a specific FDB operation.
- setLeaseLengthMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the lease length in milliseconds if the synchronized session is used.
- setLimit(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the maximum number of records to process in one transaction.
- setLimitsFrom(ExecuteProperties) - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Merge these limits with the ones specified inother, using the limit specified byotherexcept where it is unlimited, in which case the limit from thisExecutePropertiesis used instead.
- setLocalFileDescriptor(Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Set the local meta-data file descriptor.
- setLocalFileDescriptor(Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Sets the local file descriptor.
- setLocalityProvider(FDBLocalityProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Set the locality provider that is used to discover the server location of the keys.
- setLogTransaction(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Set whether transaction is logged to FDB client logs.
- setLow(byte[], EndpointType) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
- setLow(Tuple, EndpointType) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
- setMaintainHistory(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Set whether this store keeps a record of older versions.
- setMapping(FDBRecordContext, String, ResolverResult) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- setMapping(FDBRecordContext, String, ResolverResult) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- setMapping(FDBRecordContext, String, ResolverResult) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- setMapping(FDBRecordContext, String, ResolverResult) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- setMapping(FDBRecordContext, String, ResolverResult) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- setMapping(FDBRecordContext, String, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- setMaxAttempts(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Sets the maximum number of attempts for a database to make when running a retriable transactional operation.
- setMaxAttempts(int) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Sets the maximum number of attempts for a database to make when running a retriable transactional operation.
- setMaxAttempts(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- setMaxAttempts(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the maximum number of transaction retry attempts.
- setMaxAttempts(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- setMaxDelayMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Sets the maximum delay (in milliseconds) that will be applied between attempts to run a transactional database operation.
- setMaxDelayMillis(long) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Sets the maximum delay (in milliseconds) that will be applied between attempts to run a transactional database operation.
- setMaxDelayMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- setMaxDelayMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the maximum delay between transaction retry attempts.
- setMaxDelayMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- setMaxLimit(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config.Builder
- 
Set the maximum number of records to process in one transaction.
- setMaxMillisPerTransaction(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- setMaxRetries(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the maximum number of times to retry a single range rebuild.
- setMaxRetries(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config.Builder
- 
Set the maximum number of times to retry a single range rebuild.
- setMaxRowsPerTransaction(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- setMaxSize(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCacheFactory
- 
Set the maximum number of elements to keep in produced caches.
- setMaxSize(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.ReadVersionRecordStoreStateCacheFactory
- 
Set the maximum number of entries to cache.
- setMaxSuppressedCountIfNotSet(int) - Static method in class com.apple.foundationdb.record.logging.CompletionExceptionLogHelper
- 
Change the maximum number of suppressed exceptions to add to any given exception, if this maximum has not already been set.
- setMaxWriteLimitBytes(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the approximate maximum transaction write size.
- setMdcContext(Map<String, String>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Set the logging context used in record contexts opened by this runner.
- setMdcContext(Map<String, String>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- setMdcContext(Map<String, String>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Set the MDC context.
- setMdcContext(Map<String, String>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the logging context used inOnlineIndexer.buildIndex(boolean).
- setMetaData(RecordMetaDataProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the meta-data to use when indexing.
- setMetaDataProvider(RecordMetaDataProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setMetaDataProvider(RecordMetaDataProvider) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set the provider for the record store's meta-data.
- setMetaDataProvider(RecordMetaDataProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setMetaDataStore(FDBMetaDataStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setMetaDataStore(FDBMetaDataStore) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set theFDBMetaDataStoreto use as the source of meta-data.
- setMetaDataStore(FDBMetaDataStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setMetaDataVersionStamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Update the meta-data version-stamp.
- setNetworkExecutor(Executor) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- setPipelineSizer(FDBRecordStoreBase.PipelineSizer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setPipelineSizer(FDBRecordStoreBase.PipelineSizer) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set theobjectto be used to determine the depth of pipelines run by the record store.
- setPipelineSizer(FDBRecordStoreBase.PipelineSizer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setPrimaryKey(KeyExpression) - Method in class com.apple.foundationdb.record.metadata.RecordTypeBuilder
- setPrimaryKey(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- setPrimaryKeyComponentPositions(int[]) - Method in class com.apple.foundationdb.record.metadata.Index
- 
Set the positions of primary key components within the index key.
- setPriority(FDBTransactionPriority) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Set the priority of transactions opened by this runner.
- setPriority(FDBTransactionPriority) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Set theFDBTransactionPriorityto use when creating a transaction.
- setPriority(FDBTransactionPriority) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the priority of transactions used for this index build.
- setProgressLogIntervalMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the minimum time between successful progress logs when building across transactions.
- setProgressLogIntervalMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config.Builder
- 
Set the minimum time between successful progress logs when building across transactions.
- setRange(KeyRange) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
- setRange(TupleRange) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
- setReadVersion(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- 
Set the read version used by this transaction.
- setReadVersion(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- setRecord(M) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- setRecordCountKey(KeyExpression) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Deprecated.useCOUNTtype indexes instead
- setRecords(RecordMetaDataProto.MetaData) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Deserializes the meta-data proto into the builder.
- setRecords(RecordMetaDataProto.MetaData, boolean) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Deserializes the meta-data proto into the builder.
- setRecords(Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Adds the root file descriptor of theRecordMetaDataand processes the extension options.
- setRecords(Descriptors.FileDescriptor, boolean) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Adds the root file descriptor of theRecordMetaData.
- setRecordsPerSecond(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the maximum number of records to process in a single second.
- setRecordsPerSecond(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config.Builder
- 
Set the maximum number of records to process in a single second.
- setRecordStore(FDBRecordStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the record store that will be used as a template to open record store instances for indexing.
- setRecordStoreBuilder(FDBRecordStore.Builder) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the record store builder that will be used to open record store instances for indexing.
- setRecordType(RecordType) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- setRecordType(String) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- setRecordTypeKey(Object) - Method in class com.apple.foundationdb.record.metadata.RecordTypeBuilder
- setRecordTypeKey(Object) - Method in class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
- setRecordTypeKey(Object) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- setRecordTypes(Collection<RecordType>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the explicit set of record types to be indexed.
- setRecordTypes(Collection<String>) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- setRefreshTimeMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.ReadVersionRecordStoreStateCacheFactory
- 
Set the maximum amount of time to keep an entry in the cache.
- setRemoveDuplicates(boolean) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- setRequiredResults(List<KeyExpression>) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- setResetTime(StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
- 
Set the reset time on the provided timer to the create time of this snapshot.
- setResolverStateRefreshTimeMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- setReturnedRowLimit(int) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- setReturnedRowLimit(int) - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Set the limit on the number of rows that will be returned.
- setReverse(boolean) - Method in class com.apple.foundationdb.record.ScanProperties
- 
Change direction of scans.
- setReverseDirectoryMaxMillisPerTransaction(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
When a reverse directory lookup is performed from aFDBReverseDirectoryCacheand an entry is not found in the cache and, thus, the directory layer must be scanned to find it, this property determines how many milliseconds may be spent scanning the cache within the context of a single transaction, before the transaction is closed and re-opened in order to avoid apast_version.
- setReverseDirectoryRowsPerTransaction(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
When a reverse directory lookup is performed from aFDBReverseDirectoryCacheand an entry is not found in the cache and, thus, the directory layer must be scanned to find it, this property determines how many rows will be scanned within the context of a single transaction, before the transaction is closed and re-opened in order to avoid apast_version.
- setRootSource(Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpression.Builder
- setRunner(FDBDatabaseRunner) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the runner that will be used to call into the database.
- setSatisfied(boolean) - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- 
Set whether this filter has been satisfied.
- setSaveOpenStackTrace(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Set whether stack trace is recorded when context is opened.
- setScannedBytesLimit(long) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- setScannedRecordsLimit(int) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- 
Set the limit on the number of records that may be scanned.
- setScanProperties(ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
- setSecondChild(B, C) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorContinuation
- 
Fill in the Protobuf builder with the information from the second child.
- setSecureRandom(SecureRandom) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
- 
Sets the secure random number generator used during cryptographic operations.
- setSerializer(RecordSerializer<Message>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setSerializer(RecordSerializer<Message>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set theRecordSerializerto use while building the index.
- setSerializer(RecordSerializer<M>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set the serializer used to convert records into byte arrays.
- setSerializer(RecordSerializer<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setShouldCheckContinuationAccess(boolean) - Static method in class com.apple.foundationdb.record.cursors.IllegalContinuationAccessChecker
- setSinceVersion(Integer) - Method in class com.apple.foundationdb.record.metadata.RecordTypeBuilder
- setSize(FDBStoredSizes) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- setSkip(int) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- setSkip(int) - Method in class com.apple.foundationdb.record.ExecuteProperties
- setSort(KeyExpression) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- setSort(KeyExpression, boolean) - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
- setSort(KeyExpression, boolean) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
- setSplit(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- setSplit(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- setSplitLongRecords(boolean) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- setState(ExecuteState) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- setState(ExecuteState) - Method in class com.apple.foundationdb.record.ExecuteProperties
- 
Build a newExecutePropertieswith the givenExecuteState.
- setState(String, IndexState) - Method in class com.apple.foundationdb.record.MutableRecordStoreState
- 
Modify the state of an index in this map.
- setStateCacheability(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Set whether the store state is cacheable.
- setStateCacheabilityAsync(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Set whether the store state is cacheable.
- setStateRefreshTimeMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Set the refresh time for the cachedLocatableResolverstate.
- setStaticMessage(String) - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- setStoreHeader(RecordMetaDataProto.DataStoreInfo) - Method in class com.apple.foundationdb.record.MutableRecordStoreState
- 
Update the store header in this record store state.
- setStoreRecordVersions(boolean) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- setStoreStateCache(FDBRecordStoreStateCache) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Set the store state cache for this database.
- setStoreStateCache(FDBRecordStoreStateCache) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setStoreStateCache(FDBRecordStoreStateCache) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set the store state cache to be used by the record store.
- setStoreStateCache(FDBRecordStoreStateCache) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setStoreStateCacheFactory(FDBRecordStoreStateCacheFactory) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Set the store state cache factory.
- setStreamingMode(CursorStreamingMode) - Method in class com.apple.foundationdb.record.ScanProperties
- 
Set cursor streaming mode.
- setSubspace(Subspace) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setSubspace(Subspace) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set the subspace to use for the record store.
- setSubspace(Subspace) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setSubspace(Subspace) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the subspace of the record store in which to build the index.
- setSubspaceKey(Object) - Method in class com.apple.foundationdb.record.metadata.Index
- 
Set the key used to determine this index's subspace prefix.
- setSubspaceKeyCounter(long) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Set the initial value of the subspace key counter.
- setSubspaceProvider(SubspaceProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setSubspaceProvider(SubspaceProvider) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set the subspace provider from a subspace provider.
- setSubspaceProvider(SubspaceProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setSubspaceProvider(SubspaceProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the subspace of the record store in which to build the index.
- setTimeLimit(long) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
- setTimer(FDBStoreTimer) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Set the timer used in record contexts opened by this runner.
- setTimer(FDBStoreTimer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Set the timer to use when instrumenting events.
- setTimer(FDBStoreTimer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- setTimer(FDBStoreTimer) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the timer used inOnlineIndexer.buildIndex(boolean).
- setTrace(String, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Configure the client trace directory and log group.
- setTraceFormat(FDBTraceFormat) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Set the output format for the client trace logs.
- setTrackLastSeenVersion(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- setTrackLastSeenVersion(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- setTrackLastSeenVersionOnCommit(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- setTrackLastSeenVersionOnRead(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- setTrackOpen(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Set whether open context is tracked in the associatedFDBDatabase.
- setTrackProgress(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set whether or not to track the index build progress by updating the number of records successfully scanned and processed.
- setTransactionId(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Set the transaction ID to use within FDB logs.
- setTransactionIsTracedSupplier(Supplier<Boolean>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Use transactionIsTracedSupplier to control whether a newly created transaction should be traced or not.
- setTransactionTimeoutMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Set the transaction timeout time in milliseconds.
- setTransactionTimeoutMillis(long) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Set the transaction timeout for all transactions started by this runner.
- setTransactionTimeoutMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Set the transaction timeout time in milliseconds.
- setUnclosedWarning(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- setUnionField(RecordMetaData, RecordType, B, M) - Method in class com.apple.foundationdb.record.provider.common.MessageBuilderRecordSerializerBase
- setUnionField(RecordMetaData, RecordType, B, M) - Method in class com.apple.foundationdb.record.provider.common.TypedRecordSerializer
- setUnionField(RecordMetaData, RecordType, Message.Builder, Message) - Method in class com.apple.foundationdb.record.provider.common.MessageBuilderRecordSerializer
- setUntypedSerializer(RecordSerializer<Message>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- 
Get the serializer that will be used by the underlying record store for non-typed operations such as building indexes.
- setUpdateTimestamp(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- setUserVersionChecker(FDBRecordStoreBase.UserVersionChecker) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- setUserVersionChecker(FDBRecordStoreBase.UserVersionChecker) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Set thefunctionto be used to check the meta-data version of the record store.
- setUserVersionChecker(FDBRecordStoreBase.UserVersionChecker) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- setUseSynchronizedSession(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set whether or not to use a synchronized session when usingOnlineIndexer.buildIndexAsync()(or its variations) to build the index across multiple transactions.
- setValueSize(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- setValueSize(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- setVersion(int) - Method in class com.apple.foundationdb.record.metadata.Index
- 
Deprecated.
- setVersion(int) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- setVersion(FDBRecordVersion) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- setVersionedInline(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
- setVersionedInline(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- setWarnAndCloseOpenContextsAfterSeconds(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Set whether to warn and close record contexts open for too long.
- setWeakReadSemantics(FDBDatabase.WeakReadSemantics) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Set the read semantics used in record contexts opened by this runner.
- setWeakReadSemantics(FDBDatabase.WeakReadSemantics) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
- 
Set theFDBDatabase.WeakReadSemanticsto use when creating a transaction.
- setWeakReadSemantics(FDBDatabase.WeakReadSemantics) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- 
Set the acceptable staleness bounds for transactions used by this build.
- setWindow(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- setWindow(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- setWindow(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- setWindow(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
- setWindow(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- setWindow(FDBRecordContext, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- setWriteLimitBytes(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config.Builder
- 
Set the maximum transaction size in a single transaction.
- SHOULD_BUILD_INDEX - com.apple.foundationdb.record.logging.LogMessageKeys
- SHOULD_CLEAR_EXISTING_DATA - com.apple.foundationdb.record.logging.LogMessageKeys
- SHOULD_MARK_READABLE - com.apple.foundationdb.record.logging.LogMessageKeys
- shouldAttemptFailedInJoinAsOr() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
- 
Get whether the query planner should attempt to transform IN predicates that can't be implemented using aRecordQueryInJoinPlaninto an equivalent OR of equality predicates, which might be plannable as a union.
- shouldCheckForDuplicateConditions() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
- 
Get whether normalization of query conditions should check for redundant conditions.
- shouldDeferFetchAfterUnionAndIntersection() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
- shouldVisit(ExpressionRef<? extends RelationalExpression>) - Method in interface com.apple.foundationdb.record.query.plan.temp.PlannerProperty
- 
Return whether the property should visit the given reference and, transitively, the members of the reference.
- shouldVisit(Quantifier) - Method in interface com.apple.foundationdb.record.query.plan.temp.PlannerProperty
- 
Return whether the property should visit the given quantifier and the references that the quantifier ranges over.
- shouldVisit(RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.temp.PlannerProperty
- 
Return whether the property should visit the subgraph rooted at the given expression.
- show(boolean) - Method in interface com.apple.foundationdb.record.query.plan.temp.RelationalExpression
- 
This is needed for graph integration into IntelliJ as IntelliJ only ever evaluates selfish methods.
- show(boolean, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.temp.explain.PlannerGraphProperty
- 
Show the planner expression that is passed in as a graph rendered in your default browser.
- shutdown() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- SimpleComparison(Comparisons.Type, Object) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
- SingleKeyUnsplitter(FDBRecordContext, Tuple, Subspace, AsyncIterator<KeyValue>, SplitHelper.SizeInfo) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SingleKeyUnsplitter
- singleRecordTypeWithPrefixKey(Map<Index, List<RecordType>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- size() - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- size() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Get the length of the path.
- size() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Get the length of the path.
- size() - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator.AllocationWindow
- size() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- size() - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- size() - Method in class com.apple.foundationdb.record.query.plan.temp.RelationalExpressionPointerSet
- SizeInfo() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
- SizeStatisticsCollectorCursor - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
- 
A cursor that collects various distribution statistics on the keys and values within a record store or within an index.
- SizeStatisticsCollectorCursor.SizeStatisticsResults - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
- 
Encapsulates the distribution statistics returned by a SizeStatisticsCollectorCursor.
- skip - Variable in class com.apple.foundationdb.record.ExecuteProperties
- skip(int) - Method in interface com.apple.foundationdb.record.query.plan.temp.TopologicalSort.TopologicalOrderPermutationIterator
- 
Instructs the iterator to advance to the next possible ordering using the given zero-indexed level.
- skip(int) - Method in interface com.apple.foundationdb.record.RecordCursor
- 
Get a new cursor that skips the given number of records.
- SKIP - com.apple.foundationdb.record.provider.foundationdb.IndexOrphanBehavior
- 
Silently ignore the index entry.
- SKIP_INDEX_ENTRY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent maintaining an index when an entry is skipped by theIndexMaintenanceFilter.
- SKIP_INDEX_RECORD - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent maintaining an index when the entire record is skipped by theIndexMaintenanceFilter.
- SkipCursor<T> - Class in com.apple.foundationdb.record.cursors
- 
A cursor that skips a specified number of initial elements.
- SkipCursor(RecordCursor<T>, int) - Constructor for class com.apple.foundationdb.record.cursors.SkipCursor
- skipThenLimit(int, int) - Method in interface com.apple.foundationdb.record.RecordCursor
- skipUpdateForUnchangedKeys() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- skipUpdateForUnchangedKeys() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- snapshot - Variable in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- snapshot() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- SNAPSHOT - com.apple.foundationdb.record.IsolationLevel
- SOME - com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter.IndexValues
- SORT - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- sortByClauses() - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
- sortReverse - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- SortToIndexRule - Class in com.apple.foundationdb.record.query.plan.temp.rules
- 
A rule for implementing aLogicalSortExpressionas a scan of any appropriately-ordered index.
- SortToIndexRule() - Constructor for class com.apple.foundationdb.record.query.plan.temp.rules.SortToIndexRule
- sortValues(List<Object>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- sortValuesNeeded - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- Source - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
A source represents a stream of entities that can be used to generateElements, such as records or field values.
- Source() - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.Source
- Source(Set<Source>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.Source
- SOURCE_EXHAUSTED - com.apple.foundationdb.record.RecordCursor.NoNextReason
- 
The underlying scan, irrespective of any limit, has reached the end.
- SourceEntry - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
A single entity produced by a source from a record, mapping each (inclusive) dependant source to a concrete value.
- sources() - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- 
Returns the set ofCorrelationIdentifiers that are mapped by thisAliasMap.
- SPATIAL_INDEX_SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- split(int) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- SPLIT_LONG_RECORDS - com.apple.foundationdb.record.logging.TestLogMessageKeys
- SPLIT_NEXT_INDEX - com.apple.foundationdb.record.logging.LogMessageKeys
- SPLIT_RANGES - com.apple.foundationdb.record.logging.LogMessageKeys
- SPLIT_RECORD_SIZE - Static variable in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper
- 
If a record is greater than this size (in bytes), it will be split into multiple kv pairs.
- SPLIT_REVERSE - com.apple.foundationdb.record.logging.LogMessageKeys
- SplitHelper - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Helper classes for splitting records across multiple key-value pairs.
- SplitHelper.FoundSplitWithoutStartException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown when only part of a split record is found.
- SplitHelper.KeyValueUnsplitter - Class in com.apple.foundationdb.record.provider.foundationdb
- 
This cursor may exceed out-of-band limits in order to ensure that it only ever stops in between (split) records.
- SplitHelper.SingleKeyUnsplitter - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Unsplit a single record from a given range scan.
- SplitHelper.SizeInfo - Class in com.apple.foundationdb.record.provider.foundationdb
- 
Accumulator for key-value sizes while loading / saving split records.
- splitIndexBuildRange(int, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Split the index build range to support building an index across multiple transactions in parallel if needed.
- SplitKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
Turn a key with repeated single values into multipleKey.Evaluatedcontaining several of the values.
- SplitKeyExpression(KeyExpression, int) - Constructor for class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- SplitKeyExpression(RecordMetaDataProto.Split) - Constructor for class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- StandardIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
Base class forIndexMaintainerimplementation.
- StandardIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- START - Static variable in class com.apple.foundationdb.record.RecordCursorStartContinuation
- START_SPLIT_RECORD - Static variable in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper
- 
Minimum index used when a record is split.
- START_TUPLE - com.apple.foundationdb.record.logging.LogMessageKeys
- startingFrom(long) - Static method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator.AllocationWindow
- STARTS_WITH - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- startSession(Subspace, long, FDBDatabaseRunnerImpl) - Static method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- 
Synchronous/blocking version ofSynchronizedSessionRunner.startSessionAsync(Subspace, long, FDBDatabaseRunnerImpl).
- startSessionAsync(Subspace, long, FDBDatabaseRunnerImpl) - Static method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- 
Produces a new runner, wrapping a given runner, which performs all work in the context of a newSynchronizedSession.
- startsWith(String) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Checks if the field starts with the given string.
- startsWith(String) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field starts with the given string.
- startsWith(String) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
- 
Checks if the key expression starts with the given string.
- startSynchronizedSession(Subspace, long) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Synchronous/blocking version ofFDBDatabaseRunner.startSynchronizedSessionAsync(Subspace, long).
- startSynchronizedSession(Subspace, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- startSynchronizedSession(Subspace, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- startSynchronizedSessionAsync(Subspace, long) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
- 
Produces a new runner, wrapping this runner, which performs all work in the context of a newSynchronizedSession.
- startSynchronizedSessionAsync(Subspace, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunnerImpl
- startSynchronizedSessionAsync(Subspace, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
- state - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- stopOngoingOnlineIndexBuilds() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Synchronous/blocking version ofOnlineIndexer.stopOngoingOnlineIndexBuildsAsync().
- stopOngoingOnlineIndexBuilds(FDBRecordStore, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Stop any ongoing online index build (only if it usesSynchronizedSessions) by forcefully releasing the lock.
- stopOngoingOnlineIndexBuildsAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Stop any ongoing online index build (only if it usesSynchronizedSessions) by forcefully releasing the lock.
- store - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
- STORE_INFO - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- STORE_INFO_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- STORE_STATE_CACHE_HIT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of times the store state cache returned a cached result.
- STORE_STATE_CACHE_MISS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of times the store state cache was unable to return a cached result.
- stored(FDBStoredRecord<M>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
- STORED_VERSION - com.apple.foundationdb.record.logging.LogMessageKeys
- storedRecordTypesForIndex(Index, Collection<RecordType>) - Method in class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
- 
Determine what stored record types would be need to scanned in order to rebuild a given index.
- storeHeader - Variable in class com.apple.foundationdb.record.RecordStoreState
- StoreRecordFunction<T> - Class in com.apple.foundationdb.record.metadata
- 
Record function that should be evaluated for some record against anFDBRecordStoreBaseinstance.
- StoreRecordFunction(String) - Constructor for class com.apple.foundationdb.record.metadata.StoreRecordFunction
- storeStateCache - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- StoreTimer - Class in com.apple.foundationdb.record.provider.common
- 
A context-wide accumulator of timing information.
- StoreTimer() - Constructor for class com.apple.foundationdb.record.provider.common.StoreTimer
- StoreTimer.Aggregate - Interface in com.apple.foundationdb.record.provider.common
- 
An aggregate event is an event whose value is computed over the value of another set of events.
- StoreTimer.Count - Interface in com.apple.foundationdb.record.provider.common
- 
StoreTimer.Events that only count occurrences or total size.
- StoreTimer.Counter - Class in com.apple.foundationdb.record.provider.common
- 
Contains the number of occurrences and cummulative time spent on an associatedStoreTimer.Event.
- StoreTimer.DetailEvent - Interface in com.apple.foundationdb.record.provider.common
- 
StoreTimer.Events that are a significant part of a larger process.
- StoreTimer.Event - Interface in com.apple.foundationdb.record.provider.common
- 
An identifier for occurrences that need to be timed.
- StoreTimer.Wait - Interface in com.apple.foundationdb.record.provider.common
- 
StoreTimer.Events that can be waited on.
- StoreTimerSnapshot - Class in com.apple.foundationdb.record.provider.common
- 
An immutable snapshot of aStoreTimer.
- StoreTimerSnapshot.CounterSnapshot - Class in com.apple.foundationdb.record.provider.common
- 
An immutable snapshot of aStoreTimer.Counter.
- STRING - com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- stringHashUnordered(Iterable<String>) - Static method in interface com.apple.foundationdb.record.PlanHashable
- StringInterningLayer - Class in com.apple.foundationdb.record.provider.foundationdb.layers.interning
- 
A persistent bidirectional unique mapping between strings and integers.
- StringInterningLayer(Subspace) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- StringInterningLayer(Subspace, boolean) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- structuralEquals(Object) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
- 
Overloaded method to determine structural equality between two different plans using an emptyAliasMap.
- structuralEquals(Object) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical
- structuralEquals(Object, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
- 
Determine if two plans are structurally equal.
- structuralHashCode() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
- 
Return a hash code for this plan which is defined based on the structural layout of a plan.
- structuralHashCode() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical
- SUBDIRECTORY - com.apple.foundationdb.record.logging.LogMessageKeys
- subdirs - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- subdirsByName - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- subFilter() - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
- subKey(int, int) - Method in class com.apple.foundationdb.record.IndexEntry
- 
Produces a newIndexEntrywhose key is a subset of thisIndexEntry.
- subKey(int, int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- SUBSPACE - com.apple.foundationdb.record.logging.LogMessageKeys
- SUBSPACE_KEY - com.apple.foundationdb.record.logging.LogMessageKeys
- subspaceProvider - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- subspaceProvider - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
- SubspaceProvider - Interface in com.apple.foundationdb.record.provider.foundationdb
- 
Subspace provider can provide a subspace (might be blocking) and logging information to the subspace (non-blocking).
- SubspaceProviderByKeySpacePath - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A SubspaceProvider wrapping a key space path.
- SubspaceProviderBySubspace - Class in com.apple.foundationdb.record.provider.foundationdb
- 
A SubspaceProvider wrapping a subspace.
- SubspaceProviderBySubspace(Subspace) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderBySubspace
- SUM - Static variable in class com.apple.foundationdb.record.FunctionNames
- SUM - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
A total of a long-valued field.
- SUM_LONG - com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- supportsSourceIn(ViewExpressionComparisons, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeSource
- supportsSourceIn(ViewExpressionComparisons, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RepeatedFieldSource
- supportsSourceIn(ViewExpressionComparisons, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.Source
- 
Check whether this source can be replaced by the given source in the givenViewExpressionComparisons.
- SynchronizedSessionRunner - Class in com.apple.foundationdb.record.provider.foundationdb.synchronizedsession
- 
AnFDBDatabaseRunnerimplementation that performs all work in the context of aSynchronizedSession.
- SYNTHETIC_RECORD_JOIN - Static variable in class com.apple.foundationdb.record.PipelineOperation
- syntheticIndex - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- SyntheticRecordFromStoredRecordPlan - Interface in com.apple.foundationdb.record.query.plan.synthetic
- 
A plan for deriving synthetic records from a given record.
- SyntheticRecordPlan - Interface in com.apple.foundationdb.record.query.plan.synthetic
- 
A plan for generating synthetic records without an explicit starting point.
- SyntheticRecordPlanner - Class in com.apple.foundationdb.record.query.plan.synthetic
- 
A planner forSyntheticRecordPlanandSyntheticRecordFromStoredRecordPlanplans.
- SyntheticRecordPlanner(FDBRecordStore) - Constructor for class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
- 
Initialize a new planner.
- SyntheticRecordPlanner(RecordMetaData, RecordStoreState) - Constructor for class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
- 
Initialize a new planner.
- SyntheticRecordType<C extends SyntheticRecordType.Constituent> - Class in com.apple.foundationdb.record.metadata
- 
A synthetic record type is made up of other record types and not actually stored separately in the record store.
- SyntheticRecordType(RecordMetaData, Descriptors.Descriptor, KeyExpression, Object, List<Index>, List<Index>, List<C>) - Constructor for class com.apple.foundationdb.record.metadata.SyntheticRecordType
- SyntheticRecordType.Constituent - Class in com.apple.foundationdb.record.metadata
- 
A constituent type of the synthetic record type.
- SyntheticRecordTypeBuilder<C extends SyntheticRecordTypeBuilder.Constituent> - Class in com.apple.foundationdb.record.metadata
- 
A builder forSyntheticRecordType.
- SyntheticRecordTypeBuilder(String, Object, RecordMetaDataBuilder) - Constructor for class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
- SyntheticRecordTypeBuilder.Constituent - Class in com.apple.foundationdb.record.metadata
- 
A constituent type within a joined record type.
- SYSTEM_IMMEDIATE - com.apple.foundationdb.record.provider.foundationdb.FDBTransactionPriority
- 
The priority level for system operations.
T
- TABLE_FUNCTION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- takenAfterReset(StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
- 
Determine if this snapshot was taken after the provided timer was last reset.
- targets() - Method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
- 
Returns the set of allCorrelationIdentifiers that this map maps to using the set ofCorrelationIdentifiers returned byAliasMap.sources().
- TEMPORARY_BUFFER_DATA - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- TERTIARY - Static variable in class com.apple.foundationdb.record.provider.common.text.TextCollator.Strength
- 
Respect tertiary differences, which normally means case.
- test(CorrelationIdentifier, CorrelationIdentifier, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.temp.AliasMap.MatchingIdPredicate
- test(Quantifier, Quantifier, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.temp.Quantifiers.MatchingPredicate
- TEST - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
- TestLogMessageKeys - Enum in com.apple.foundationdb.record.logging
- 
CommonKeyValueLogMessagekeys logged by the Record Layer core.
- text() - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Query where the value of this field matches some property when performing a full-text search.
- text() - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field matches some property when performing a full-text search.
- text(String) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Query where the value of this field matches some property when performing a full-text search.
- text(String) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field matches some property when performing a full-text search.
- text(String, String) - Method in class com.apple.foundationdb.record.query.expressions.Field
- 
Query where the value of this field matches some property when performing a full-text search.
- text(String, String) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThem
- 
Checks if one of the values in this repeated field matches some property when performing a full-text search.
- Text - Class in com.apple.foundationdb.record.query.expressions
- 
Predicates that can be applied to a field that has been indexed with a full-text index.
- TEXT - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
An index on the tokens in a text field.
- TEXT_ADD_AGGRESSIVE_CONFLICT_RANGES_OPTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
If"true", aIndexTypes.TEXTindex will add a conflict range for the whole index to keep the commit size down at the expense of more conflicts.
- TEXT_CONTAINS_ALL - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- TEXT_CONTAINS_ALL_PREFIXES - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- TEXT_CONTAINS_ALL_WITHIN - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- TEXT_CONTAINS_ANY - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- TEXT_CONTAINS_ANY_PREFIX - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- TEXT_CONTAINS_PHRASE - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- TEXT_CONTAINS_PREFIX - com.apple.foundationdb.record.query.expressions.Comparisons.Type
- TEXT_INDEX_SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- TEXT_INDEX_SIZE_AMORTIZED - com.apple.foundationdb.record.logging.LogMessageKeys
- TEXT_INDEX_UPDATE - Static variable in class com.apple.foundationdb.record.PipelineOperation
- TEXT_KEY_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
- TEXT_OMIT_POSITIONS_OPTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
If"true", aIndexTypes.TEXTindex will not store position numbers for tokens.
- TEXT_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
- TEXT_TOKENIZER_NAME_OPTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
The name of theTextTokenizerto use with aIndexTypes.TEXTindex.
- TEXT_TOKENIZER_VERSION_OPTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
The version of theTextTokenizerto use with aIndexTypes.TEXTindex.
- TEXT_VALUE_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
- TextCollator - Interface in com.apple.foundationdb.record.provider.common.text
- 
An interface for locale-sensitive text comparison and sorting.
- TextCollator.Strength - Class in com.apple.foundationdb.record.provider.common.text
- 
Standard strength values.
- TextCollatorJRE(Collator) - Constructor for class com.apple.foundationdb.record.provider.common.text.TextCollatorRegistryJRE.TextCollatorJRE
- TextCollatorRegistry - Interface in com.apple.foundationdb.record.provider.common.text
- 
Registry forTextCollators.
- TextCollatorRegistryJRE - Class in com.apple.foundationdb.record.provider.common.text
- 
A text collator registry using the Java Platform's ownCollatorimplementation.
- TextCollatorRegistryJRE.TextCollatorJRE - Class in com.apple.foundationdb.record.provider.common.text
- TextComparison(Comparisons.Type, String, String, String) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- TextComparison(Comparisons.Type, List<String>, String, String) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- TextContainsAllPrefixesComparison(String, boolean, long, double, String, String) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
- TextContainsAllPrefixesComparison(String, boolean, String, String) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
- TextContainsAllPrefixesComparison(List<String>, boolean, long, double, String, String) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
- TextContainsAllPrefixesComparison(List<String>, boolean, String, String) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
- TextIndexBunchedSerializer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
Serializer used by theTextIndexMaintainerto write entries into aBunchedMap.
- TextIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
The index maintainer class for full-text indexes.
- TextIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexMaintainer
- TextIndexMaintainerFactory - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
Supplier ofTextIndexMaintainers, that is, of index maintainers for the full text index type.
- TextIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexMaintainerFactory
- TextScan - Class in com.apple.foundationdb.record.query.plan
- 
Encapsulate the information necessary to scan a text-based index.
- TextScan(Index, ScanComparisons, Comparisons.TextComparison, ScanComparisons) - Constructor for class com.apple.foundationdb.record.query.plan.TextScan
- TextScanPlanner - Class in com.apple.foundationdb.record.query.plan.planning
- 
A utility class for choosing aTextScanobject to satisfy a text query.
- TextTokenizer - Interface in com.apple.foundationdb.record.provider.common.text
- 
An interface to tokenize text fields.
- TextTokenizer.TokenizerMode - Enum in com.apple.foundationdb.record.provider.common.text
- 
Mode that can be used to alter tokenizer behavior depending on the the context its used in.
- TextTokenizerFactory - Interface in com.apple.foundationdb.record.provider.common.text
- 
Each implementation ofTextTokenizershould have its own implementation of this factory interface to provide instances of the tokenizer to aTextTokenizerRegistry.
- TextTokenizerRegistry - Interface in com.apple.foundationdb.record.provider.common.text
- 
Registry forTextTokenizers.
- TextTokenizerRegistryImpl - Class in com.apple.foundationdb.record.provider.common.text
- 
Default implementation of theTextTokenizerRegistry.
- TextWithMaxDistanceComparison(String, int, String, String) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.TextWithMaxDistanceComparison
- TextWithMaxDistanceComparison(List<String>, int, String, String) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.TextWithMaxDistanceComparison
- ThenKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
Combine keys from two or more child keys.
- ThenKeyExpression(KeyExpression, KeyExpression, KeyExpression...) - Constructor for class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- ThenKeyExpression(RecordMetaDataProto.Then) - Constructor for class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- ThenKeyExpression(List<KeyExpression>) - Constructor for class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- ThenKeyExpression(List<KeyExpression>, int, int) - Constructor for class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- throwExceptionOnBlocking() - Method in enum com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
- 
Indicates how to react if the future passed intoasyncToSync()has not yet been completed.
- TIME_ENDED - com.apple.foundationdb.record.logging.LogMessageKeys
- TIME_LIMIT - com.apple.foundationdb.record.logging.LogMessageKeys
- TIME_LIMIT_REACHED - com.apple.foundationdb.record.RecordCursor.NoNextReason
- 
The limit on the amount of time that a scan can take was reached.
- TIME_STARTED - com.apple.foundationdb.record.logging.LogMessageKeys
- TIME_UNIT - com.apple.foundationdb.record.logging.LogMessageKeys
- TIME_WINDOW_COUNT - Static variable in class com.apple.foundationdb.record.FunctionNames
- TIME_WINDOW_LEADERBOARD - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
An index with sliding time window leaderboards.
- TIME_WINDOW_LEADERBOARD_ADD_WINDOW - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of times that a leaderboard update adds a time window.
- TIME_WINDOW_LEADERBOARD_DELETE_WINDOW - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of times that a leaderboard update deleted a time window.
- TIME_WINDOW_LEADERBOARD_GET_DIRECTORY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent inTimeWindowLeaderboardDirectoryOperation.
- TIME_WINDOW_LEADERBOARD_GET_SUB_DIRECTORY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent inTimeWindowLeaderboardSubDirectoryOperation.
- TIME_WINDOW_LEADERBOARD_OVERLAPPING_CHANGED - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
The number of times that a leaderboard needs to be rebuilt because a window was added after a score it should contain.
- TIME_WINDOW_LEADERBOARD_SAVE_SUB_DIRECTORY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent inTimeWindowLeaderboardSaveSubDirectory.
- TIME_WINDOW_LEADERBOARD_TRIM_SCORES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent inTimeWindowLeaderboardScoreTrim.
- TIME_WINDOW_LEADERBOARD_UPDATE_DIRECTORY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The amount of time spent inTimeWindowLeaderboardWindowUpdate.
- TIME_WINDOW_RANK - Static variable in class com.apple.foundationdb.record.FunctionNames
- TIME_WINDOW_RANK_AND_ENTRY - Static variable in class com.apple.foundationdb.record.FunctionNames
- TIME_WINDOW_RANK_FOR_SCORE - Static variable in class com.apple.foundationdb.record.FunctionNames
- timeoutCounters - Variable in class com.apple.foundationdb.record.provider.common.StoreTimer
- TIMEOUTS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
The total number of timeouts that have happened during asyncToSync and their durations.
- timer - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- timeReadSampleKey(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- TimeScanLimiter - Class in com.apple.foundationdb.record
- 
Track time remaining until a given time limit, after which record scans should not be allowed.
- TimeScanLimiter(long, long) - Constructor for class com.apple.foundationdb.record.TimeScanLimiter
- TimeWindowAggregateFunction - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Evaluate aggregate functions in a certain time window.
- TimeWindowAggregateFunction(String, KeyExpression, String, TimeWindowForFunction) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowAggregateFunction
- TimeWindowForFunction - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Additional function arguments for time window.
- TimeWindowForFunction(int, long, String, String) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- TimeWindowLeaderboard - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
A single leaderboard, representing ranks within a time window.
- TimeWindowLeaderboard(TimeWindowLeaderboardDirectory, int, long, long, Tuple, int) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- TimeWindowLeaderboard(TimeWindowLeaderboardDirectory, TimeWindowLeaderboardProto.TimeWindowLeaderboard) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- TimeWindowLeaderboardDirectory - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
The persisted set of active leaderboard ranked sets.
- TimeWindowLeaderboardDirectory(boolean) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- TimeWindowLeaderboardDirectory(TimeWindowLeaderboardProto.TimeWindowLeaderboardDirectory) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- TimeWindowLeaderboardDirectoryOperation - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Get the current directory.
- TimeWindowLeaderboardDirectoryOperation() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectoryOperation
- TimeWindowLeaderboardDirectoryResult - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Currently saved directory.
- TimeWindowLeaderboardDirectoryResult(TimeWindowLeaderboardDirectory) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectoryResult
- TimeWindowLeaderboardIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Maintainer for theTIME_WINDOW_LEADERBOARDindex type.
- TimeWindowLeaderboardIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- TimeWindowLeaderboardIndexMaintainer.UpdateState - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- TimeWindowLeaderboardIndexMaintainerFactory - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Factory for theTIME_WINDOW_LEADERBOARDindex type.
- TimeWindowLeaderboardIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainerFactory
- TimeWindowLeaderboardSaveSubDirectory - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Save a subdirectory to specify direction.
- TimeWindowLeaderboardSaveSubDirectory(TimeWindowLeaderboardSubDirectory) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardSaveSubDirectory
- TimeWindowLeaderboardScoreTrim - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Retain only scores that would be indexed by active time windows.
- TimeWindowLeaderboardScoreTrim(Collection<Tuple>, boolean) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardScoreTrim
- TimeWindowLeaderboardScoreTrimResult - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Scores that would be indexed by active time windows.
- TimeWindowLeaderboardScoreTrimResult(Collection<Tuple>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardScoreTrimResult
- TimeWindowLeaderboardSubDirectory - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Persisted per-group information for leaderboard ranked sets.
- TimeWindowLeaderboardSubDirectory(Tuple, boolean) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardSubDirectory
- TimeWindowLeaderboardSubDirectory(Tuple, TimeWindowLeaderboardProto.TimeWindowLeaderboardSubDirectory) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardSubDirectory
- TimeWindowLeaderboardSubDirectoryOperation - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Get a sub-directory, which presently only contains information about direction.
- TimeWindowLeaderboardSubDirectoryOperation(Tuple) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardSubDirectoryOperation
- TimeWindowLeaderboardSubDirectoryResult - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
A sub-directory, which presently only contains information about direction.
- TimeWindowLeaderboardSubDirectoryResult(TimeWindowLeaderboardSubDirectory) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardSubDirectoryResult
- TimeWindowLeaderboardWindowUpdate - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Maintain active set of time windows.
- TimeWindowLeaderboardWindowUpdate(long, boolean, long, boolean, Iterable<TimeWindowLeaderboardWindowUpdate.TimeWindowSpec>, int, TimeWindowLeaderboardWindowUpdate.Rebuild) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
- 
Create a time window update operation.
- TimeWindowLeaderboardWindowUpdate(long, boolean, long, boolean, Iterable<TimeWindowLeaderboardWindowUpdate.TimeWindowSpec>, TimeWindowLeaderboardWindowUpdate.Rebuild) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
- 
Create a time window update operation.
- TimeWindowLeaderboardWindowUpdate.Rebuild - Enum in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
When to completely rebuild an index.
- TimeWindowLeaderboardWindowUpdate.TimeWindowSpec - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
A specification of a set of sliding time windows.
- TimeWindowLeaderboardWindowUpdateResult - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
Result ofTimeWindowLeaderboardWindowUpdate.
- TimeWindowLeaderboardWindowUpdateResult(boolean, boolean) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdateResult
- timeWindowRank(int, long, GroupingKeyExpression) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
A record function that can be used to determine or compare the rank value for a record for a time window.
- timeWindowRank(int, long, String, String, GroupingKeyExpression) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
A record function that can be used to determine or compare the rank value for a record for a time window.
- timeWindowRank(TimeWindowForFunction, GroupingKeyExpression) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
A record function that can be used to determine or compare the rank value for a record for a time window.
- timeWindowRank(String, String, GroupingKeyExpression) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
A record function that can be used to determine or compare the rank value for a record for a time window.
- timeWindowRankAndEntry(int, long, GroupingKeyExpression) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
A record function that can be used to determine or compare the rank value for a record for a time window and the score entry that determined that rank.
- timeWindowRankAndEntry(int, long, String, String, GroupingKeyExpression) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
A record function that can be used to determine or compare the rank value for a record for a time window and the score entry that determined that rank.
- timeWindowRankAndEntry(EvaluationContext, TimeWindowForFunction, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- timeWindowRankAndEntry(FDBRecord<M>, int, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- timeWindowRankAndEntry(TimeWindowForFunction, GroupingKeyExpression) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
A record function that can be used to determine or compare the rank value for a record for a time window and the score entry that determined that rank.
- timeWindowRankAndEntry(String, String, GroupingKeyExpression) - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
A record function that can be used to determine or compare the rank value for a record for a time window and the score entry that determined that rank.
- TimeWindowRecordFunction<T> - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
- 
TheTIME_WINDOW_RANKrecord function.
- TimeWindowRecordFunction(String, GroupingKeyExpression, String, TimeWindowForFunction) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowRecordFunction
- TimeWindowSpec(int, long, long, long, int) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.TimeWindowSpec
- title() - Method in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Counts
- title() - Method in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Events
- title() - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Event
- 
Get the title of this event for user displays.
- title() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.CountAggregates
- title() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- title() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- title() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- title() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- title() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.Events
- TITLE - com.apple.foundationdb.record.logging.LogMessageKeys
- toAliasToQuantifierMap(Collection<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifiers
- toBuilder() - Method in class com.apple.foundationdb.record.ExecuteProperties
- toBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
- 
Convert the current configuration to a builder.
- toBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Config
- 
To create a builder for the given config.
- toBuilder() - Method in class com.apple.foundationdb.record.query.RecordQuery
- toBytes() - Method in class com.apple.foundationdb.record.ByteArrayContinuation
- toBytes() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorContinuation
- toBytes() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Serializes the version information to a byte array.
- toBytes() - Method in interface com.apple.foundationdb.record.RecordCursorContinuation
- 
Serialize this continuation to a byte array.
- toBytes() - Method in class com.apple.foundationdb.record.RecordCursorEndContinuation
- toBytes() - Method in class com.apple.foundationdb.record.RecordCursorStartContinuation
- toBytes(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Serializes the version information to a byte array.
- toElement(Source) - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
- toElement(Source) - Method in interface com.apple.foundationdb.record.metadata.expressions.QueryableKeyExpression
- toIDMap(BiMap<Quantifier, Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifiers
- 
Convenience helper to create an alias translation map based on a translation map using quantifiers.
- toImmutable() - Method in class com.apple.foundationdb.record.MutableRecordStoreState
- toImmutable() - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Create an immutable version of thisRecordStoreState.
- tokenize(String, int, TextTokenizer.TokenizerMode) - Method in class com.apple.foundationdb.record.provider.common.text.DefaultTextTokenizer
- 
Tokenize the text based on whitespace.
- tokenize(String, int, TextTokenizer.TokenizerMode) - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizer
- 
Create a stream of tokens from the given input text.
- TOKENIZER_NAME - com.apple.foundationdb.record.logging.LogMessageKeys
- tokenizeToList(String, int, TextTokenizer.TokenizerMode) - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizer
- 
Create a list of tokens from the given input text.
- tokenizeToMap(String, int, TextTokenizer.TokenizerMode) - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizer
- 
Create a map from tokens to their offset lists from the given input text.
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- toKeyExpression() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- toKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- toList() - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
Converts to a list.
- toMutable() - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Create a mutable copy of thisRecordStoreState.
- TOO_LARGE_VALUE_MESSAGE_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- toPath() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Convert the resolved path back into aKeySpacePath.
- toPathString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Returns the path that leads up to this directory (including this directory), and returns it as a string that looks something like a filesystem path.
- topologicalOrderPermutations(Set<T>, Function<T, Set<T>>) - Static method in class com.apple.foundationdb.record.query.plan.temp.TopologicalSort
- 
Create aTopologicalSort.TopologicalOrderPermutationIterablebased on a set and a function describing the depends-on relationships between items in the given set.
- TopologicalSort - Class in com.apple.foundationdb.record.query.plan.temp
- 
Utility class to provide helpers related to topological sorts.
- TopologicalSort() - Constructor for class com.apple.foundationdb.record.query.plan.temp.TopologicalSort
- TopologicalSort.TopologicalOrderPermutationIterable<T> - Interface in com.apple.foundationdb.record.query.plan.temp
- 
Iterable that provides special iterators of typeTopologicalSort.TopologicalOrderPermutationIterator.
- TopologicalSort.TopologicalOrderPermutationIterator<T> - Interface in com.apple.foundationdb.record.query.plan.temp
- 
An iterator extendingIteratorproviding the ability to skip a certain prefix.
- toPrintable(Object) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- toProto() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- toProto() - Method in class com.apple.foundationdb.record.metadata.FormerIndex
- toProto() - Method in class com.apple.foundationdb.record.metadata.Index
- toProto() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordType
- toProto() - Method in enum com.apple.foundationdb.record.metadata.Key.Evaluated.NullStandin
- toProto() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorContinuation
- toProto() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
- toProto() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
- toProto() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardSubDirectory
- toProto() - Method in class com.apple.foundationdb.record.RecordMetaData
- 
Serializes the record meta-data to aMetaDataproto message.
- toProto(boolean) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a Javabooleanto a ProtobufNullableBool.
- toProto(double) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a Javadoubleto a ProtobufNullableDouble.
- toProto(float) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a Javafloatto a ProtobufNullableFloat.
- toProto(int) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a Javaintto a ProtobufNullableInt32.
- toProto(long) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a Javalongto a ProtobufNullableInt64.
- toProto(ByteString) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a JavaByteStringto a ProtobufNullableBytes.
- toProto(Descriptors.FileDescriptor[]) - Method in class com.apple.foundationdb.record.RecordMetaData
- 
Serializes the record meta-data to aMetaDataproto message.
- toProto(Object, Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a field's value from aTupleitem to a message.
- toProto(String) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a JavaStringto a ProtobufNullableString.
- toProto(UUID) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
- 
Convert a JavaUUIDto a ProtobufUUID.
- toProtoValue(Object) - Static method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- toRange() - Method in class com.apple.foundationdb.record.TupleRange
- 
Convert into a FoundationDBRange.
- toRange(byte[], byte[], EndpointType, EndpointType) - Static method in class com.apple.foundationdb.record.TupleRange
- 
Convert a pair of endpoints into a FoundationDBRange.
- toRange(Subspace) - Method in class com.apple.foundationdb.record.TupleRange
- 
Convert into a FoundationDBRange.
- toRecord(Descriptors.Descriptor, IndexEntry) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
- toResolvedPath(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Resolves the path into aResolvedKeySpacePath, a form the retains all of the information about the path itself along with the value to which each path entry is resolved.
- toResolvedPathAsync(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Resolves the path into aResolvedKeySpacePath, a form the retains all of the information about the path itself along with the value to which each path entry is resolved.
- toResolvedPathAsync(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- toScanComparisons() - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpressionComparisons
- 
Convert these comparisons toScanComparisonsfor query execution.
- toString() - Method in class com.apple.foundationdb.record.AsyncLoadingCache
- toString() - Method in class com.apple.foundationdb.record.ExecuteProperties
- toString() - Method in class com.apple.foundationdb.record.ExecuteState
- toString() - Method in class com.apple.foundationdb.record.IndexEntry
- toString() - Method in class com.apple.foundationdb.record.IndexScanType
- toString() - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
- toString() - Method in enum com.apple.foundationdb.record.logging.LogMessageKeys
- toString() - Method in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- toString() - Method in class com.apple.foundationdb.record.metadata.FormerIndex
- toString() - Method in class com.apple.foundationdb.record.metadata.Index
- toString() - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- toString() - Method in class com.apple.foundationdb.record.metadata.IndexRecordFunction
- toString() - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- toString() - Method in class com.apple.foundationdb.record.metadata.RecordType
- toString() - Method in class com.apple.foundationdb.record.metadata.StoreRecordFunction
- toString() - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordType
- toString() - Method in class com.apple.foundationdb.record.PipelineOperation
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.Resolved
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree.ResolvedPrefixRoot
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Human-readable representation of thisFDBRecordVersion.
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexBuildState
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingReplicator
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverResult
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedValue
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator.AllocationWindow
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowAggregateFunction
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowRecordFunction
- toString() - Method in interface com.apple.foundationdb.record.provider.foundationdb.SubspaceProvider
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderByKeySpacePath
- toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderBySubspace
- toString() - Method in class com.apple.foundationdb.record.query.expressions.AndComponent
- toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextWithMaxDistanceComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.EmptyComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.NestedField
- toString() - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
- toString() - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
- toString() - Method in class com.apple.foundationdb.record.query.expressions.OrComponent
- toString() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- toString() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- toString() - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- toString() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan.ComposerBase
- toString() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
- toString() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicateFilterPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.ScoreForRank
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
- toString() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.CorrelationIdentifier
- 
Returns the backing string id.
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.FullUnorderedScanExpression
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.expressions.IndexEntrySourceScanExpression
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionPrinter
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.GroupExpressionRef
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.IndexEntrySource
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.PlannerRule
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Physical
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeSource
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.view.RepeatedFieldSource
- toString() - Method in class com.apple.foundationdb.record.query.plan.temp.view.ValueElement
- toString() - Method in class com.apple.foundationdb.record.query.plan.TextScan
- toString() - Method in class com.apple.foundationdb.record.query.predicates.AndPredicate
- toString() - Method in class com.apple.foundationdb.record.query.predicates.ElementPredicate
- toString() - Method in class com.apple.foundationdb.record.query.predicates.NotPredicate
- toString() - Method in class com.apple.foundationdb.record.query.predicates.OrPredicate
- toString() - Method in class com.apple.foundationdb.record.query.RecordQuery
- toString() - Method in class com.apple.foundationdb.record.RecordCursorResult
- toString() - Method in class com.apple.foundationdb.record.RecordStoreState
- 
A human-readable representation of the state.
- toString() - Method in class com.apple.foundationdb.record.ScanProperties
- toString() - Method in class com.apple.foundationdb.record.TupleRange
- toString() - Method in class com.apple.foundationdb.record.ValueRange
- toString(boolean) - Method in enum com.apple.foundationdb.record.EndpointType
- toString(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.SubspaceProvider
- 
This method is typically called in support of error logging; hence, implementations should not assume a workingFDBRecordContextbut might, for example, use it to retrieve a subspace previously resolved against the corresponding database.
- toString(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderByKeySpacePath
- toString(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.SubspaceProviderBySubspace
- toString(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
String representation of thisKeySpacePaththat shows correspondences between original and resolved directory values in accordance with the inputTuple.
- toString(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- toSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- toSubspace(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Converts the tuple produced for this path to a subspace.
- toSubspaceAsync(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Converts the tuple produced for this path to a subspace.
- TOTAL_QUERY_MILLIS - com.apple.foundationdb.record.logging.TestLogMessageKeys
- TOTAL_RESULT_COUNT - com.apple.foundationdb.record.logging.TestLogMessageKeys
- TOTAL_SCAN_MILLIS - com.apple.foundationdb.record.logging.TestLogMessageKeys
- totalSize() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- toTree(Writer) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
- 
Creates a visually pleasing ASCII-art representation of the directory tree.
- toTree(Writer) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Sends the keyspace as an ascii-art tree to an output stream.
- toTuple() - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
Convert this key to the correspondingTuplethat can then be serialized into the database.
- toTuple() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
- 
Converts the resolved path into aTuple.
- toTuple(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Converts this path into a tuple.
- toTupleAppropriateList() - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- 
Converts to a list.
- toTupleAsync(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
- 
Converts this path into a tuple.
- toTupleAsync(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
- toTupleItem(Object) - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- toTupleRange() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- toTupleRange(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- toTupleRangeWithoutContext() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
- toTupleValue(FDBRecordContext, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- toTupleValueAsync(FDBRecordContext, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Asks the directory implementation to "resolve" a tuple value.
- toTupleValueAsyncImpl(FDBRecordContext, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
- toTupleValueAsyncImpl(FDBRecordContext, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
This method is called during the process of turning aKeySpacePathinto aTuple.
- toVersionstamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Converts thisRecordVersioninstance to aVersionstampinstance.
- toVersionstamp(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Converts thisRecordVersioninstance to aVersionstampinstance.
- tracking() - Static method in class com.apple.foundationdb.record.ByteScanLimiterFactory
- 
Creates a limiter that tracks the number of bytes that has been scanned, but does not impose a limit.
- tracking() - Static method in class com.apple.foundationdb.record.RecordScanLimiterFactory
- 
Creates a limiter that tracks the number of records that has been scanned, but does not impose a limit.
- trackOpenContext(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- transaction - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
- transaction - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
- TRANSACTION_ID - com.apple.foundationdb.record.logging.LogMessageKeys
- TransformedRecordSerializer<M extends Message> - Class in com.apple.foundationdb.record.provider.common
- 
ARecordSerializerimplementation that transforms the bytes produced by another serializer before returning (and likewise performs the reverse transformation before deserializing).
- TransformedRecordSerializer(RecordSerializer<M>, boolean, int, boolean) - Constructor for class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- TransformedRecordSerializer.Builder<M extends Message> - Class in com.apple.foundationdb.record.provider.common
- 
Builder class for theTransformedRecordSerializerclass.
- TransformedRecordSerializer.TransformState - Class in com.apple.foundationdb.record.provider.common
- TransformedRecordSerializerJCE<M extends Message> - Class in com.apple.foundationdb.record.provider.common
- 
An extension ofTransformedRecordSerializerto use JCE to encrypt and decrypt records.
- TransformedRecordSerializerJCE(RecordSerializer<M>, boolean, int, boolean, String, Key, SecureRandom) - Constructor for class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
- TransformedRecordSerializerJCE.Builder<M extends Message> - Class in com.apple.foundationdb.record.provider.common
- 
Builder class for theTransformedRecordSerializerJCEclass.
- TransformState(byte[]) - Constructor for class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.TransformState
- TransformState(byte[], int, int) - Constructor for class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.TransformState
- translate(Quantifier, Quantifier) - Static method in class com.apple.foundationdb.record.query.plan.temp.Quantifiers
- 
Convenience helper to create a single ID translation map from the alias of one quantifier to the alias of another quantifier.
- TREE_END - com.apple.foundationdb.record.EndpointType
- TREE_START - com.apple.foundationdb.record.EndpointType
- TriFunction<T,U,V,R> - Interface in com.apple.foundationdb.record.util
- 
Represents a function that accepts three arguments and produces a result.
- trimPrimaryKey(List<?>) - Method in class com.apple.foundationdb.record.metadata.Index
- trimScores(TimeWindowLeaderboardDirectory, Collection<Tuple>, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- trimTooLargeTuple(Tuple) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- tryBuild(RecordQueryPlanner, Collection<String>, IndexAggregateFunction, QueryComponent) - Static method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexAggregate
- 
Try to build a composed bitmap for the given aggregate function and filters.
- tryPlan(RecordQueryPlanner, RecordQuery.Builder) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexAggregate
- 
Try to turn this composed bitmap into an executable plan.
- tryPlan(RecordQueryPlanner, RecordQuery, IndexAggregateFunction) - Static method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexAggregate
- 
Try to build a composed bitmap plan for the given query and aggregate function.
- tryRecordScan() - Method in class com.apple.foundationdb.record.cursors.CursorLimitManager
- 
Inform the limit manager that a cursor is trying to scan a record.
- tryRecordScan() - Method in interface com.apple.foundationdb.record.RecordScanLimiter
- 
Atomically decrement the counter and return false if falls below 0.
- tryRecordScan() - Method in class com.apple.foundationdb.record.TimeScanLimiter
- tryToAdd(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.plan.temp.ComparisonRange
- tryToFillPipeline() - Method in class com.apple.foundationdb.record.cursors.FlatMapPipelinedCursor
- 
Take items from inner cursor and put in pipeline until no more or a mapped cursor item is available.
- tryToFillPipeline() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
- 
Take items from inner cursor and put in pipeline until no more or a mapping result is available.
- TupleFieldsHelper - Class in com.apple.foundationdb.record.metadata.expressions
- 
Static methods for dealing with special field types that are messages in protobuf but single items inTuples.
- TupleRange - Class in com.apple.foundationdb.record
- 
A range within a subspace specified by twoTupleendpoints.
- TupleRange(Tuple, Tuple, EndpointType, EndpointType) - Constructor for class com.apple.foundationdb.record.TupleRange
- TupleRange.ByteStringBoundException - Exception in com.apple.foundationdb.record
- 
Exception thrown when range endpoint is not consistent withCONTINUATIONendpoint type.
- tupleToString(Tuple) - Static method in class com.apple.foundationdb.record.TupleRange
- TYPE_FILTER_DEPTH - Static variable in class com.apple.foundationdb.record.query.plan.temp.properties.RelationalExpressionDepthProperty
- TYPE_FILTER_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- TypedRecordSerializer<M extends Message,U extends Message,B extends Message.Builder> - Class in com.apple.foundationdb.record.provider.common
- 
Serialize records using default Protobuf serialization using supplied message builder for the union message type and two accessors for the message field corresponding to the known record type.
- TypedRecordSerializer(Descriptors.FieldDescriptor, Supplier<B>, Predicate<U>, Function<U, M>, BiConsumer<B, M>) - Constructor for class com.apple.foundationdb.record.provider.common.TypedRecordSerializer
- TypeFilterCountProperty - Class in com.apple.foundationdb.record.query.plan.temp.properties
- 
A property that determines the sum, over all elements of aPlannerExpressiontree, of the number of record types that are passed by type filters in the tree.
- TypeFilterCountProperty() - Constructor for class com.apple.foundationdb.record.query.plan.temp.properties.TypeFilterCountProperty
- TypeFilterExpression - Interface in com.apple.foundationdb.record.query.plan.temp.expressions
- 
A relational planner expression that represents a type filter.
- typelessString() - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
- 
Get the printed representation of the comparison less the comparison operator itself.
- typelessString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
- typelessString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- typelessString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
- typelessString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- typelessString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
- typelessString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- TypeMatcher<T extends Bindable> - Class in com.apple.foundationdb.record.query.plan.temp.matchers
- 
A matcher that is specified by the class of its expression: to match any of several types of expressions, they must all implement a common interface (which itself extendsPlannerExpression).
- TypeMatcher(Class<? extends T>, ExpressionChildrenMatcher) - Constructor for class com.apple.foundationdb.record.query.plan.temp.matchers.TypeMatcher
- typeOf(Object) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- TypeWithPredicateMatcher<T extends RelationalExpressionWithPredicate> - Class in com.apple.foundationdb.record.query.plan.temp.matchers
- 
Matches a subclass ofRelationalExpressionWithPredicatewith a given predicate (as determined byRelationalExpressionWithPredicate.getPredicate()and a given matcher against the children.
U
- uncheckedMarkIndexReadable(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Marks the index with the given name as readable without checking to see if it is ready.
- uncheckedOpen() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- 
Synchronous version ofFDBRecordStoreBase.BaseBuilder.uncheckedOpenAsync().
- uncheckedOpenAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
- uncheckedOpenAsync() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
- uncheckedOpenAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
- UngettableReferenceException(String) - Constructor for exception com.apple.foundationdb.record.query.plan.temp.ExpressionRef.UngettableReferenceException
- ungrouped() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- 
Get this field as a group without any grouping keys.
- ungrouped() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- 
Get this nesting as a group without any grouping keys.
- ungrouped() - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- 
ARecordTypeexpression with no grouping keys (mostly for evaluating record functions).
- ungrouped() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- 
Get this entire split as a group without any grouping keys.
- ungrouped() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- 
Get this entire concatenation as a group without any grouping keys.
- ungrouped() - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- 
AVersionexpression with no grouping keys (mostly for evaluating record functions).
- ungroupedAggregateOperand(KeyExpression) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainer
- UninitializedRecordStoreException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
An exception that can be thrown byFDBRecordStores if they are used before they have been properly initialized.
- UNION - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- UNION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- UnionCursor<T> - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
- 
A cursor that implements a union of all the records from a set of cursors, all of whom are ordered compatibly.
- UnionVisitor - Class in com.apple.foundationdb.record.query.plan.visitor
- 
This visitor pulls index fetches after the intersection if possible.
- UnionVisitor(RecordMetaData, PlannableIndexTypes, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.visitor.UnionVisitor
- UNIQUE_OPTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
If"true", index throwsRecordIndexUniquenessViolationon attempts to store duplicate values.
- UNIQUE_OPTIONS - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
- 
Options to set to enableIndexOptions.UNIQUE_OPTION.
- UNIQUE_TOKENS - com.apple.foundationdb.record.logging.LogMessageKeys
- uniquenessViolationKey(Tuple, Tuple) - Static method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Return the key portion ofentry, which should be the key with the index value as a tuple.
- UNKNOWN_FIELDS - com.apple.foundationdb.record.logging.LogMessageKeys
- UNLIMITED - Static variable in class com.apple.foundationdb.record.AsyncLoadingCache
- 
A constant to indicate that an operation should not have a limit.
- UNLIMITED - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
- 
Constant indicating that there should be no limit to some usually limited operation.
- UNLIMITED - Static variable in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCacheFactory
- 
A constant indicating that the cache should be of unlimited size or keep items for an unlimited time.
- UNLIMITED_TIME - Static variable in class com.apple.foundationdb.record.ExecuteProperties
- 
A constant representing that no time limit is set.
- UNLIMITED_TR_TIMEOUT_MILLIS - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
- 
Special value to set the transaction timeout to to indicate that transactions should not have any timeout set at all.
- UnmatchedFieldsProperty - Class in com.apple.foundationdb.record.query.plan.temp.properties
- 
A property for counting the total number ofKeyExpressioncolumns (i.e., field-likeKeyExpressions such asFieldKeyExpressionandRecordTypeKeyExpression) that are not matched with at least oneComparisons.Comparisonin a planner expression tree.
- UnmatchedFieldsProperty(PlanContext) - Constructor for class com.apple.foundationdb.record.query.plan.temp.properties.UnmatchedFieldsProperty
- UNORDERED_DISTINCT_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- UNORDERED_PRIMARY_KEY_DISTINCT_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- UNORDERED_UNION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- UnorderedPrimaryKeyDistinctVisitor - Class in com.apple.foundationdb.record.query.plan.visitor
- 
This class moves the index fetch up from the index scan to after a distinct operation has been applied to the records.
- UnorderedPrimaryKeyDistinctVisitor(RecordMetaData, PlannableIndexTypes, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.visitor.UnorderedPrimaryKeyDistinctVisitor
- UnorderedUnionCursor<T> - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
- 
A cursor that returns the results of two or more cursors that may return elements in any order.
- UnorderedUnionCursor(List<MergeCursorState<T>>, FDBStoreTimer) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.cursors.UnorderedUnionCursor
- unpackKey(Subspace, KeyValue) - Static method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper
- unpackKeyValue(KeyValue) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Convert stored key value pair into an index entry.
- unpackKeyValue(Subspace, KeyValue) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Convert stored key value pair located in the given subspace into an index entry.
- UNSPLIT_RECORD - Static variable in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper
- 
Value added to the end of the key when a record is not split.
- UnsplittableKeyExpressionException(BaseKeyExpression) - Constructor for exception com.apple.foundationdb.record.metadata.expressions.BaseKeyExpression.UnsplittableKeyExpressionException
- unsupportedAggregateFunction(IndexAggregateFunction) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- UnsupportedFormatVersionException - Exception in com.apple.foundationdb.record.provider.foundationdb
- 
Exception thrown when a record store has a format version in the database that is not supported by this codebase.
- UnsupportedFormatVersionException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.UnsupportedFormatVersionException
- UnsupportedFormatVersionException(String, Throwable) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.UnsupportedFormatVersionException
- UnsupportedFormatVersionException(Throwable) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.UnsupportedFormatVersionException
- unsupportedRecordFunction(IndexRecordFunction<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- untracked() - Static method in class com.apple.foundationdb.record.ByteScanLimiterFactory
- 
Creates a limiter that neither enforces nor tracks the number of bytes scanned.
- untracked() - Static method in class com.apple.foundationdb.record.RecordScanLimiterFactory
- 
Creates a limiter that neither enforces nor tracks the number of records scanned.
- untrackOpenContext(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- update() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer.UpdateState
- update(FDBIndexableRecord<M>, FDBIndexableRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- update(FDBIndexableRecord<M>, FDBIndexableRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- update(FDBIndexableRecord<M>, FDBIndexableRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexMaintainer
- 
Updates an associated text index with the data associated with a new record.
- update(FDBIndexableRecord<M>, FDBIndexableRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Update associated index for a changed record.
- updateIndexKeys(FDBIndexableRecord<M>, boolean, List<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
- updateIndexKeys(FDBIndexableRecord<M>, boolean, List<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainer
- updateIndexKeys(FDBIndexableRecord<M>, boolean, List<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainer
- updateIndexKeys(FDBIndexableRecord<M>, boolean, List<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Update index according to record keys.
- updateIndexKeys(FDBIndexableRecord<M>, boolean, List<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexMaintainer
- 
Update index according to record keys.
- updateIndexKeys(FDBIndexableRecord<M>, boolean, List<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
- updateIndexKeysFunction(FDBIndexableRecord<M>, boolean, List<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- updateLastSeenFDBVersion(long, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- updateMetadata(FDBRecordContext, String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
- updateMetadata(FDBRecordContext, String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- updateMetadata(FDBRecordContext, String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
- updateMetadata(FDBRecordContext, String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
- updateMetadata(FDBRecordContext, String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
- updateMetadataAndVersion(String, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- 
Transactionally update the metadata for the providedkeyand (within the same transaction) increment the version of the resolver state (seeLocatableResolver.incrementVersion().
- updateOneKeyAsync(FDBIndexableRecord<M>, boolean, IndexEntry) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Store a single key in the index.
- updateOneKeyAsync(FDBIndexableRecord<M>, boolean, IndexEntry) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.VersionIndexMaintainer
- updateRankedSet(IndexMaintainerState, Subspace, RankedSet.Config, Tuple, Tuple, boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper
- updateRecord(M) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Save the given record and throw an exception if the record does not already exist in the database.
- updateRecordAsync(M) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
- 
Save the given record and throw an exception if the record does not already exist in the database.
- updateRecords(Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Update the meta-data records descriptor.
- updateRecords(Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Update the records descriptor of the record meta-data.
- updateRecords(Descriptors.FileDescriptor, boolean) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Update the records descriptor of the record meta-data.
- updateRecordsAsync(Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Update the meta-data records descriptor asynchronously.
- UpdateState(TimeWindowLeaderboardWindowUpdate) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer.UpdateState
- updateStoreRecordVersions(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Update whether record versions should be stored in the meta-data.
- updateStoreRecordVersionsAsync(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
- 
Update whether record versions should be stored in the meta-data asynchronously.
- updateVersionMutation(MutationType, byte[], byte[], BiFunction<byte[], byte[], byte[]>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
- userVersion - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- usesSubspaceKeyCounter() - Method in class com.apple.foundationdb.record.RecordMetaData
- 
Checks if counter-based subspace key assignment is used.
- usesSubspaceKeyCounter() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
- 
Checks if counter-based subspace key assignment is used.
- uuid - Variable in class com.apple.foundationdb.record.provider.common.StoreTimer
- UUID - com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
V
- validate() - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
- validate() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
- validate(MetaDataValidator) - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- validate(RecordMetaData) - Method in class com.apple.foundationdb.record.query.RecordQuery
- 
Validates that this record query is valid with the provided metadata.
- validate(RecordMetaData, RecordMetaData) - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Validate that the new meta-data has been safely evolved from an older version.
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.ElementKeyExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- validate(Descriptors.Descriptor) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Validate this expression against a given record type descriptor.
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.Index
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.IndexRecordFunction
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.expressions.EmptyComparison
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.expressions.NestedField
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
- validate(Descriptors.Descriptor) - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
- 
Validate that the given descriptor is consistent with this component.
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- validate(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.RecordFunction
- validate(Descriptors.Descriptor, boolean) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- validate(Descriptors.Descriptor, Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
- validate(Descriptors.FieldDescriptor, boolean) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
- 
Validate that this comparison is compatible with a given record field.
- validate(Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
- validate(Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
- validate(Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
- validate(Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
- validate(Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
- validate(Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
- validate(BiConsumer<T, T>, T...) - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Aggregate
- 
Helper for implementations to validate that all of the events in the aggregate conform to some basic expectations.
- validate(T...) - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Aggregate
- 
Helper for implementations to validate that all of the events in the aggregate conform to some basic expectations.
- validateChangedOptions(Index) - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- 
Validate any options that have changed.
- validateChangedOptions(Index, Set<String>) - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- 
Validate any option changes included in the set of changed options provided.
- validateConstant(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
- validateConstant(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Called during creation to validate that the constant value provided is of a valid type for this directory.
- validateContext(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.storestate.FDBRecordStoreStateCache
- validateCurrentAndFormerIndexes() - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
- validateDatabase(FDBDatabase) - Method in interface com.apple.foundationdb.record.provider.foundationdb.storestate.FDBRecordStoreStateCache
- validateDatabase(FDBDatabase) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.MetaDataVersionStampStoreStateCache
- validateDatabase(FDBDatabase) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.PassThroughRecordStoreStateCache
- validateDatabase(FDBDatabase) - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.ReadVersionRecordStoreStateCache
- validateEntries(byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
- validateEntries(byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Validate the integrity of the index (such as identifying index entries that do not point to records or identifying records that do not point to valid index entries).
- validateEntries(byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainer
- 
Validate entries in the index.
- validateEntries(byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
- 
Validates the integrity of the index entries.
- validateFieldExistence(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.expressions.BaseField
- validateFormerIndex(FormerIndex) - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
- validateGrouping(int) - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- validateIndex(Index) - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
- validateIndexForRecordType(Index, RecordType) - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
- validateIndexForRecordType(RecordType, MetaDataValidator) - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- validateIndexForRecordTypes(Index, IndexValidator) - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
- validateInIndex(Index) - Method in class com.apple.foundationdb.record.IndexEntry
- 
Validate that this entry is associated with the given index.
- validateMetaData() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- 
Deprecated.validation is done byRecordMetaDataBuilder
- validateMissingEntries(byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Validate entries in the index.
- validateNotGrouping() - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- validateNotUnique() - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- validateNotVersion() - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- validateNoValue() - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- validateOrphanEntries(byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
- 
Validate entries in the index.
- validatePrimaryKeyForRecordType(KeyExpression, RecordType) - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
- validateRecordType(RecordType) - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
- validateResolvedValue(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
Ensures that a value is suitable to be stored within this directory.
- validateStoresRecordVersions(RecordMetaDataProvider) - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- validateUnion(Descriptors.Descriptor, Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator
- 
Validate that the record types have all been evolved in a legal way.
- validateUnionDescriptor(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
- validateVersion(int) - Method in interface com.apple.foundationdb.record.provider.common.text.TextTokenizer
- 
Verify that the provided version is supported by this tokenizer.
- validateVersionInGroupedKeys() - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- validateVersionKey() - Method in class com.apple.foundationdb.record.metadata.IndexValidator
- value - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- value(T) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
Create a static scalar value of typeT.
- VALUE - com.apple.foundationdb.record.logging.LogMessageKeys
- VALUE - com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.TupleSource
- VALUE - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
A normal index on field values.
- VALUE_COMPARATOR - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
- VALUE_KEY - com.apple.foundationdb.record.logging.LogMessageKeys
- VALUE_SIZE - com.apple.foundationdb.record.logging.LogMessageKeys
- VALUE_SIZE_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- ValueElement - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
AnElementrepresenting an entire value, such as a scalar or message, obtained from a source.
- ValueElement(Source) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.ValueElement
- ValueIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
An index maintainer for an ordinary index by value, implementing ordered enumeration of records within a range of indexed values.
- ValueIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainer
- ValueIndexMaintainerFactory - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
A factory forValueIndexMaintainerindexes.
- ValueIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainerFactory
- valueOf(RecordMetaDataProto.Field.FanType) - Static method in enum com.apple.foundationdb.record.metadata.expressions.KeyExpression.FanType
- 
Returns the enum constant of this type with the specified name.
- valueOf(RecordMetaDataProto.Field.NullInterpretation) - Static method in enum com.apple.foundationdb.record.metadata.Key.Evaluated.NullStandin
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.Bindings.Internal
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.cursors.MapWhileCursor.StopContinuation
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.CursorStreamingMode
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.EndpointType
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.IndexState
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.IsolationLevel
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.logging.LogMessageKeys
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.metadata.expressions.KeyExpression.FanType
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.metadata.Key.Evaluated.NullStandin
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Counts
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Events
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.common.text.TextTokenizer.TokenizerMode
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBLatencySource
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.StoreExistenceCheck
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.VersionstampSaveBehavior
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.CountAggregates
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBTraceFormat
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBTransactionPriority
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry.Reasons
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.Events
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter.IndexValues
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.IndexOrphanBehavior
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.Rebuild
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.query.expressions.Field.OneOfThemEmptyMode
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.TupleSource
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.QueryPlanner.IndexScanPreference
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.ScanComparisons.ComparisonType
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.temp.ComparisonRange.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.query.QueryToKeyMatcher.MatchType
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.apple.foundationdb.record.RecordCursor.NoNextReason
- 
Returns the enum constant of this type with the specified name.
- ValueRange<T> - Class in com.apple.foundationdb.record
- 
A range defines the boundaries around a contiguous span of values of some type.
- ValueRange(T, T, EndpointType, EndpointType) - Constructor for class com.apple.foundationdb.record.ValueRange
- values() - Static method in enum com.apple.foundationdb.record.Bindings.Internal
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.cursors.MapWhileCursor.StopContinuation
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.CursorStreamingMode
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.EndpointType
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.IndexState
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.IsolationLevel
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.logging.LogMessageKeys
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.metadata.expressions.KeyExpression.FanType
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.metadata.Key.Evaluated.NullStandin
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
- values() - Static method in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Counts
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Events
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.common.text.TextTokenizer.TokenizerMode
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBLatencySource
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.StoreExistenceCheck
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.VersionstampSaveBehavior
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.CountAggregates
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBTraceFormat
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBTransactionPriority
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry.Reasons
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.Events
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter.IndexValues
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.IndexOrphanBehavior
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.Rebuild
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.query.expressions.Field.OneOfThemEmptyMode
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.TupleSource
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.query.plan.QueryPlanner.IndexScanPreference
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.query.plan.ScanComparisons.ComparisonType
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.query.plan.temp.ComparisonRange.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.query.QueryToKeyMatcher.MatchType
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.apple.foundationdb.record.RecordCursor.NoNextReason
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- VALUES_DATA - Static variable in class com.apple.foundationdb.record.query.plan.temp.explain.NodeInfo
- version() - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
- 
The version key expression, which indicates that a versionstamp should be contained within the key.
- version() - Static method in class com.apple.foundationdb.record.query.expressions.Query
- 
A record function that can be used to determine the version of a record.
- VERSION - com.apple.foundationdb.record.logging.LogMessageKeys
- VERSION - Static variable in class com.apple.foundationdb.record.FunctionNames
- VERSION - Static variable in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- VERSION - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
- 
An index likeIndexTypes.VALUE, but that allows one of the components to beVersionKeyExpression.
- VERSION_LENGTH - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Length of the underlying byte array representation of anFDBRecordVersion.
- VERSION_PROTO - Static variable in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- versionColumns() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
- versionColumns() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
- 
Returns the number of version columns produced by this key expression.
- versionColumns() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
- versionColumns() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
- versionColumns() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
- versionColumns() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
- versionColumns() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
- versionColumns() - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
- VersionElement - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
AnElementrepresenting a serialized versionstamp in a query or index entry.
- VersionElement() - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- VersionIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
Implementation ofIndexMaintainerfor the "version" index type.
- VersionIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.VersionIndexMaintainer
- VersionIndexMaintainerFactory - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
- 
A factory forVersionIndexMaintainerindexes.
- VersionIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.VersionIndexMaintainerFactory
- VersionKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
- 
A key expression that indicates that a serializedFDBRecordVersionshould be contained within the key.
- ViewExpression - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
An abstraction that represents a stream of values that can be represented as tuple-encoding keys and binary values in FoundationDB.
- ViewExpression(List<Element>, QueryPredicate, Source, List<Element>) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.ViewExpression
- ViewExpression.Builder - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
A builder class for constructing an (immutable) view expression.
- ViewExpressionComparisons - Class in com.apple.foundationdb.record.query.plan.temp.view
- 
A data structure that represents aViewExpressionwith aComparisonRangeon some of theElements in its sort order.
- ViewExpressionComparisons(ViewExpression) - Constructor for class com.apple.foundationdb.record.query.plan.temp.view.ViewExpressionComparisons
- visitEnter(RecordCursor<?>) - Method in interface com.apple.foundationdb.record.RecordCursorVisitor
- 
Called on nodes in the record cursor tree in visit pre-order of the depth-first traversal of the tree.
- visitLeave(RecordCursor<?>) - Method in interface com.apple.foundationdb.record.RecordCursorVisitor
- 
Called on nodes in the record cursor tree in visit post-order of the depth-first traversal of the tree.
W
- WAIT_ADD_INDEX - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for adding an index.
- WAIT_ADVANCE_CURSOR - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for a synchronousRecordCursor.next().
- WAIT_BUILD_ENDPOINTS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait forOnlineIndexerto build endpoints.
- WAIT_CHECK_SYNC_SESSION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for checking a synchronized session.
- WAIT_CHECK_VERSION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for check version on a record store.
- WAIT_COLLECT_STATISTICS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for statistics to be collected.
- WAIT_COMMIT - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for a transaction to commit.
- WAIT_DELETE_RECORD - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for deleting a record.
- WAIT_DIRECTORY_RESOLVE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for resolving directory layer entries.
- WAIT_DROP_INDEX - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for dropping an index.
- WAIT_EDIT_HEADER_USER_FIELD - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for editing a header user field.
- WAIT_ENABLE_SPLIT_LONG_RECORDS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for enabling splitting long records.
- WAIT_END_SYNC_SESSION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for ending a synchronized session.
- WAIT_ERROR_CHECK - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
A fake wait for a future already known to be completed.
- WAIT_EXECUTE_QUERY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for query execution to complete.
- WAIT_GET_BOUNDARY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for getting boundaries.
- WAIT_GET_INDEX_BUILD_STATE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for getting index build state.
- WAIT_GET_READ_VERSION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for explicit call toFDBDatabase.getReadVersion(com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext).
- WAIT_INDEX_OPERATION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for anIndexOperationto complete.
- WAIT_INIT_SYNC_SESSION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for initializing a synchronized session.
- WAIT_KEYSPACE_CLEAR - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for clearing aKeySpace.
- WAIT_KEYSPACE_LIST - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for listing aKeySpace.
- WAIT_KEYSPACE_PATH_RESOLVE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for resolving the path for aKeySpace.
- WAIT_KEYSPACE_SCAN - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for scanning aKeySpaceto see whether it has data.
- WAIT_LOAD_META_DATA - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for loading meta-data from aFDBMetaDataStore.
- WAIT_LOAD_RECORD - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for loading a record.
- WAIT_LOAD_RECORD_STORE_STATE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for loadingRecordStoreState.
- WAIT_LOAD_RECORD_VERSION - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for loading a record's version.
- WAIT_LOCATABLE_RESOLVER_COMPUTE_DIGEST - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for aResolverMappingDigestto be computed.
- WAIT_LOCATABLE_RESOLVER_MAPPING_COPY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait forResolverMappingReplicatorto copy a directory layer.
- WAIT_META_DATA_VERSION_STAMP - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait to load the the cluster's meta-data version stamp.
- WAIT_MUTATE_METADATA - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for meta-data mutation.
- WAIT_ONLINE_BUILD_INDEX - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait forOnlineIndexerto complete building an index.
- WAIT_PERFORM_NO_OP - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for performing a no-op operation.
- WAIT_RECORD_EXISTS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait to check if a record exists.
- WAIT_RETRY_DELAY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for a backoff delay on retryable error inFDBDatabase.run(java.util.function.Function<? super com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext, ? extends T>).
- WAIT_REVERSE_DIRECTORY_LOCATE - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for finding reverse directory location.
- WAIT_REVERSE_DIRECTORY_LOOKUP - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for a reverse directory lookup.
- WAIT_REVERSE_DIRECTORY_SCAN - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for a reverse directory scan.
- WAIT_SAVE_META_DATA - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for saving meta-data to aFDBMetaDataStore.
- WAIT_SAVE_RECORD - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for saving a record.
- WAIT_SCAN_INDEX_RECORDS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for a indexed record scan.
- WAIT_SCAN_RECORDS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for a record scan without an index.
- WAIT_SET_STATE_CACHEABILITY - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for setting the store state cacheability.
- WAIT_STOP_ONLINE_INDEX_BUILD - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait forOnlineIndexerto stop ongoing online index builds.
- WAIT_UPDATE_RECORDS_DESCRIPTOR - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for updating records descriptor.
- WAIT_UPDATE_STORE_RECORD_VERSIONS - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for updating if record versions should be stored.
- WAIT_VERSION_STAMP - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
- 
Wait for the updated version stamp from a committed transaction.
- waitUntilReadyForTesting() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
- 
Wait for any asynchronous work started at object creation time to complete.
- WANT_ALL - com.apple.foundationdb.record.CursorStreamingMode
- 
The client will load all records immediately, such as withRecordCursor.asList().
- WARN_COMPLETE_EXCEPTION_BLOCKING - com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
- 
WhenasyncToSync()is called in an asynchronous context and the future it is passed would block, an exception will be thrown; however, if the future is complete, then a warning will be logged.
- WARN_COMPLETE_WARN_BLOCKING - com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
- 
WhenasyncToSync()is called in an asynchronous context, a warning is logged.
- warnAndCloseOldTrackedOpenContexts(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
- 
Log warning and close tracked contexts that have been open for too long.
- watch(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
- WeakReadSemantics(long, long) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase.WeakReadSemantics
- 
Deprecated.
- WeakReadSemantics(long, long, boolean) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase.WeakReadSemantics
- whenAll(List<S>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- whenAny(List<S>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
- widen() - Method in class com.apple.foundationdb.record.provider.common.DynamicMessageRecordSerializer
- widen() - Method in class com.apple.foundationdb.record.provider.common.MessageBuilderRecordSerializer
- widen() - Method in class com.apple.foundationdb.record.provider.common.MessageBuilderRecordSerializerBase
- widen() - Method in interface com.apple.foundationdb.record.provider.common.RecordSerializer
- 
Convert this typed record serializer to an untyped one.
- widen() - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
- with(Function<ExecuteProperties, ExecuteProperties>) - Method in class com.apple.foundationdb.record.ScanProperties
- 
Change execute properties.
- WITH_VERSION - com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.VersionstampSaveBehavior
- withAlias(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.temp.Quantifier.Builder
- withBinding(String, Object) - Method in class com.apple.foundationdb.record.EvaluationContext
- 
Create a newEvaluationContextwith an additional binding.
- withChildren(List<RecordQueryPlan>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
- withChildren(List<RecordQueryPlan>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
- withChildren(List<RecordQueryPlan>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
- withCommittedVersion(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Complete this version with the version from as successful commit.
- withCommittedVersion(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- 
Get this record with an updated version after committing.
- withComparison(Comparisons.Type, Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- withContinuation(RecordCursorContinuation) - Method in class com.apple.foundationdb.record.RecordCursorResult
- 
Return a new result with the given continuation in place of this result's continuation, but the same value or no-next-reason as this result.
- withCreatesDuplicates(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
- withIndexesInState(List<String>, IndexState) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Create a new version of this RecordStoreState, but with the specified indexes in the specified state, ignoring their present state.
- withLimit(int) - Static method in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
- 
Obtain a normalizer with the given size limit.
- withNextValue(T, RecordCursorContinuation) - Static method in class com.apple.foundationdb.record.RecordCursorResult
- 
Create a newRecordCursorResultthat has a value, using the given value and continuation.
- withOtherChild(QueryComponent) - Method in class com.apple.foundationdb.record.query.expressions.BaseNestedField
- withOtherChild(QueryComponent) - Method in interface com.apple.foundationdb.record.query.expressions.ComponentWithSingleChild
- withOtherChild(QueryComponent) - Method in class com.apple.foundationdb.record.query.expressions.NestedField
- withOtherChild(QueryComponent) - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
- withOtherChild(QueryComponent) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
- withOtherChildren(List<QueryComponent>) - Method in class com.apple.foundationdb.record.query.expressions.AndComponent
- withOtherChildren(List<QueryComponent>) - Method in interface com.apple.foundationdb.record.query.expressions.ComponentWithChildren
- withOtherChildren(List<QueryComponent>) - Method in class com.apple.foundationdb.record.query.expressions.OrComponent
- withOtherComparison(Comparisons.Comparison) - Method in interface com.apple.foundationdb.record.query.expressions.ComponentWithComparison
- withOtherComparison(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
- withOtherComparison(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
- withOtherComparison(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
- withOtherComparison(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
- withOtherComparison(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
- withoutNextValue(RecordCursorContinuation, RecordCursor.NoNextReason) - Static method in class com.apple.foundationdb.record.RecordCursorResult
- 
Create a newRecordCursorResultthat does not have a next value, using the given continuation and no-next-reason.
- withoutNextValue(RecordCursorResult<U>) - Static method in class com.apple.foundationdb.record.RecordCursorResult
- 
Cast aRecordCursorResultto one with a new type from a result without a next value.
- withParameterComparison(Comparisons.Type, String) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
- withPlan(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
- withRoot(ExpressionRef<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.temp.ExpressionRefTraversal
- 
Construct a traversal object using therootRefreference passed in.
- withScore(int) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
- withSourceMappedInto(Source, Source) - Method in interface com.apple.foundationdb.record.query.plan.temp.view.Element
- 
Replace the given duplicate source with the given original source everywhere that it occurs in this element, including in ancestor sources of this element's source.
- withSourceMappedInto(Source, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.FieldElement
- withSourceMappedInto(Source, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.LiteralElement
- withSourceMappedInto(Source, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeElement
- withSourceMappedInto(Source, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RecordTypeSource
- withSourceMappedInto(Source, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.RepeatedFieldSource
- withSourceMappedInto(Source, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.Source
- 
Replace the given duplicate source with the given original source everywhere that it occurs in this source, including in ancestor sources.
- withSourceMappedInto(Source, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ValueElement
- withSourceMappedInto(Source, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.VersionElement
- withSourcesMappedInto(Source, Source) - Method in class com.apple.foundationdb.record.query.plan.temp.view.ViewExpressionComparisons
- 
Replace the given duplicate source with the given original source everywhere that it occurs in these view expression comparisons.
- withSubspace(Subspace) - Static method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
- withUnsatisfiedFilters(List<QueryComponent>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
- withVersion(FDBRecordVersion) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecord
- 
Copy this record with a different version.
- withWriteOnlyIndexes(List<String>) - Method in class com.apple.foundationdb.record.MutableRecordStoreState
- withWriteOnlyIndexes(List<String>) - Method in class com.apple.foundationdb.record.RecordStoreState
- 
Create a new version of thisRecordStoreState, but with additionalIndexState.WRITE_ONLYindexes.
- wrap(KeySpacePath) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- 
If awrapperwas installed for this directory, the providedpathwill be wrapped by thewrapperand returned, otherwise the originalpathis returned.
- wrap(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
- wrap(RecordQueryPlan, Set<RankComparisons.RankComparison>, RecordMetaData) - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons
- wrap(T) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
- wrapException(Throwable) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBExceptions
- wrapper - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
- WRITE_ONLY - com.apple.foundationdb.record.IndexState
- 
Indicates the index should not be read from but is written to.
- writeOnlyIfTooManyRecordsForRebuild(long, boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
- writeOnlyMap(List<String>) - Method in class com.apple.foundationdb.record.RecordStoreState
- WRITES - com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
- 
Total number of write operations.
- writeTo(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Write the serialized version to the beginning of the given byte array.
- writeTo(byte[], int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Write the serialized version to a specified offset within the given byte array.
- writeTo(ByteBuffer) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
- 
Write the serialized version information to the end of aByteBuffer.
- WROTE_INDEX - com.apple.foundationdb.record.logging.LogMessageKeys
X
- XML - com.apple.foundationdb.record.provider.foundationdb.FDBTraceFormat
- 
Format the trace logs as XML.
Y
- yield(ExpressionRef<? extends RelationalExpression>) - Method in class com.apple.foundationdb.record.query.plan.temp.CascadesRuleCall
- yield(ExpressionRef<? extends RelationalExpression>) - Method in interface com.apple.foundationdb.record.query.plan.temp.PlannerRuleCall
- 
Notify the planner's data structures that the new expression contained inexpressionhas been produced by the rule.
Z
- zip(List<CorrelationIdentifier>, List<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.temp.AliasMap
All Classes All Packages