Index

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 and Interfaces|All Packages|Constant Field Values|Serialized Form

A

absorptionAndRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
absorptionOrRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
AbsorptionRule<P extends AndOrPredicate> - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A rule that matches an AndPredicate or OrPredicate and attempts to simplify the terms underneath according to the boolean absorption law.
AbsorptionRule(Class<P>, BindingMatcher<QueryPredicate>, BindingMatcher<P>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AbsorptionRule
 
AbstractArrayConstructorValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value that encapsulates its homogeneous children Values into a single Type.Array typed Value.
AbstractArrayConstructorValue(PlanSerializationContext, PAbstractArrayConstructorValue) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue
 
AbstractArrayConstructorValue(List<? extends Value>, Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue
 
AbstractArrayConstructorValue.ArrayFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The array function.
AbstractArrayConstructorValue.LightArrayConstructorValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
An array that does not need any nested proto constructed.
AbstractArrayConstructorValue.LightArrayConstructorValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
AbstractDataAccessRule<R extends RelationalExpression> - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that utilizes index matching information compiled by CascadesPlanner to create one or more expressions for data access.
AbstractDataAccessRule(BindingMatcher<MatchPartition>, BindingMatcher<PartialMatch>, BindingMatcher<R>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.AbstractDataAccessRule
 
AbstractEdge(String, Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.AbstractEdge
 
AbstractEdge(Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.AbstractEdge
 
AbstractEventWithState(Reference, Deque<CascadesPlanner.Task>, Debugger.Location) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.AbstractEventWithState
 
AbstractNode(Object, String) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.AbstractNode
 
AbstractNode(Object, String, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.AbstractNode
Overloaded constructor.
AbstractPlannerGraph<N extends AbstractPlannerGraph.AbstractNode,E extends AbstractPlannerGraph.AbstractEdge> - Class in com.apple.foundationdb.record.query.plan.cascades.explain
The planner graph class.
AbstractPlannerGraph(N, Network<N, E>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph
Protected constructor.
AbstractPlannerGraph.AbstractEdge - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Edge class.
AbstractPlannerGraph.AbstractNode - Class in com.apple.foundationdb.record.query.plan.cascades.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.cascades.explain
Builder class for planner graph.
AbstractQueryPredicate - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Abstract implementation of QueryPredicate that provides memoization of correlatedTo sets.
AbstractQueryPredicate(boolean) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.AbstractQueryPredicate
 
AbstractQueryPredicate(PlanSerializationContext, PAbstractQueryPredicate) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.AbstractQueryPredicate
 
AbstractQueryPredicateRule<RESULT,CALL extends AbstractQueryPredicateRuleCall<RESULT,CALL>,TYPE extends QueryPredicate> - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
Tag class to bind the base BASE to QueryPredicate.
AbstractQueryPredicateRule(BindingMatcher<TYPE>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AbstractQueryPredicateRule
 
AbstractQueryPredicateRuleCall<RESULT,CALL extends AbstractQueryPredicateRuleCall<RESULT,CALL>> - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A rule call tag sub class for the simplification of QueryPredicate trees.
AbstractQueryPredicateRuleCall(AbstractRule<RESULT, CALL, QueryPredicate, ? extends QueryPredicate>, QueryPredicate, QueryPredicate, PlannerBindings, AliasMap, Set<CorrelationIdentifier>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AbstractQueryPredicateRuleCall
 
AbstractQueryPredicateRuleSet<R,C extends AbstractQueryPredicateRuleCall<R,C>> - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A set of rules for use by a planner that supports quickly finding rules that could match a given planner expression.
AbstractQueryPredicateRuleSet(Set<? extends AbstractQueryPredicateRule<R, C, ? extends QueryPredicate>>, SetMultimap<? extends AbstractQueryPredicateRule<R, C, ? extends QueryPredicate>, ? extends AbstractQueryPredicateRule<R, C, ? extends QueryPredicate>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AbstractQueryPredicateRuleSet
 
AbstractRule<RESULT,CALL extends AbstractRuleCall<RESULT,CALL,BASE>,BASE,TYPE extends BASE> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
The rule matching occurs in two stages: first, the planner examines the AbstractRule.matcher of the rule, which is a BindingMatcher expression that expresses the operators that the rule applies to and the hierarchical structure that they take on in the expression tree.
AbstractRule(BindingMatcher<TYPE>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRule
 
AbstractRuleCall<RESULT,CALL extends AbstractRuleCall<RESULT,CALL,BASE>,BASE> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule call implementation for the simplification of Value trees.
AbstractRuleCall(AbstractRule<RESULT, CALL, ? extends BASE, ? extends BASE>, BASE, BASE, PlannerBindings, AliasMap, Set<CorrelationIdentifier>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
AbstractRuleSet<RESULT,CALL extends AbstractRuleCall<RESULT,CALL,BASE>,BASE> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A set of rules for use by a planner that supports quickly finding rules that could match a given planner expression.
AbstractRuleSet(Set<? extends AbstractRule<RESULT, CALL, BASE, ? extends BASE>>, SetMultimap<? extends AbstractRule<RESULT, CALL, BASE, ? extends BASE>, ? extends AbstractRule<RESULT, CALL, BASE, ? extends BASE>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleSet
 
AbstractTrieNode(T, Map<D, N>) - Constructor for class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNode
 
AbstractTrieNodeBuilder(T, Map<D, N>) - Constructor for class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNodeBuilder
 
AbstractValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
Abstract implementation of Value that provides memoization of correlatedTo sets.
AbstractValue() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.AbstractValue
 
AbstractValueRule<RESULT,CALL extends AbstractValueRuleCall<RESULT,CALL>,TYPE extends Value> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
Tag class to bind the base BASE to Value.
AbstractValueRule(BindingMatcher<TYPE>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractValueRule
 
AbstractValueRuleCall<RESULT,CALL extends AbstractValueRuleCall<RESULT,CALL>> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule call implementation for the simplification of Value trees.
AbstractValueRuleCall(AbstractRule<RESULT, CALL, Value, ? extends Value>, Value, Value, PlannerBindings, AliasMap, Set<CorrelationIdentifier>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractValueRuleCall
 
AbstractValueRuleSet<R,C extends AbstractValueRuleCall<R,C>> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A set of rules for use by a planner that supports quickly finding rules that could match a given planner expression.
AbstractValueRuleSet(Set<? extends AbstractValueRule<R, C, ? extends Value>>, SetMultimap<? extends AbstractValueRule<R, C, ? extends Value>, ? extends AbstractValueRule<R, C, ? extends Value>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractValueRuleSet
 
accept(RecordQueryPlannerSubstitutionVisitor) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
 
accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.aggregate.AggregateCursor
 
accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.AsyncLockCursor
 
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.FallbackCursor
 
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.AsyncIteratorCursor
 
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
Deprecated.
 
accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
 
accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.MapResultCursor
 
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.RangeCursor
 
accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor
 
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.cursors.TempTableInsertCursor
 
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 implements RecordCursorVisitor.
accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.sorting.FileSortCursor
 
accept(RecordCursorVisitor) - Method in class com.apple.foundationdb.record.sorting.MemorySortCursor
 
acceptPropertyVisitor(ExpressionProperty<U>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Apply the given property visitor to this planner expression and its children.
acceptPropertyVisitor(ExpressionProperty<U>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Allow the computation of ExpressionPropertys across the quantifiers in the data flow graph.
acceptPropertyVisitor(ExpressionProperty<U>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
AccessHint - Interface in com.apple.foundationdb.record.query.plan.cascades
Interface to represent an access hint.
AccessHints - Class in com.apple.foundationdb.record.query.plan.cascades
Represents a set of AccessHint a query or a match candidate has.
AccessHints(AccessHint...) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.AccessHints
 
Accessor(String, int) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.Accessor
 
accumulate(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, M) - Method in interface com.apple.foundationdb.record.cursors.aggregate.AggregateAccumulator
Apply a new record on top of the current aggregation.
accumulate(Double) - Method in class com.apple.foundationdb.record.cursors.aggregate.DoubleState
 
accumulate(Float) - Method in class com.apple.foundationdb.record.cursors.aggregate.FloatState
 
accumulate(Integer) - Method in class com.apple.foundationdb.record.cursors.aggregate.IntegerState
 
accumulate(Iterable<M>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.graph.MatchAccumulator
Accumulates the Iterable handed in into the internal state of the instance.
accumulate(Long) - Method in class com.apple.foundationdb.record.cursors.aggregate.LongState
 
accumulate(Object) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Accumulator
 
accumulate(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue.SumAccumulator
 
accumulate(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.NumericAccumulator
 
accumulate(T) - Method in interface com.apple.foundationdb.record.cursors.aggregate.AccumulatorState
Add additional value to the state.
accumulate(T) - Method in class com.apple.foundationdb.record.cursors.aggregate.AverageAccumulatorState
 
Accumulator - Interface in com.apple.foundationdb.record.query.plan.cascades.values
An aggregate accumulator.
AccumulatorState<T,R> - Interface in com.apple.foundationdb.record.cursors.aggregate
This interface presents a state af an accumulated value.
acquireReadLock(LockIdentifier) - Method in class com.apple.foundationdb.record.locking.LockRegistry
Attempts to get access for performing read operations on the resource represented by the id and returns a CompletableFuture of the lock after the access has been granted.
acquireReadLock(LockIdentifier) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
 
acquireWriteLock(LockIdentifier) - Method in class com.apple.foundationdb.record.locking.LockRegistry
Attempts to get access for performing write operations on the resource represented by the id and returns a CompletableFuture of the lock after the access has been granted.
acquireWriteLock(LockIdentifier) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
 
ACTUAL - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
ACTUAL_COLUMN_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
ACTUAL_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
add(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.SizeInfo
 
add(byte[], FDBRecordVersion) - 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) - Method in class com.apple.foundationdb.record.provider.common.StoreSubTimer
 
add(StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
 
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(RangeConstraints) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.Builder
 
add(Value, Value, Supplier<QueryPlanConstraint>) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ValueMap.Builder
 
add(ExplainTokens.Token) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
add(ExplainTokens.Token) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
add(QueryResult) - Method in class com.apple.foundationdb.record.query.plan.cascades.TempTable
Add a new QueryResult element to the underlying buffer.
add(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.PropertiesMap
Method to add a new RecordQueryPlan to this properties map.
add(RecordQueryPlan, Map<PlanProperty<?>, ?>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PropertiesMap
Method to add a new RecordQueryPlan to this properties map using precomputed properties.
add(String) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
Adds the constant value for subdirectory dirName to 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 a value for a specific subdirectory dirName to 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.combinatorics.PartiallyOrderedSet.Builder
 
add(T) - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
ADD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
ADD - Static variable in class com.apple.foundationdb.record.FunctionNames
 
ADD_DD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_DF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_DI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_DL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_DS - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_FD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_FF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_FI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_FL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_FS - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_ID - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_IF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_II - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_IL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_IS - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_LD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_LF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_LI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_LL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_LS - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_SD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_SF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_SI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_SL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ADD_SS - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
addAfterCommit(FDBRecordContext.AfterCommit) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Adds code to be executed immediately following a successful commit.
addAliasDefinition(int, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addAliasDefinition(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addAliasReference(int, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addAliasReference(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addAll(ComparisonRanges) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
addAll(LinkedIdentitySet<T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
addAll(ScanComparisons) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons.Builder
 
addAll(Iterable<? extends T>) - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet.Builder
 
addAll(Collection<? extends ExplainTokens.Token>) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addAll(List<Comparisons.Comparison>, Set<Comparisons.Comparison>) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons.Builder
 
addAllPlaceholders(Iterable<? extends Placeholder>) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
addAllPredicates(Iterable<? extends QueryPredicate>) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
addAllQuantifiers(Iterable<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
addAllResultColumns(Iterable<Column<? extends Value>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
addAllResultValues(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
addAllTypes(Collection<Type>) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
addClosingAngledBracket() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addClosingAngledBracket(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addClosingBrace() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addClosingBrace(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addClosingParen() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addClosingParen(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addClosingSquareBracket() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addClosingSquareBracket(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addComma() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addComma(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addCommaAndWhiteSpace() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addCommaAndWhiteSpace(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addCommitCheck(FDBRecordContext.CommitCheckAsync) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Add a FDBRecordContext.CommitCheckAsync to be performed before FDBRecordContext.commit() finishes.
addCommitCheck(String, FDBRecordContext.CommitCheckAsync) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Add a FDBRecordContext.CommitCheckAsync by name to be performed before FDBRecordContext.commit() finishes.
addCommitCheck(CompletableFuture<Void>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Add a check to be completed before FDBRecordContext.commit() finishes.
addComparandToList(List<Object>, Comparisons.Comparison, FDBRecordStoreBase<?>, EvaluationContext) - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
addComparisonMaybe(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.Builder
 
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.
addConstituentFields(DescriptorProtos.DescriptorProto.Builder, Set<Descriptors.FileDescriptor>) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
 
addCoveringField(KeyExpression, AvailableFields.FieldData, IndexKeyValueToPartialRecord.Builder) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields
 
addCoveringField(IndexKeyValueToPartialRecord.Builder, FieldValue, Value) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.ScanWithFetchMatchCandidate
 
addCurrentAliasDefinition(int, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addCurrentAliasDefinition(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
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 the RecordMetaData from a meta-data proto.
addDependency(Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
Adds a dependency to the list of dependencies.
addDependency(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
addDependency(T, T) - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet.Builder
 
addEdge(EndpointPair<N>, E) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
addEdge(N, N, E) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.PlannerGraphBuilder
 
addEdge(N, N, E) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
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 the RangeSet associated with this index.
addEmptyRanges(int) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
addEnumType(DescriptorProtos.EnumDescriptorProto) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
addEqualityComparison(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
addEqualityComparison(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons.Builder
 
addExpression(Reference, RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal
 
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, Value) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
 
addField(String, IndexKeyValueToPartialRecord.TupleSource, AvailableFields.CopyIfPredicate, ImmutableIntArray, String) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
 
AddFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.AddFn
 
addFormerIndex(FormerIndex) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
 
addFunctionCall(int, String) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addFunctionCall(int, String, ExplainTokens) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addFunctionCall(String) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addFunctionCall(String, ExplainTokens) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addGraph(AbstractPlannerGraph<N, E>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.PlannerGraphBuilder
 
addIdentifier(int, String) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addIdentifier(String) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
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.
addIndexUniquenessCommitCheck(Index, Subspace, CompletableFuture<Void>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
addInequalityComparison(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
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
 
ADDITIVE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
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
 
addKeyValue(K, V) - Method in class com.apple.foundationdb.record.sorting.MemoryScratchpad
 
addKeyword(int, String) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addKeyword(String) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
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
 
addLinebreakOrWhitespace() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addLinebreakOrWhitespace(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addListWithDependencies(List<? extends T>) - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet.Builder
 
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
 
addMessageType(DescriptorProtos.DescriptorProto) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
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.
addNested(int, ExplainTokens) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addNested(int, ExplainTokens, ExplainTokens.Token) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addNested(int, ExplainTokens, String) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addNested(ExplainTokens) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addNestedConstituent(String, Descriptors.Descriptor, String, KeyExpression) - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordTypeBuilder
 
addNestedRecordType(RecordMetaDataProto.MetaData.Builder, DescriptorProtos.DescriptorProto) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
Add a new NESTED record type to the meta-data.
addNode(N) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.PlannerGraphBuilder
 
addNode(N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
addOpeningAngledBracket() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addOpeningAngledBracket(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addOpeningBrace() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addOpeningBrace(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addOpeningParen() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addOpeningParen(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addOpeningSquareBracket() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addOpeningSquareBracket(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addOptionalWhitespace() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addOptionalWhitespace(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
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.
addParentConstituent(String, RecordTypeBuilder) - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordTypeBuilder
 
addPartialMatchForCandidate(MatchCandidate, PartialMatch) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Add the PartialMatch passed in to this reference for the MatchCandidate passed in.
addPlaceholder(Placeholder) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
addPop() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addPop(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
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.
addPredicate(QueryPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
addProp(RecordLayerPropertyKey<T>, Supplier<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyStorage.Builder
 
addProp(RecordLayerPropertyKey<T>, T) - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyStorage.Builder
 
addProp(RecordLayerPropertyValue<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyStorage.Builder
 
addProtoField(TypeRepository.Builder, DescriptorProtos.DescriptorProto.Builder, int, String, Optional<String>, DescriptorProtos.FieldDescriptorProto.Label) - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Creates a synthetic protobuf descriptor that is equivalent to the this Type within a given protobuf descriptor.
addProtoField(TypeRepository.Builder, DescriptorProtos.DescriptorProto.Builder, int, String, Optional<String>, DescriptorProtos.FieldDescriptorProto.Label) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
Creates a synthetic protobuf descriptor that is equivalent to the this Type within a given protobuf descriptor.
addProtoField(TypeRepository.Builder, DescriptorProtos.DescriptorProto.Builder, int, String, Optional<String>, DescriptorProtos.FieldDescriptorProto.Label) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
Creates a synthetic protobuf descriptor that is equivalent to the this Type within a given protobuf descriptor.
addProtoField(TypeRepository.Builder, DescriptorProtos.DescriptorProto.Builder, int, String, Optional<String>, DescriptorProtos.FieldDescriptorProto.Label) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
Creates a synthetic protobuf descriptor that is equivalent to the this Type within a given protobuf descriptor.
addProtoField(TypeRepository.Builder, DescriptorProtos.DescriptorProto.Builder, int, String, Optional<String>, DescriptorProtos.FieldDescriptorProto.Label) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
addProtoField(TypeRepository.Builder, DescriptorProtos.DescriptorProto.Builder, int, String, Optional<String>, DescriptorProtos.FieldDescriptorProto.Label) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
addProtoField(TypeRepository.Builder, DescriptorProtos.DescriptorProto.Builder, int, String, Optional<String>, DescriptorProtos.FieldDescriptorProto.Label) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
addProtoField(TypeRepository.Builder, DescriptorProtos.DescriptorProto.Builder, int, String, Optional<String>, DescriptorProtos.FieldDescriptorProto.Label) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive
 
addProtoField(TypeRepository.Builder, DescriptorProtos.DescriptorProto.Builder, int, String, Optional<String>, DescriptorProtos.FieldDescriptorProto.Label) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Creates a synthetic protobuf descriptor that is equivalent to the this Type within a given protobuf descriptor.
addProtoField(TypeRepository.Builder, DescriptorProtos.DescriptorProto.Builder, int, String, Optional<String>, DescriptorProtos.FieldDescriptorProto.Label) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
Creates a synthetic protobuf descriptor that is equivalent to the this Type within a given protobuf descriptor.
addPublicDependency(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
addPush() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addPush(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addQuantifier(Quantifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
addReadConflictKey(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
addReadConflictKey(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
addReadConflictKeyIfNotSnapshot(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
addReadConflictKeyIfNotSnapshot(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
addReadConflictRange(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
addReadConflictRange(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
addReadConflictRangeIfNotSnapshot(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
addReadConflictRangeIfNotSnapshot(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
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.
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
 
addRegularCopier(IndexKeyValueToPartialRecord.Copier) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
 
addRequiredMessageFields() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
 
addResultColumn(Column<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
addResultValue(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
addSchema(TypeRepository) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
addSequence(Supplier<ExplainTokens>, ExplainTokens...) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addSequence(Supplier<ExplainTokens>, Iterable<ExplainTokens>) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addSizeLogInfo(KeyValueLogMessage) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBStoredSizes
Add logging information about size information to a log message.
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
 
addTargetIndex(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
Add one target index to the target indexes list.
addTargetIndex(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
Add one target index to the target indexes list.
addToString(int, Object) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addToString(Object) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addToStrings(int, Iterable<?>) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addToStrings(Iterable<?>) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addTypeFilterIfNeeded(RecordQueryPlanner.CandidateScan, RecordQueryPlan, Set<String>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
 
addTypeIfNeeded(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.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.
addUnnestedRecordType(String) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
addValue(V) - Method in class com.apple.foundationdb.record.sorting.MemoryScratchpad
 
addValueIndexOverScanNeeded(String) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
 
addVersionMutation(MutationType, byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Add a SET_VERSIONSTAMPED_KEY or SET_VERSIONTSTAMPED_VALUE mutation to be run at commit time.
addWhitespace() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addWhitespace(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
addWriteConflictKey(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
addWriteConflictKey(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
addWriteConflictRange(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
addWriteConflictRange(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
adjacentEdges(E) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
adjacentNodes(N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
adjustComparison(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.expressions.OrderQueryKeyExpression
Turn a comparison on the inner key (usually a field) into the corresponding comparison on this ordering key.
adjustedBuilder() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchInfo
 
AdjustedMatchInfo(MatchInfo, List<OrderingPart.MatchedOrderingPart>, MaxMatchMap) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedMatchInfo
 
adjustFixedBindings(Iterable<OrderingPart.ProvidedOrderingPart>, boolean) - Static method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan
Helper to resolve a comparison direction.
adjustMatch(PartialMatch) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
adjustMatch(PartialMatch) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Override that is called by AdjustMatchRule to improve an already existing PartialMatch.
adjustMatch(PartialMatch) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
ADJUSTMATCH - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
 
AdjustMatchEvent(Reference, Deque<CascadesPlanner.Task>, Debugger.Location, Reference, RelationalExpression) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.AdjustMatchEvent
 
AdjustMatchRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that attempts to improve an existing PartialMatch by absorbing an expression on the candidate side.
AdjustMatchRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.AdjustMatchRule
 
adjustMaybe(CorrelationIdentifier, Value, Set<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.MaxMatchMap
 
adjustOrdering(PlanOrderingKey, boolean) - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
Adjust plan ordering for the result of handling these IN clauses.
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
 
adjustValueType(Value) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap.TranslationFunction
 
AFTER - Enum constant in enum com.apple.foundationdb.record.cursors.MapWhileCursor.StopContinuation
Return the continuation following the record that stopped the cursor.
AGE_SECONDS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
AGENT - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
AGENTS - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
AGGREGATE_FUNCTION_NAME - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainer
 
AggregateAccumulator - Interface in com.apple.foundationdb.record.cursors.aggregate
This interface encapsulates the aggregation operator behavior: It holds onto the current state and applies a new record onto the current state to arrive at the new accumulated state.
AggregateCursor<M extends Message> - Class in com.apple.foundationdb.record.cursors.aggregate
A cursor that groups incoming records by the given grouping criteria.
AggregateCursor(RecordCursor<QueryResult>, StreamGrouping<M>, boolean) - Constructor for class com.apple.foundationdb.record.cursors.aggregate.AggregateCursor
 
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
 
AggregateIndexExpansionVisitor - Class in com.apple.foundationdb.record.query.plan.cascades
Expands an aggregate index into a MatchCandidate.
AggregateIndexExpansionVisitor(Index, Collection<RecordType>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexExpansionVisitor
Constructs a new instance of AggregateIndexExpansionVisitor.
AggregateIndexMatchCandidate - Class in com.apple.foundationdb.record.query.plan.cascades
Case class that represents a grouping index with aggregate function(s).
AggregateIndexMatchCandidate(Index, Traversal, List<CorrelationIdentifier>, Collection<RecordType>, Type, Value, SelectExpression) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
Creates a new instance of AggregateIndexMatchCandidate.
aggregateIndexPlan() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
aggregateIndexPlanOf(BindingMatcher<? extends RecordQueryPlanWithIndex>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
AggregateValue - Interface in com.apple.foundationdb.record.query.plan.cascades.values
A value representing an aggregate: a value calculated (derived) from other values by applying an aggregation operator (e.g.
aggregations(BindingMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
AGILITY_CONTEXT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
AGILITY_CONTEXT_AGE_MILLISECONDS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
AGILITY_CONTEXT_PREV_CHECK_MILLISECONDS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
AGILITY_CONTEXT_WRITE_SIZE_BYTES - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
alias - Variable in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Builder
 
ALIAS_DEFINITION - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
ALIAS_REFERENCE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
AliasDefinitionToken(int, CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.AliasDefinitionToken
 
aliases(Iterable<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
 
AliasMap - Class in com.apple.foundationdb.record.query.plan.cascades
This class encapsulates mappings between CorrelationIdentifiers and helpers to create and maintain these mappings.
AliasMap.Builder - Class in com.apple.foundationdb.record.query.plan.cascades
Builder class for the AliasMap.
AliasMapBackedValueEquivalence(AliasMap) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.AliasMapBackedValueEquivalence
 
AliasReferenceToken(int, CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.AliasReferenceToken
 
AliasResolver(Traversal) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Quantifiers.AliasResolver
 
aliasToQuantifierMap(Iterable<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
 
all(BindingMatcher<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MultiMatcher
 
ALL - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter.IndexValues
 
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_DETAILS - Static variable in class com.apple.foundationdb.record.query.plan.explain.ExplainLevel
Everything we can render is rendered.
ALL_FIELDS - Static variable in class com.apple.foundationdb.record.query.plan.AvailableFields
 
ALL_INTERSECTION_COMBINATIONS - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
 
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
 
allAttributesExcept(PlanProperty<?>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.PropertiesMap
 
allIndexesReadable() - Method in class com.apple.foundationdb.record.RecordStoreState
Determines whether all of the indexes in the store are currently readable.
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 a TupleRange over all keys beginning with a given Tuple.
AllOfMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A matcher that only matches anything if all of its downstream matchers produce bindings.
ALLOW_REPAIR - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
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.
allowedForCoveringIndexPlan() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithIndex
Whether this plan is appropriate for being applied with optimization by RecordQueryCoveringIndexPlan, if the planner believes the required fields can be covered by this index.
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.
allowsParallelEdges() - Method in class com.google.common.graph.StableStandardMutableNetwork
 
allowsSelfLoops() - Method in class com.google.common.graph.StableStandardMutableNetwork
 
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.
allowTakeoverContinue() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
allowTakeoverContinue(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
In some special cases, an indexing method is allowed to continue building an index that was partly built by another method.
allowTakeoverContinue(Collection<OnlineIndexer.IndexingPolicy.TakeoverTypes>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
In some special cases, an indexing method is allowed to continue building an index that was partly built by another method.
allowUniquePendingState() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
allowUniquePendingState(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
After indexing a unique index, if requested to mark the index as readable (OnlineIndexer.buildIndex()), but the index contain duplicates, this function will determine the next behavior: allow=true: mark the index as IndexState.READABLE_UNIQUE_PENDING.
allSatisfied() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
Determine if the whole filter has been satisfied.
ALWAYS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.Rebuild
 
ALWAYS_PARENS - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
alwaysTrue() - Static method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
Factory method to create an unconditional true.
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(MatchPredicate<? super T>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.graph.MatchPredicate
Method that combines this MatchPredicate and the other one passed in to produce a new MatchPredicate that first tests this predicate and if successful then tests the other.
and(BindingMatcher<? super T>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
Combinator which is just just a rename of BindingMatcher.where(BindingMatcher).
and(Proposition) - Method in enum com.apple.foundationdb.record.query.plan.cascades.predicates.Proposition
 
and(QueryPredicate, QueryPredicate, QueryPredicate...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
and(Collection<? extends QueryPredicate>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
and(Collection<? extends QueryPredicate>, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
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.
And(List<MultidimensionalIndexScanBounds.SpatialPredicate>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.And
 
AND - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
AndComponent - Class in com.apple.foundationdb.record.query.expressions
A QueryComponent that is satisfied when all of its child components are satisfied.
AndComponent(List<QueryComponent>) - Constructor for class com.apple.foundationdb.record.query.expressions.AndComponent
 
AndFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue.AndFn
 
AndOrComponent - Class in com.apple.foundationdb.record.query.expressions
The common base class for Boolean And and Or query components.
AndOrComponent(List<QueryComponent>) - Constructor for class com.apple.foundationdb.record.query.expressions.AndOrComponent
 
AndOrPredicate - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Common base class for predicates with many children, such as AndPredicate and OrPredicate.
AndOrPredicate(PlanSerializationContext, PAndOrPredicate) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.AndOrPredicate
 
AndOrPredicate(List<? extends QueryPredicate>, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.AndOrPredicate
 
AndOrValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value that applies conjunction/disjunction on its boolean children, and if possible, simplifies its boolean children.
AndOrValue.AndFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The and function.
AndOrValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
AndOrValue.OrFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The or function.
andPredicate(BindingMatcher<C>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QueryPredicateMatchers
 
AndPredicate - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
A QueryPredicate that is satisfied when all of its child components are.
AndPredicate(AndPredicate) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.AndPredicate
 
AndPredicate(RecordMetaDataProto.AndPredicate) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.AndPredicate
 
AndPredicate(Collection<IndexPredicate>) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.AndPredicate
 
AndPredicate.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Deserializer.
andThen(MatchFunction<? super T, R>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.graph.MatchPredicate
Method that combines this MatchPredicate and the MatchFunction after passed in to produce a new MatchFunction that first tests this predicate and if successful then applies after.
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 the after function to the result.
annulmentAndRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
AnnulmentAndRule - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A rule that matches a AndPredicate (with the argument values) that applies the annulment law.
AnnulmentAndRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AnnulmentAndRule
 
annulmentOrRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
AnnulmentOrRule - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A rule that matches a OrPredicate (with the argument values) that applies the annulment law.
AnnulmentOrRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AnnulmentOrRule
 
any() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
any(BindingMatcher<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AnyMatcher
 
Any() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
 
ANY - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
 
ANY - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
Any ordering.
ANY - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
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).
anyComparison() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QueryPredicateMatchers
 
anyComparisonOfType(Comparisons.Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QueryPredicateMatchers
 
anyExpression() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
anyFieldValue() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
anyInIterable(BindingMatcher<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AnyMatcher
 
AnyMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A binding matcher that is a CollectionMatcher that binds to individual elements contained in a collection separately.
AnyMatcher(BindingMatcher<T>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AnyMatcher
 
anyObject() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PrimitiveMatchers
 
AnyOfMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A matcher that matches if any of its downstream matchers produce bindings.
anyParameterComparison() - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
anyPartialMatch() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PartialMatchMatchers
Matches any PartialMatch.
anyPlan() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
anyPlanPartition() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ReferenceMatchers
 
anyPredicate() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QueryPredicateMatchers
 
anyQuantifier() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
anyQuantifier(BindingMatcher<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
anyQuantifier(CollectionMatcher<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
anyQuantifierOverRef(BindingMatcher<? extends Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
AnyRecord(boolean) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
 
anyRef() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ReferenceMatchers
 
anyRefOverOnlyPlans() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ReferenceMatchers
 
anySimpleComparison() - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
anyTopologicalOrderPermutation(PartiallyOrderedSet<T>) - Static method in class com.apple.foundationdb.record.query.combinatorics.TopologicalSort
Create a correct topological ordering based on a partial order describing the dependency relationships between the items in the given set.
anyTopologicalOrderPermutation(List<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
 
anyTopologicalOrderPermutation(Set<T>, ImmutableSetMultimap<T, T>) - Static method in class com.apple.foundationdb.record.query.combinatorics.TopologicalSort
Create a correct topological ordering based on a set and a map describing the dependency relationships between items in the given set.
anyTopologicalOrderPermutation(Set<T>, Function<T, Set<T>>) - Static method in class com.apple.foundationdb.record.query.combinatorics.TopologicalSort
Create a correct topological ordering based on a set and a function describing the dependency relationships between items in the given set.
anyValue() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
anyValueComparison() - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
API_VERSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
API_VERSION_6_3 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.APIVersion
API version corresponding to FoundationDB 6.3.
API_VERSION_7_0 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.APIVersion
API version corresponding to FoundationDB 7.0.
API_VERSION_7_1 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.APIVersion
API version corresponding to FoundationDB 7.1.
APIVersion - Enum in com.apple.foundationdb.record.provider.foundationdb
An enum representing the different supported FDB API versions.
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
 
appendPathString(StringBuilder) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.Resolved
 
appendPathString(StringBuilder) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRoot
 
appendString(StringBuilder) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.Resolved
 
appendValue(StringBuilder, Object) - Static method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
 
apply(A, Value, List<R>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRule.OnMatchComputationFunction
 
apply(FDBRecordStoreBase<M>, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction
 
apply(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression
 
apply(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues
 
apply(EnumeratingIterator<CorrelationIdentifier>, List<CorrelationIdentifier>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.graph.EnumerationFunction
Called directly or indirectly by matching logic in BaseMatcher.match(com.apple.foundationdb.record.query.plan.cascades.matching.graph.EnumerationFunction<R>, boolean) using an EnumeratingIterator for ordered aliases on this side and one stable non-violating ordering o the other side.
apply(CorrelationIdentifier, LeafValue) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap.TranslationFunction
 
apply(Memoizer, RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
When applied to a reference this method returns a RelationalExpression consuming the reference passed in that applies additional predicates as expressed by e.g.
apply(Memoizer, RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Compensation.ForMatch
When applied to a reference this method returns a RelationalExpression consuming the reference passed in that applies additional predicates as expressed by the predicate compensation map.
apply(Tuple) - Method in enum com.apple.foundationdb.record.query.plan.planning.BindingFunction
 
apply(Descriptors.GenericDescriptor, Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.ArrayCoercionBiFunction
 
apply(Descriptors.GenericDescriptor, Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.PrimitiveCoercionBiFunction
 
apply(Object) - Method in class com.apple.foundationdb.record.cursors.aggregate.StreamGrouping
Accept the next record, decide whether this next record constitutes a group break.
apply(Throwable, StoreTimer.Event) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabase.ExceptionMapper
 
apply(T) - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike.NonnullFunction
Applies this function to the given argument.
apply(T, T, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.graph.MatchFunction
Compute a match result.
apply(T, U) - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike.NonnullBiFunction
Applies this function to the given arguments.
apply(T, U, V) - Method in interface com.apple.foundationdb.record.util.TriFunction
Applies this function to the given arguments.
applyAbsorptionLaw(List<Collection<? extends QueryPredicate>>) - Static method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer
 
applyAllNeededCompensations(Memoizer, RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
 
applyComparisonKey(List<OrderingPart.ProvidedOrderingPart>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.SetOperationsOrdering
 
applyCompensationForPredicate(CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateCompensationFunction
 
applyCompensationForResult(CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.ResultCompensationFunction
 
applyCondition(QueryComponent) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
 
applyFinal(Memoizer, RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
When applied to a reference this method returns a RelationalExpression consuming the reference passed in that applies a final shape correction as needed by e.g.
applyFinal(Memoizer, RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Compensation.ForMatch
 
applyRegularVisitors(RecordQueryPlannerConfiguration, RecordQueryPlan, RecordMetaData, PlannableIndexTypes, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.visitor.RecordQueryPlannerSubstitutionVisitor
 
applyToComparisonMaybe(Comparisons.Comparison) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComparisonCompensation
Apply the compensation to a value tree.
applyToComparisonMaybe(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComparisonCompensation.NestedInvertableComparisonCompensation
 
applyToValue(Value) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComparisonCompensation
Apply the compensation to a value tree.
applyToValue(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComparisonCompensation.NestedInvertableComparisonCompensation
 
applyTranslationFunction(CorrelationIdentifier, LeafValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap
 
areAllBindingsFixed(Collection<Ordering.Binding>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
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 - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
ARGUMENT_TO_ARITHMETIC_OPERATOR_IS_OF_COMPLEX_TYPE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
ARGUMENT_TO_COLLATE_IS_OF_COMPLEX_TYPE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
arguments - Variable in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
 
arithmeticValue(CollectionMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
ArithmeticValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value that applies an arithmetic operation on its child expressions.
ArithmeticValue(ArithmeticValue.PhysicalOperator, Value, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
Constructs a new instance of ArithmeticValue.
ArithmeticValue.AddFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The add function.
ArithmeticValue.BitAndFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The bitwise and function.
ArithmeticValue.BitmapBitPositionFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The bitmap_bit_position function.
ArithmeticValue.BitmapBucketNumberFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The bitmap_bucket_number function.
ArithmeticValue.BitmapBucketOffsetFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The bitwise bitmap_bucket_offset function.
ArithmeticValue.BitOrFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The bitwise or function.
ArithmeticValue.BitXorFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The bitwise xor function.
ArithmeticValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
ArithmeticValue.DivFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The div function.
ArithmeticValue.LogicalOperator - Enum in com.apple.foundationdb.record.query.plan.cascades.values
Logical operator.
ArithmeticValue.ModFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The mod function.
ArithmeticValue.MulFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The mul function.
ArithmeticValue.PhysicalOperator - Enum in com.apple.foundationdb.record.query.plan.cascades.values
Physical operators.
ArithmeticValue.SubFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The sub function.
Array() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
Constructs a new nullable array type instance without a value Type.
Array(boolean, Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
 
Array(Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
Constructs a new nullable array type instance.
ARRAY - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
ArrayCoercionBiFunction(Type.Array, Type.Array, MessageHelpers.CoercionTrieNode) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.ArrayCoercionBiFunction
 
ArrayFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.ArrayFn
 
asAndPredicate() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
asAndPredicate() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Sealed
 
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.FDBStoredRecord
Get a builder with the parameters of this stored record.
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.
ascending() - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Binding
 
ASCENDING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
 
ASCENDING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
Ascending.
ASCENDING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
Ascending.
ASCENDING_NULLS_LAST - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
 
ASCENDING_NULLS_LAST - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
Ascending but with nulls after regular values.
ASCENDING_NULLS_LAST - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
Ascending but with nulls after regular values.
asComparisonRange() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
Returns an equivalent ComparisonRange.
asGraph() - Method in class com.google.common.graph.StableStandardMutableNetwork
 
asIterator() - Method in interface com.apple.foundationdb.record.RecordCursor
Return a view of this cursor as a RecordCursorIterator.
asList() - Method in interface com.apple.foundationdb.record.RecordCursor
Return the entire stream of records as an asynchronous list.
asList(AtomicReference<RecordCursorResult<T>>) - Method in interface com.apple.foundationdb.record.RecordCursor
Return a stream of records as an asynchronous list.
asMappingList() - Method in class com.apple.foundationdb.record.Bindings
 
asMultiMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings
Return the bindings as multimap for callers that need reason about all bindings in a generic manner, e.g.
asOr() - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
 
asPlaceholder(CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Method to create a PredicateWithValueAndRanges placeholder that is based on this value.
asScanProperties(boolean) - Method in class com.apple.foundationdb.record.ExecuteProperties
 
asScoredPlan(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredMatch
 
assignedFormerPrefixes - Variable in class com.apple.foundationdb.record.metadata.MetaDataValidator
 
assignedPrefixes - Variable in class com.apple.foundationdb.record.metadata.MetaDataValidator
 
ASSIGNMENT - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
asStream() - Method in interface com.apple.foundationdb.record.RecordCursor
Retrieve a sequential stream of type T that registers an on-close handler that will close this RecordCursor when the stream is closed.
asStream(Runnable) - Method in interface com.apple.foundationdb.record.RecordCursor
Retrieve a sequential stream of type T that registers the supplied on-close handler that will execute when the stream is closed.
AsyncBoolean<M extends Message,Q> - Class in com.apple.foundationdb.record.query.expressions
An asynchronous Boolean and / or over a sequence of operands.
AsyncBoolean(boolean, List<Q>, Function<Q, CompletableFuture<Boolean>>, FDBRecordStoreBase<M>) - Constructor for class com.apple.foundationdb.record.query.expressions.AsyncBoolean
 
AsyncIteratorCursor<T> - Class in com.apple.foundationdb.record.cursors
A cursor that returns the elements of an AsyncIterator.
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, long, long, ScheduledExecutorService) - Constructor for class com.apple.foundationdb.record.AsyncLoadingCache
Create a new cache that loads items asynchronously.
AsyncLock - Class in com.apple.foundationdb.record.locking
The data-structure to maintain the current state of requested locks on a particular resource.
AsyncLockCursor<T> - Class in com.apple.foundationdb.record.cursors
A wrapper cursor that manages the locking of resources before operating on inner cursor.
AsyncLockCursor(AsyncLock, RecordCursor<T>) - Constructor for class com.apple.foundationdb.record.cursors.AsyncLockCursor
 
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
 
AtomicMutation - Interface in com.apple.foundationdb.record.provider.foundationdb.indexes
The particular operation to be performed by an AtomicMutationIndexMaintainer index.
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 for AtomicMutationIndexMaintainer indexes.
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, its presence is significant to the meaning of the expression.
Attribute - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Basic interface for all attributes of AbstractPlannerGraph.AbstractNode as well as AbstractPlannerGraph.AbstractEdge.
Attribute.CommonAttribute - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Interface for attributes of AbstractPlannerGraph.AbstractNode as well as AbstractPlannerGraph.AbstractEdge that are used to serialize to GML or to DOT.
Attribute.DotAttribute - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Interface for attributes of AbstractPlannerGraph.AbstractNode as well as AbstractPlannerGraph.AbstractEdge that are used to serialize to DOT.
Attribute.GmlAttribute - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Basic interface all attributes of AbstractPlannerGraph.AbstractNode as well as AbstractPlannerGraph.AbstractEdge that are use to serialize to GML.
Attribute.InvisibleAttribute - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Interface for attributes of AbstractPlannerGraph.AbstractNode as well as AbstractPlannerGraph.AbstractEdge that 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 new AutoContinuingCursor.
AutoContinuingCursor(FDBDatabaseRunner, BiFunction<FDBRecordContext, byte[], RecordCursor<T>>, int) - Constructor for class com.apple.foundationdb.record.cursors.AutoContinuingCursor
Creates a new AutoContinuingCursor.
availableFields(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.visitor.RecordQueryPlannerSubstitutionVisitor
 
availableFields(RecordMetaData, PlannableIndexTypes, KeyExpression, RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.visitor.RecordQueryPlannerSubstitutionVisitor
 
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.ConditionalUponPathPredicate - Class in com.apple.foundationdb.record.query.plan
A copy-if-predicate that returns true if a particula ordinal path already exists in the tuple.
AvailableFields.ConditionalUponPathPredicate.Deserializer - Class in com.apple.foundationdb.record.query.plan
Deserializer.
AvailableFields.CopyIfPredicate - Interface in com.apple.foundationdb.record.query.plan
A predicate that tests whether a copy in IndexKeyValueToPartialRecord.Copier is necessary.
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.
AvailableFields.TruePredicate - Class in com.apple.foundationdb.record.query.plan
A copy-if-predicate that always returns true.
AvailableFields.TruePredicate.Deserializer - Class in com.apple.foundationdb.record.query.plan
Deserializer.
AverageAccumulatorState<T extends Number> - Class in com.apple.foundationdb.record.cursors.aggregate
Accumulator state for AVERAGE operations.
Avg(PlanSerializationContext, PNumericAggregationValue.PAvg) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Avg
 
Avg(NumericAggregationValue.PhysicalOperator, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Avg
 
AVG_D - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
AVG_F - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
AVG_I - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
AVG_L - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
AVG_POSITIONS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
AVG_TOKEN_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
AvgFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.AvgFn
 

B

BAD_INDEX_ENTRY - Enum constant in enum 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.cascades.explain.NodeIcon
 
BASE_DATA - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
BASE_HASH - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
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-like QueryComponents that involve predicates on one particular record field, as specified by the BaseField.fieldName member.
BaseField(String) - Constructor for class com.apple.foundationdb.record.query.expressions.BaseField
 
baseHash(PlanHashable.PlanHashMode, ObjectPlanHash) - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
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 when BaseKeyExpression.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.
BaseMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.graph
Abstract base class for all matchers.
BaseMatcher(AliasMap, Set<CorrelationIdentifier>, Function<T, CorrelationIdentifier>, Map<CorrelationIdentifier, T>, ImmutableSetMultimap<CorrelationIdentifier, CorrelationIdentifier>, Set<CorrelationIdentifier>, Function<T, CorrelationIdentifier>, Map<CorrelationIdentifier, ? extends T>, ImmutableSetMultimap<CorrelationIdentifier, CorrelationIdentifier>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
Dumb constructor.
BaseNestedField - Class in com.apple.foundationdb.record.query.expressions
An abstract base class for all QueryComponents that represent a query of a nested record type.
BaseNestedField(String, QueryComponent) - Constructor for class com.apple.foundationdb.record.query.expressions.BaseNestedField
 
basePlanHash(PlanHashable.PlanHashMode, ObjectPlanHash, Object...) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
Base implementation of PlanHashable.planHash(PlanHashMode).
basePlanHash(PlanHashable.PlanHashMode, ObjectPlanHash, Object...) - Method in class com.apple.foundationdb.record.query.expressions.BaseField
Base implementation of PlanHashable.planHash(PlanHashMode).
basePlanHash(PlanHashable.PlanHashMode, ObjectPlanHash, Object...) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
Base implementation of PlanHashable.planHash(PlanHashMode).
basePlanHash(PlanHashable.PlanHashMode, ObjectPlanHash, Object...) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
Base implementation of PlanHashable.planHash(PlanHashMode).
basePlanHash(PlanHashable.PlanHashMode, ObjectPlanHash, Object...) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
Base implementation of PlanHashable.planHash(PlanHashMode).
basePlanHash(PlanHashable.PlanHashMode, ObjectPlanHash, Object...) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
Base implementation of PlanHashable.planHash(PlanHashMode).
basePlanHash(PlanHashable.PlanHashMode, ObjectPlanHash, Object...) - Method in class com.apple.foundationdb.record.RecordFunction
Base implementation of PlanHashable.planHash(PlanHashMode).
baseQueryHash(QueryHashable.QueryHashKind, ObjectPlanHash, Object...) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
baseQueryHash(QueryHashable.QueryHashKind, ObjectPlanHash, Object...) - Method in class com.apple.foundationdb.record.query.expressions.BaseField
baseQueryHash(QueryHashable.QueryHashKind, ObjectPlanHash, Object...) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
baseQueryHash(QueryHashable.QueryHashKind, ObjectPlanHash, Object...) - Method in class com.apple.foundationdb.record.RecordFunction
BATCH - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBTransactionPriority
The priority level that should be used for batch operations.
BATCH_GET_READ_VERSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken to get a read version for batch priority transactions.
BATCH_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
BEFORE - Enum constant in enum com.apple.foundationdb.record.cursors.MapWhileCursor.StopContinuation
Return the continuation before the record that stopped the cursor.
begin() - Static method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
BEGIN - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
BEGIN - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
 
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 a TupleRange over all keys between the given Tuples.
BETWEEN - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
betweenInclusive(Tuple, Tuple) - Static method in class com.apple.foundationdb.record.TupleRange
Create a TupleRange over all keys between the given Tuples, including both endpoints.
BiFunctionBuilder(String, BiFunction<String, KeyExpression, FunctionKeyExpression>) - Constructor for class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression.BiFunctionBuilder
 
binaryFunction(String, String, BinaryOperator<Long>) - Static method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression.Builder
Variant of LongArithmethicFunctionKeyExpression.Builder.binaryFunction(String, BinaryOperator) that supports using an alternate name for the BuiltInFunction used by the planner.
binaryFunction(String, BinaryOperator<Long>) - Static method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression.Builder
Create a new builder of a binary function.
bind(FDBRecordStore) - Method in class com.apple.foundationdb.record.query.RecordQuery
 
bind(FDBRecordStoreBase<?>, Index, EvaluationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
bind(FDBRecordStoreBase<?>, Index, EvaluationContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScanParameters
Get the bound form of the index scan for use by the maintainer.
bind(FDBRecordStoreBase<?>, Index, EvaluationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons
 
bind(FDBRecordStoreBase<?>, Index, EvaluationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
bind(FDBRecordStore, Bindings) - Method in class com.apple.foundationdb.record.query.RecordQuery
 
bindAggregateFunction(FDBRecordStore, IndexAggregateFunction, List<String>, IndexQueryabilityFilter) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
 
bindAggregateFunctionCall(FDBRecordStore, IndexAggregateFunctionCall, List<String>, IndexQueryabilityFilter) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
(Public) method to bind an IndexAggregateFunctionCall to an index resulting in an IndexAggregateFunction if successful.
bindIdentities(RelationalExpression, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Given the correlatedTo sets c1 and c2 of this expression and some other expression compute a set of bindings that contains identity bindings (a -> a) for the intersection of c1 and c2.
bindIndexForPermutableAggregateFunctionCall(FDBRecordStore, IndexAggregateFunctionCall, List<String>, IndexQueryabilityFilter) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
Bind a IndexAggregateFunctionCall to an index and return a resulting IndexAggregateFunction and IndexMaintainer.
BindingFunction - Enum in com.apple.foundationdb.record.query.plan.planning
Helper methods for manipulating parameter values passed in Bindings.
BindingMatcher<T> - Interface in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A binding matcher is an object that can be matched against a complex object tree, while binding certain references in the tree to matcher objects.
bindingName() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
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 for Bindings.
Bindings.Internal - Enum in com.apple.foundationdb.record
Bindings slots used internally by plan operators.
bindMatches(RecordQueryPlannerConfiguration, PlannerBindings, Object) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
A matcher is completely agnostic to the actual class of an object that is being passed in meaning that a matcher that can only match e.g.
bindMatchesForPermutation(RecordQueryPlannerConfiguration, PlannerBindings, List<Equivalence.Wrapper<T>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.SetMatcher
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ContainsExpressionInReferenceMatcher
Attempt to match this matcher against the given expression.
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, Iterable<? extends T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AnyMatcher
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.NotMatcher
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, Collection<T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ListMatcher
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, Collection<T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MultiMatcher
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, Collection<T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.SetMatcher
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, Optional<T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.OptionalIfPresentMatcher
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, T) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AllOfMatcher
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, T) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AnyOfMatcher
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, T) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
Attempt to match this matcher against the given object.
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, T) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.InstanceMatcher
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, T) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcher
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, T) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcherWithExtractAndDownstream
 
bindMatchesSafely(RecordQueryPlannerConfiguration, PlannerBindings, T) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcherWithPredicate
 
BITAND - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
BITAND - Static variable in class com.apple.foundationdb.record.FunctionNames
 
BITAND_II - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITAND_IL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITAND_LI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITAND_LL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BitAndFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.BitAndFn
 
BITMAP_BIT_POSITION - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
BITMAP_BIT_POSITION - Static variable in class com.apple.foundationdb.record.FunctionNames
 
BITMAP_BIT_POSITION_II - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITMAP_BIT_POSITION_LI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITMAP_BUCKET_NUMBER - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
BITMAP_BUCKET_NUMBER_II - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITMAP_BUCKET_NUMBER_LI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITMAP_BUCKET_OFFSET - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
BITMAP_BUCKET_OFFSET - Static variable in class com.apple.foundationdb.record.FunctionNames
 
BITMAP_BUCKET_OFFSET_II - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITMAP_BUCKET_OFFSET_LI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITMAP_CONSTRUCT_AGG_I - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
BITMAP_CONSTRUCT_AGG_L - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
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 for IndexTypes.BITMAP_VALUE indexes.
BitmapAggregateIndexExpansionVisitor - Class in com.apple.foundationdb.record.query.plan.cascades
The bitmap aggregate index expansion visitor.
BitmapAggregateIndexExpansionVisitor(Index, Collection<RecordType>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.BitmapAggregateIndexExpansionVisitor
Constructs a new instance of BitmapAggregateIndexExpansionVisitor.
BitmapBitPositionFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.BitmapBitPositionFn
 
BitmapBucketNumberFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.BitmapBucketNumberFn
 
BitmapBucketOffsetFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.BitmapBucketOffsetFn
 
BitmapConstructAgg(PlanSerializationContext, PNumericAggregationValue.PBitmapConstructAgg) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.BitmapConstructAgg
 
BitmapConstructAgg(NumericAggregationValue.PhysicalOperator, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.BitmapConstructAgg
 
BitmapConstructAggFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.BitmapConstructAggFn
 
bitmapConstructAggValue(BindingMatcher<V>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
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
BitmapValueIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.BitmapValueIndexMaintainerFactory
 
BITNOT - Static variable in class com.apple.foundationdb.record.FunctionNames
 
BITOR - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
BITOR - Static variable in class com.apple.foundationdb.record.FunctionNames
 
BITOR_II - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITOR_IL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITOR_LI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITOR_LL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BitOrFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.BitOrFn
 
BITWISE_AND - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
BITWISE_OR - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
BITWISE_XOR - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
BITXOR - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
BITXOR - Static variable in class com.apple.foundationdb.record.FunctionNames
 
BITXOR_II - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITXOR_IL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITXOR_LI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BITXOR_LL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
BitXorFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.BitXorFn
 
BLACK - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
blockIndexBuilds(String, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Block partly built indexes, preventing continuation.
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), or FDBDatabase.get(CompletableFuture)) is called from within a CompletableFuture completion 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 whether FDBDatabase.asyncToSync(FDBStoreTimer, FDBStoreTimer.Wait, java.util.concurrent.CompletableFuture) or FDBRecordContext.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.
blockingInAsyncDetectionSupplier - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
BlockingInAsyncException - Exception in com.apple.foundationdb.record.provider.foundationdb
Exception thrown when asyncToSync detects 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
 
BLUE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
BOOLEAN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
 
BOOLEAN - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
BOOLEAN - Enum constant in enum com.apple.foundationdb.record.query.plan.planning.BindingFunction
 
BooleanComponent - Interface in com.apple.foundationdb.record.query.expressions
A boolean component is a component representing an operation in the boolean algebra, e.g.
BooleanNormalizer - Class in com.apple.foundationdb.record.query.plan.planning
A normalizer of a tree of QueryComponent predicates into disjunctive normal form.
BooleanPredicateNormalizer - Class in com.apple.foundationdb.record.query.plan.planning
A normalizer of a tree of QueryPredicates into a normal form which may be its conjunctive or disjunctive normal form.
BooleanPredicateNormalizer.Mode - Enum in com.apple.foundationdb.record.query.plan.planning
The target normal form.
BooleanPredicateNormalizer.PredicateMetrics - Class in com.apple.foundationdb.record.query.plan.planning
Case class for metrics we need to keep track of for various purposes.
booleanPropertyKey(String, boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
 
BooleanValue - Interface in com.apple.foundationdb.record.query.plan.cascades.values
Shim class to translate objects of type Value to QueryPredicate.
BooleanWithConstraint - Class in com.apple.foundationdb.record.query.plan.cascades
A boolean container that can if the boolean is true carry a QueryPlanConstraint.
borrowCipher() - Static method in class com.apple.foundationdb.record.provider.common.CipherPool
 
borrowCipher(String) - Static method in class com.apple.foundationdb.record.provider.common.CipherPool
 
bothFunction(String, String, UnaryOperator<Long>, BinaryOperator<Long>) - Static method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression.Builder
Variant of LongArithmethicFunctionKeyExpression.Builder.bothFunction(String, UnaryOperator, BinaryOperator) that supports using an alternate name for the BuiltInFunction used by the planner.
bothFunction(String, UnaryOperator<Long>, BinaryOperator<Long>) - Static method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression.Builder
Create a new builder of a function that can be either unary or binary.
BoundEquivalence(AliasMap) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Correlated.BoundEquivalence
 
BoundMatch<R> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.graph
Case class to represent a match for matchers that compute a result.
BoundRecordQuery - Class in com.apple.foundationdb.record.query
A bound record query wraps an instance of RecordQuery and RecordStoreState in order to associate the query with the state of a store.
BoundRecordQuery(RecordStoreState, RecordQuery) - Constructor for class com.apple.foundationdb.record.query.BoundRecordQuery
 
BoundRecordQuery(RecordStoreState, RecordQuery, Bindings) - Constructor for class com.apple.foundationdb.record.query.BoundRecordQuery
 
BracketLikeToken(int, boolean, String) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.BracketLikeToken
 
BRACKETS_CLOSE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
BRACKETS_OPEN - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
BRIGHT_BLACK - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
BRIGHT_BLUE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
BRIGHT_CYAN - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
BRIGHT_GREEN - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
BRIGHT_MAGENTA - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
BRIGHT_RED - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
BRIGHT_WHITE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
BRIGHT_YELLOW - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
browse(String, Map<String, String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.debug.BrowserHelper
Show the planner expression that is passed in as a graph rendered in your default browser.
BrowserHelper - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Helper class to interface with the system browser.
build() - Method in class com.apple.foundationdb.record.Bindings.Builder
 
build() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
build() - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
Create a MetaDataEvolutionValidator using the options specified through this builder.
build() - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
Construct a TransformedRecordSerializer from the parameters specified by this builder.
build() - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
Construct a TransformedRecordSerializerJCE from the parameters specified by this builder.
build() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Create an FDBRecordContextConfig from 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.IndexPrefetchRangeKeyValueCursor.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 an OnlineIndexer.
build() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
 
build() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
build() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.Builder
build() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy.Builder
 
build() - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyStorage.Builder
 
build() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet.Builder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap.Builder
Build a new AliasMap.
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.PlannerGraphBuilder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.InternalPlannerGraphBuilder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedBuilder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings.Builder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMap.Builder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.Builder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.Builder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.FieldAccessTrieNodeBuilder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.Builder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ValueMap.Builder
 
build() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap.Builder
 
build() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
 
build() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo.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.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(KeyExpression) - Method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression.Builder
 
build(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Builder
 
build(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Existential.ExistentialBuilder
 
build(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach.ForEachBuilder
 
build(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical.PhysicalBuilder
 
build(TypeRepository) - Method in class com.apple.foundationdb.record.EvaluationContextBuilder
Construct an EvaluationContext with updated bindings.
build(RecordMetaData) - Method in class com.apple.foundationdb.record.metadata.NestedRecordTypeBuilder
 
build(RecordMetaData) - Method in class com.apple.foundationdb.record.metadata.RecordTypeBuilder
 
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(RecordMetaData, Descriptors.FileDescriptor) - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordTypeBuilder
 
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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
Only build if the index is disabled.
BUILD_IF_DISABLED_CONTINUE_BUILD_IF_WRITE_ONLY - Enum constant in enum 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_CONTINUE_BUILD_IF_WRITE_ONLY_ERROR_IF_POLICY_CHANGED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
Build if the index is disabled; Continue build if the index is write-only and the requested method is the same as the previous one.
BUILD_IF_DISABLED_CONTINUE_BUILD_IF_WRITE_ONLY_REBUILD_IF_POLICY_CHANGED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
Build if the index is disabled; Continue build if the index is write-only - only if the requested method matches the previous one, else restart the built.
BUILD_IF_DISABLED_REBUILD_IF_WRITE_ONLY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
Build if the index is disabled; Rebuild if the index is write-only.
buildAndBind(FDBRecordStore) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
 
buildAndBind(FDBRecordStore, Bindings) - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
 
buildCommitRetryAsync(BiFunction<FDBRecordStore, AtomicLong, CompletableFuture<R>>, Function<FDBException, Optional<R>>, List<Object>, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingThrottle
 
buildCommitRetryAsync(BiFunction<FDBRecordStore, AtomicLong, CompletableFuture<R>>, List<Object>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
buildCommitRetryAsync(BiFunction<FDBRecordStore, AtomicLong, CompletableFuture<R>>, List<Object>, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
buildDescriptor(DescriptorProtos.FileDescriptorProto.Builder, Set<Descriptors.FileDescriptor>) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordTypeBuilder
 
buildDescriptor(DescriptorProtos.FileDescriptorProto.Builder, Set<Descriptors.FileDescriptor>) - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordTypeBuilder
 
buildEndpoints() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingByRecords
Builds (with a retry loop) the endpoints of an index.
buildEndpoints() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Deprecated, for removal: This API element is subject to removal in a future version.
buildEndpoints(FDBRecordStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Deprecated, for removal: This API element is subject to removal in a future version.
buildEndpoints(FDBRecordStore, AtomicLong) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingByRecords
Builds (transactionally) the endpoints of an index.
builder() - Static method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
builder() - Static method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Create a new empty builder.
builder() - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
builder() - Static method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMap
 
builder() - Static method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap
 
builder() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap
 
builder() - Static method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
 
builder(int) - Static method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Create a new empty builder using an expected size that is passed in.
builder(PlannerGraph.Node) - Static method in class com.apple.foundationdb.record.query.plan.cascades.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.IndexingPolicy.Builder
 
Builder() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
 
Builder() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.Builder
 
Builder() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy.Builder
 
Builder() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings.Builder
 
Builder() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.PredicateMap.Builder
 
Builder() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.Builder
 
Builder() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Builder
 
Builder() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap.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.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(QueryPredicate, QueryPredicate, QueryPredicate, PredicateMultiMap.PredicateMapping.MappingKind) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.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(Subspace) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
 
Builder(Subspace) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
Builder(String) - Constructor for class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression.Builder
 
builderWithInheritedPlaceholders() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Sealed
 
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.
buildIndexAsync(boolean, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
buildIndexKeyValueToPartialRecord(RecordType) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields
 
buildIndexSingleTarget() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Deprecated, for removal: This API element is subject to removal in a future version.
buildMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMap.Builder
 
buildMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.Builder
 
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
 
buildPrimaryKey() - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordTypeBuilder
 
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.IndexingByRecords
Builds (with a retry loop) the index by adding records with primary keys within the given range.
buildRange(Key.Evaluated, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Deprecated, for removal: This API element is subject to removal in a future version.
buildRange(FDBRecordStore, Key.Evaluated, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingByRecords
Builds (transactionally) 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
Deprecated, for removal: This API element is subject to removal in a future version.
buildRequestedOrdering(List<Value>, boolean, Quantifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
buildSelect() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
buildSelect() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Sealed
 
buildSelectWithResultValue(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
buildSelectWithResultValue(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Sealed
 
buildSimpleSelectOverQuantifier(Quantifier.ForEach) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
buildSimpleSelectOverQuantifier(Quantifier.ForEach) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Sealed
 
buildSingleRecord(FDBIndexedRawRecord) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
buildSingleRecord(FDBIndexedRawRecord) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
buildSingleRecord(FDBIndexedRawRecord) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
buildSingleRecordInternal(FDBIndexedRawRecord, RecordSerializer<M>, ByteScanLimiter) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
buildUnbuiltRange(FDBRecordStore, Key.Evaluated, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingByRecords
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
Deprecated, for removal: This API element is subject to removal in a future version.
buildValue(Supplier<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
 
BuiltInFunction<T extends Typed> - Class in com.apple.foundationdb.record.query.plan.cascades
Main interface for defining a built-in function that can be evaluated against a number of arguments.
BuiltInFunction(String, List<Type>, EncapsulationFunction<T>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
Creates a new instance of BuiltInFunction.
BuiltInFunction(String, List<Type>, Type, EncapsulationFunction<T>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
Creates a new instance of BuiltInFunction.
BY_GROUP - Static variable in class com.apple.foundationdb.record.IndexScanType
 
BY_RANK - Static variable in class com.apple.foundationdb.record.IndexScanType
 
BY_RECORDS_TO_MUTUAL - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.TakeoverTypes
Allow converting (single or multi target) by-records to mutual.
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
 
BY_VALUE_OVER_SCAN - Static variable in class com.apple.foundationdb.record.IndexScanType
 
BYTE_LIMIT_REACHED - Enum constant in enum com.apple.foundationdb.record.RecordCursor.NoNextReason
The limit on the number of bytes to scan was reached.
BYTE_STRING - Enum constant in enum com.apple.foundationdb.record.query.plan.planning.BindingFunction
 
ByteArrayContinuation - Class in com.apple.foundationdb.record
A shim to wrap old-style byte array continuations.
BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
 
BYTES - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
BYTES_DELETED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.CountAggregates
The number of bytes deleted.
BYTES_FETCHED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Bytes read.
BYTES_READ - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of bytes read.
BYTES_WRITTEN - Enum constant in enum 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 of ByteScanLimiters.
ByteStringBoundException(byte[]) - Constructor for exception com.apple.foundationdb.record.TupleRange.ByteStringBoundException
 
byValue() - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
byValue(ScanComparisons) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
byValue(ScanComparisons, IndexScanType) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
byValue(ScanComparisons, List<ScanComparisons>, ScanComparisons) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 

C

CACHEABLE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.StateCacheabilityOnOpen
Update the store state cacheability flag to true during FDBRecordStore.checkVersion(UserVersionChecker, StoreExistenceCheck).
CACHEABLE_IF_NEW - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.StateCacheabilityOnOpen
On existing stores, the store state cacheability flag is not changed.
CACHEABLE_STATE_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
CACHED_KEY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
CACHED_STATE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
CACHED_VERSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
calculatePrefixLength() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
Calculate the key prefix length for the returned values.
call(List<Object>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfValue
 
CALLING_CLASS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
CALLING_LINE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
CALLING_METHOD - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
callToString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.ScoreForRank
 
canAppend() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexBunchedSerializer
Return true as this serialization format supports appending.
canBeDeferred() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
Returns if this compensation can further be combined with subsequent compensations further up the graph or whether this compensation would actually have to be applied exactly at the position in the graph that created it.
canBeImplemented() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
cancel() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
cancel() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
cancel() - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
 
cancel() - Method in class com.apple.foundationdb.record.RecordCursorIterator
 
canCorrelate() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
canCorrelate() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Returns if this expression can be the anchor of a correlation.
canCorrelate() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
canCorrelate() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
canCorrelate() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
canCorrelate() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
canDeleteGroup(QueryToKeyMatcher, Key.Evaluated) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
 
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.MultidimensionalIndexMaintainer
 
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.PermutedMinMaxIndexMaintainer
 
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 a FDBRecordStoreBase.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.
candidateContainingPrimaryKey(Collection<RecordQueryPlanner.ScoredPlan>, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
Find a candidate key for the sort that includes (at least) the given primary key.
CandidateScan(RecordQueryPlanner.PlanContext, Index, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.CandidateScan
 
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.PermutedMinMaxIndexMaintainer
 
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
Return true if this index be used to evaluate the given record function.
canEvaluateRecordFunction(IndexRecordFunction<?>) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
 
canResultInType(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue
 
canResultInType(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
canResultInType(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
canResultInType(Type) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
canTransitionToNewStep() - Method in interface com.apple.foundationdb.record.cursors.RecursiveUnionCursor.RecursiveStateManager
Checks whether it is possible to transition from current recursive step n to next step n + 1.
Cardinalities(CardinalitiesProperty.Cardinality, CardinalitiesProperty.Cardinality) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty.Cardinalities
 
CardinalitiesProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
This property attempts to derive the minimum and the maximum cardinality of the conceptual result of a RelationalExpression.
CardinalitiesProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
CardinalitiesProperty.Cardinalities - Class in com.apple.foundationdb.record.query.plan.cascades.properties
Class to capture both minimum and maximum cardinality of an expression.
CardinalitiesProperty.Cardinality - Class in com.apple.foundationdb.record.query.plan.cascades.properties
Class to encapsulate the minimum or maximum cardinality of an expression.
CascadesCostModel - Class in com.apple.foundationdb.record.query.plan.cascades
A comparator implementing the current heuristic cost model for the CascadesPlanner.
CascadesCostModel(RecordQueryPlannerConfiguration) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.CascadesCostModel
 
CascadesPlanner - Class in com.apple.foundationdb.record.query.plan.cascades
A Cascades-style query planner that converts a RecordQuery to a RecordQueryPlan, possibly using secondary indexes defined in a RecordMetaData to execute the query efficiently.
CascadesPlanner(RecordMetaData, RecordStoreState) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
 
CascadesPlanner(RecordMetaData, RecordStoreState, PlannerRuleSet) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
 
CascadesPlanner.Task - Interface in com.apple.foundationdb.record.query.plan.cascades
Represents actual tasks in the task stack of the planner.
CascadesRule<T> - Class in com.apple.foundationdb.record.query.plan.cascades
Classes that inherit from CascadesRule form the base of the Cascades planning system.
CascadesRule(BindingMatcher<T>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.CascadesRule
 
CascadesRule(BindingMatcher<T>, Collection<PlannerConstraint<?>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.CascadesRule
 
CascadesRuleCall - Class in com.apple.foundationdb.record.query.plan.cascades
A rule call implementation for the CascadesPlanner.
CascadesRuleCall(PlanContext, CascadesRule<?>, Reference, Traversal, Deque<CascadesPlanner.Task>, PlannerBindings, EvaluationContext) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.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 a ChainedCursor.
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 new ChainedCursor.
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(boolean, SemanticException.ErrorCode) - Static method in exception com.apple.foundationdb.record.query.plan.cascades.SemanticException
 
check(boolean, SemanticException.ErrorCode, String) - Static method in exception com.apple.foundationdb.record.query.plan.cascades.SemanticException
 
CHECK_INDEX_BUILD_TYPE_DURING_UPDATE_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
CHECK_INDEX_UNIQUENESS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent checking an index for duplicate entries to preserve uniqueness.
CHECK_VERSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time in the checkVersion call.
checkAndPrepareOrderedFieldPaths(Map<FieldValue.FieldPath, ? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
 
checkAnyOngoingOnlineIndexBuilds() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
checkAnyOngoingOnlineIndexBuildsAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Check if the index is being built by any of the OnlineIndexers (only if they use SynchronizedSessions), including this OnlineIndexer.
checkAnyOngoingOnlineIndexBuildsAsync(FDBRecordStore, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Check if the index is being built by any of OnlineIndexers (only if they use SynchronizedSessions).
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.
checkCorrectness() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMap.Builder
 
checkCorrectness() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.Builder
 
CheckedSubspace(byte[], boolean, boolean, int, int) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.MinimumTupleSizeKeyChecker.CheckedSubspace
Create a new checked subspace.
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.
checkIfBlockingInFuture(CompletableFuture<?>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
 
checkIndexingStampFrequencyMilliseconds(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
During indexing, the indexer can check the current indexing stamp and throw an exception if it had changed.
checkKey(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
checkKey(byte[], boolean) - Method in interface com.apple.foundationdb.record.provider.foundationdb.KeyChecker
Check a single key.
checkKey(byte[], boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
checkKey(byte[], boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.MinimumTupleSizeKeyChecker
 
checkKey(KeySelector) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
checkKey(Range) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
checkKeyRange(byte[], byte[], boolean) - Method in interface com.apple.foundationdb.record.provider.foundationdb.KeyChecker
Check a key range.
checkKeyRange(byte[], byte[], boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
checkKeyRange(byte[], byte[], boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.MinimumTupleSizeKeyChecker
 
checkKeyRange(Range, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
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
checkUserVersion(RecordMetaDataProto.DataStoreInfo, RecordMetaDataProvider) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.UserVersionChecker
Check the user version.
checkValue(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
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.plan.cascades.predicates.NotPredicate
 
CHILD_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
CHILD_FILTER - Enum constant in enum 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
 
childrenPlans(Class<R>, CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
choose() - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Binding
 
choose(BindingMatcher<? extends E>, BindingMatcher<? extends E>, BindingMatcher<? extends E>...) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.CollectionMatcher
 
choose(List<? extends BindingMatcher<? extends E>>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.CollectionMatcher
 
CHOOSE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
Choose the sort order.
chooseK(Collection<? extends T>, int) - Static method in class com.apple.foundationdb.record.query.combinatorics.ChooseK
Create an EnumeratingIterable of the choose-K sets for a given number of elements based on a set and a function describing the depends-on relationships between items in the given set.
chooseK(Collection<T>, int, int) - Static method in class com.apple.foundationdb.record.query.combinatorics.ChooseK
Create an Iterable of the choose-K sets for a given number range of elements based on a set and a function describing the depends-on relationships between items in the given set.
ChooseK - Class in com.apple.foundationdb.record.query.combinatorics
Utility class to provide helpers related to enumeration of n choose k.
CHUNK_READ_FAILURES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Number of chunk reads that failed.
cipherName - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
 
cipherName - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
 
CipherPool - Class in com.apple.foundationdb.record.provider.common
Helper class for pooling Cipher.
claimLocalVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Claims a local version that is unique within a single transaction.
CLASS_TO_TYPE_CODE_SUPPLIER - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
A map from Java Class to corresponding Type.TypeCode.
clear() - Method in class com.apple.foundationdb.record.AsyncLoadingCache
 
clear() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
clear() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Clear the range set of all ranges.
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.cascades.ComparisonRanges
 
clear() - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
clear() - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
clear() - Method in class com.apple.foundationdb.record.query.plan.cascades.PropertiesMap
 
clear() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
clear() - Method in class com.apple.foundationdb.record.query.plan.cascades.TempTable
Clears the underlying buffer.
clear() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons.Builder
 
clear(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Clear a single key.
clear(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
clear(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
clear(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
clear(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
clear(Range) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Clear a key range.
clear(Range) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
clear(Range) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
CLEAR_WHEN_ZERO - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
Whether to remove index entry for IndexTypes.COUNT type indexes when they decrement to zero.
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 this Builder.
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.
clearRangeStartsWith(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
clearReturnedRowLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
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 this Builder.
clearSkipAndAdjustLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
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 new ExecuteProperties with an empty state.
clearStats() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
Clears all of the statistics gathered.
clearTimeLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
clearUniquenessViolations() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
 
clearUniquenessViolations() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
 
clearUniquenessViolations() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
Clear the list of uniqueness violations.
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.aggregate.AggregateCursor
 
close() - Method in class com.apple.foundationdb.record.cursors.AsyncLockCursor
 
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.FallbackCursor
 
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.AsyncIteratorCursor
 
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
Deprecated.
 
close() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
 
close() - Method in class com.apple.foundationdb.record.cursors.MapResultCursor
 
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.RangeCursor
 
close() - Method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor
 
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.cursors.TempTableInsertCursor
 
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.IndexingCommon
 
close() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
close() - Method in interface com.apple.foundationdb.record.provider.foundationdb.KeyChecker
Called when transaction it closed.
close() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
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.MinimumTupleSizeKeyChecker
 
close() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
 
close() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber
 
close() - Method in class com.apple.foundationdb.record.provider.foundationdb.runners.TransactionalRunner
 
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() - Method in class com.apple.foundationdb.record.sorting.FileSortCursor
 
close() - Method in class com.apple.foundationdb.record.sorting.MemorySortCursor
 
close() - Method in class com.apple.foundationdb.record.sorting.SortedFileReader
 
close(FDBDatabase, Transaction, StoreTimer) - Method in interface com.apple.foundationdb.record.provider.foundationdb.TransactionListener
Called immediately following the closing of a transaction.
CLOSE_CONTEXT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of times a record context is closed.
CLOSE_CONTEXT_OPEN_TOO_LONG - Enum constant in enum 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(Set<N>, GraphExporter.ComponentAttributeProvider<GraphExporter.Cluster<N, E>>, GraphExporter.ClusterProvider<N, E>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter.Cluster
 
CLUSTER - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
CNF - Enum constant in enum com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer.Mode
 
cnfRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateWithCnfRuleSet
 
COALESCE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.ComparisonFunction
 
COALESCE_ARRAY - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
COALESCE_BOOLEAN - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
COALESCE_DOUBLE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
COALESCE_FLOAT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
COALESCE_INT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
COALESCE_LONG - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
COALESCE_RECORD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
COALESCE_STRING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
CoalesceFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.CoalesceFn
 
code() - Method in enum com.apple.foundationdb.record.IndexState
Value corresponding to the state.
CODE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
coerceArray(Type.Array, Type.Array, Descriptors.GenericDescriptor, MessageHelpers.CoercionTrieNode, Object) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
Method to coerce an array.
coerceMessage(MessageHelpers.CoercionTrieNode, Type, Descriptors.Descriptor, Type, Message) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
 
coerceObject(MessageHelpers.CoercionTrieNode, Type, Descriptors.GenericDescriptor, Type, Object) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
Coerce an object to become an object of a different type.
CoercionTrieNode(MessageHelpers.CoercionBiFunction, Map<Integer, MessageHelpers.CoercionTrieNode>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.CoercionTrieNode
 
collapseRecordConstructorOverFieldsToStarRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.DefaultValueSimplificationRuleSet
 
CollapseRecordConstructorOverFieldsToStarRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that un-expands a star expansion.
CollapseRecordConstructorOverFieldsToStarRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.CollapseRecordConstructorOverFieldsToStarRule
 
CollateFunction(String, TextCollatorRegistry) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue.CollateFunction
 
CollateFunctionKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
COLLATE function.
CollateFunctionKeyExpression(TextCollatorRegistry, String, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
 
CollateFunctionKeyExpressionFactoryJRE - Class in com.apple.foundationdb.record.metadata.expressions
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
 
CollateValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value that turns a string into a locale-specific sort key.
CollateValue(TextCollatorRegistry, Value, Value, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
CollateValue.CollateFunction - Class in com.apple.foundationdb.record.query.plan.cascades.values
Base class for defining collation built-in function.
CollateValue.CollateValueJRE - Class in com.apple.foundationdb.record.query.plan.cascades.values
Define collate_jre built-in function.
CollateValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer for PCollateValue.
CollateValueJRE() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue.CollateValueJRE
 
collectConstraints(RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
collectDescendantPlans() - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
 
CollectionMatcher<T> - Interface in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Tag interface used for overloads for matchers that bind to collections of values/objects.
collectionValue(BindingMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
collectPulledUpPredicateMappings(RelationalExpression, Set<QueryPredicate>) - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedMatchInfo
 
collectPulledUpPredicateMappings(RelationalExpression, Set<QueryPredicate>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchInfo
 
collectPulledUpPredicateMappings(RelationalExpression, Set<QueryPredicate>) - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
Column<V extends Value> - Class in com.apple.foundationdb.record.query.plan.cascades
A class to hold a value computing a column together with information about the field of a record it supplies the result for.
Column(Type.Record.Field, V) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Column
 
COLUMN_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
columns - Variable in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
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.cursors.aggregate - package com.apple.foundationdb.record.cursors.aggregate
Cursor implementation classes.
com.apple.foundationdb.record.locking - package com.apple.foundationdb.record.locking
Implement locking to be used in RecordCursors and various IndexMaintainers for controlling concurrency in read/write data paths.
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.indexing - package com.apple.foundationdb.record.provider.foundationdb.indexing
Classes used during index builds.
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.properties - package com.apple.foundationdb.record.provider.foundationdb.properties
Classes for a property mechanism that supports server-side configuration for Record Layer by its adopter.
com.apple.foundationdb.record.provider.foundationdb.runners - package com.apple.foundationdb.record.provider.foundationdb.runners
Classes for running blocks of asynchronous code with-or-without retries.
com.apple.foundationdb.record.provider.foundationdb.storestate - package com.apple.foundationdb.record.provider.foundationdb.storestate
Classes for caching RecordStoreState information.
com.apple.foundationdb.record.provider.foundationdb.synchronizedsession - package com.apple.foundationdb.record.provider.foundationdb.synchronizedsession
Extends the com.apple.foundationdb.synchronizedsession package to support running operations in synchronized sessions with FDBDatabaseRunners and FDBRecordContexts.
com.apple.foundationdb.record.query - package com.apple.foundationdb.record.query
Classes for querying records.
com.apple.foundationdb.record.query.combinatorics - package com.apple.foundationdb.record.query.combinatorics
Utility package to hold general-purpose algorithms used by the Cascades planner.
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 over BITMAP_VALUE index entries.
com.apple.foundationdb.record.query.plan.cascades - package com.apple.foundationdb.record.query.plan.cascades
This will contain design docs for the Cascades planner at some point.
com.apple.foundationdb.record.query.plan.cascades.debug - package com.apple.foundationdb.record.query.plan.cascades.debug
Stub for planner debugger.
com.apple.foundationdb.record.query.plan.cascades.explain - package com.apple.foundationdb.record.query.plan.cascades.explain
This package implements a visualization of a RelationalExpression as a graph for both internal debugging purposes and for consumption by end-users.
com.apple.foundationdb.record.query.plan.cascades.expressions - package com.apple.foundationdb.record.query.plan.cascades.expressions
A variety of planner-specific RelationalExpression implementations which will never be used outside of the planner.
com.apple.foundationdb.record.query.plan.cascades.matching.graph - package com.apple.foundationdb.record.query.plan.cascades.matching.graph
This package contains everything related to graph matching.
com.apple.foundationdb.record.query.plan.cascades.matching.structure - package com.apple.foundationdb.record.query.plan.cascades.matching.structure
Classes related to the Cascades matcher system and its implementation.
com.apple.foundationdb.record.query.plan.cascades.predicates - package com.apple.foundationdb.record.query.plan.cascades.predicates
A package for all implementations of the QueryPredicate.
com.apple.foundationdb.record.query.plan.cascades.predicates.simplification - package com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A package for all simplification rules defined over QueryPredicates.
com.apple.foundationdb.record.query.plan.cascades.properties - package com.apple.foundationdb.record.query.plan.cascades.properties
A package for planner properties (in the sense that Cascades uses them).
com.apple.foundationdb.record.query.plan.cascades.rules - package com.apple.foundationdb.record.query.plan.cascades.rules
A package containing the rules used by the planner.
com.apple.foundationdb.record.query.plan.cascades.typing - package com.apple.foundationdb.record.query.plan.cascades.typing
Code to create dynamic messages from structured Types using protobuf.
com.apple.foundationdb.record.query.plan.cascades.values - package com.apple.foundationdb.record.query.plan.cascades.values
A package for all implementations of the Value.
com.apple.foundationdb.record.query.plan.cascades.values.simplification - package com.apple.foundationdb.record.query.plan.cascades.values.simplification
Package to contain logic to simplify a tree of Values.
com.apple.foundationdb.record.query.plan.cascades.values.translation - package com.apple.foundationdb.record.query.plan.cascades.values.translation
A package for Value translation algorithms.
com.apple.foundationdb.record.query.plan.explain - package com.apple.foundationdb.record.query.plan.explain
Classes supporting plan explains.
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.serialization - package com.apple.foundationdb.record.query.plan.serialization
Classes related to plan serialization/deserialization.
com.apple.foundationdb.record.query.plan.sorting - package com.apple.foundationdb.record.query.plan.sorting
Classes relating to plan execution with in-memory / file sorting.
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.visitor - package com.apple.foundationdb.record.query.plan.visitor
A package of classes in the visitor pattern that perform substitutions on a tree of RecordQueryPlans.
com.apple.foundationdb.record.sorting - package com.apple.foundationdb.record.sorting
Implement sorting for RecordCursor for use in queries without a sorting index.
com.apple.foundationdb.record.util - package com.apple.foundationdb.record.util
Miscellaneous record layer support classes.
com.apple.foundationdb.record.util.pair - package com.apple.foundationdb.record.util.pair
Classes used for utility classes for handling pairs of elements.
com.google.common.graph - package com.google.common.graph
contains implementation of graph network that have stable iteration order over the edges.
com.google.protobuf - package com.google.protobuf
Ability to support zero copy byte[] wrapping to ByteString.
combinations(CollectionMatcher<? extends E>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.CollectionMatcher
 
combinations(CollectionMatcher<? extends E>, BiFunction<RecordQueryPlannerConfiguration, Collection<E>, Integer>, BiFunction<RecordQueryPlannerConfiguration, Collection<E>, Integer>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.CollectionMatcher
 
combinations(CollectionMatcher<? extends E>, Function<Collection<E>, Integer>, Function<Collection<E>, Integer>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.CollectionMatcher
 
combine(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Combine two compatible AliasMaps.
combine(AliasMap, Iterable<AliasMap>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression.CombinePredicate
combine(AliasMap, Iterable<BoundMatch<EnumeratingIterable<R>>>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression.CombineFunction
Combine the sets of bindings (and their results) under the given set of outer bindings to an iterable of combined results.
combine(ReferencedFieldsConstraint.ReferencedFields, ReferencedFieldsConstraint.ReferencedFields) - Method in class com.apple.foundationdb.record.query.plan.cascades.ReferencedFieldsConstraint
 
combine(Set<RequestedOrdering>, Set<RequestedOrdering>) - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrderingConstraint
 
combine(T, T) - Method in interface com.apple.foundationdb.record.query.plan.cascades.PlannerConstraint
Method to be provided by the implementor to provide a mechanism to combine different constraints of the same kind into one.
combineBindings(Set<Ordering.Binding>, Set<Ordering.Binding>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Ordering.MergeOperator
 
CombineFilterRule - Class in com.apple.foundationdb.record.query.plan.cascades.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.cascades.rules.CombineFilterRule
 
combineHashes(List<Integer>) - Static method in interface com.apple.foundationdb.record.PlanHashable
 
combineMaybe(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Combine two AliasMaps if possible.
combineNonSargables() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
COMMA_LIKE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
CommaLikeToken(int, String) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.CommaLikeToken
 
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() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
commit(FDBDatabase, Transaction, StoreTimer, Throwable) - Method in interface com.apple.foundationdb.record.provider.foundationdb.TransactionListener
Called when a transaction commit completes, either successfully or unsuccessfully.
COMMIT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken committing transactions successfully.
COMMIT_ASYNC - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBLatencySource
COMMIT_FAILURE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken committing transactions that did not succeed.
COMMIT_NAME - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
COMMIT_READ_ONLY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken committing transactions that did not actually have any writes.
COMMIT_UNKNOWN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Count failed due to commit_unknown.
commitAndAdvance() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
commitAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Async version of FDBRecordContext.commit().
commitExploration() - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
Method to be called when exploration of a group is completed.
commitExploration() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
COMMITS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
Total number and duration of commits.
COMMITS_FAILED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Count of commits that failed for any reason.
common - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
common(Object) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.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
 
commonPrimaryKeyLength(Collection<RecordType>) - Static method in class com.apple.foundationdb.record.RecordMetaData
Calculate and return the length common to all the PKs of the given types.
commonPrimaryKeyValuesMaybe(Iterable<? extends MatchCandidate>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.WithPrimaryKeyMatchCandidate
 
commonPrimaryKeyValuesMaybeFromOptionals(Iterable<Optional<List<Value>>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty
 
ComparablePair<L extends Comparable<? super L>,R extends Comparable<? super R>> - Class in com.apple.foundationdb.record.util.pair
An implementation of the Pair that adds comparison support to the Pair.
comparand - Variable in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
COMPARAND_TO_COMPARISON_IS_OF_COMPLEX_TYPE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
comparator() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
COMPARATOR_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
ComparatorCursor<T> - Class in com.apple.foundationdb.record.provider.foundationdb.cursors
A cursor that implements a comparison of matching elements from a set of cursors all of whom are ordered compatibly.
compare(RelationalExpression, RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesCostModel
 
compare(Tuple, Tuple) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
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
 
compare(K, K) - Method in class com.apple.foundationdb.record.sorting.MemorySortAdapter.InsertionOrderComparator
 
compare(K, K) - Method in class com.apple.foundationdb.record.sorting.MemorySortAdapter.OrderComparator
 
compareListEquals(Object, List<?>) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons
 
compareMessageEquals(Object, Object) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
 
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
 
compareTo(Type.Record.Field) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
 
compareTo(ComparablePair<L, R>) - Method in class com.apple.foundationdb.record.util.pair.ComparablePair
 
compareToMinimumKey(K) - Method in class com.apple.foundationdb.record.sorting.MemorySortAdapter.InsertionOrderComparator
 
compareToMinimumKey(K) - Method in interface com.apple.foundationdb.record.sorting.MemorySortAdapter.MemorySortComparator
 
compareToMinimumKey(K) - Method in class com.apple.foundationdb.record.sorting.MemorySortAdapter.OrderComparator
 
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_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
COMPARISON_VALUE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
ComparisonCompensation - Interface in com.apple.foundationdb.record.query.plan.cascades.values.simplification
Interface to define compensation for partially matched Value-trees and their associated comparisons, as e.g.
ComparisonCompensation.NestedInvertableComparisonCompensation - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
Nested chaining comparison compensation.
comparisonKey(KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
comparisonKey(BindingMatcher<KeyExpression>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
comparisonKeyValue(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedOrderingPart
Compute the comparison key value for a set operation from this ordering part and a reversed-ness indicator.
comparisonKeyValues(CollectionMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
comparisonKeyValues(Iterable<OrderingPart.ProvidedOrderingPart>, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedOrderingPart
 
ComparisonRange - Class in com.apple.foundationdb.record.query.plan.cascades
A set of compatible comparisons on a single field of a KeyExpression representing a contiguous range of values for that field.
ComparisonRange.MergeResult - Class in com.apple.foundationdb.record.query.plan.cascades
Class to represent the outcome of a merge operation.
ComparisonRange.Type - Enum in com.apple.foundationdb.record.query.plan.cascades
Comparison ranges can be divided into three types.
ComparisonRanges - Class in com.apple.foundationdb.record.query.plan.cascades
Helper class that operates on a list of ComparisonRanges.
ComparisonRanges() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
ComparisonRanges(List<ComparisonRange>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
comparisons(Stream<QueryComponent>) - Static method in interface com.apple.foundationdb.record.query.expressions.BooleanComponent
 
Comparisons - Class in com.apple.foundationdb.record.query.expressions
Helper methods for building Comparisons.Comparisons.
COMPARISONS - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
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.ComparisonWithParameter - Interface in com.apple.foundationdb.record.query.expressions
A comparison against a 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.InvertedFunctionComparison - Class in com.apple.foundationdb.record.query.expressions
Comparison that is built on applying function's inverse to the comparand of a different comparison.
Comparisons.InvertedFunctionComparison.Deserializer - Class in com.apple.foundationdb.record.query.expressions
Deserializer.
Comparisons.ListComparison - Class in com.apple.foundationdb.record.query.expressions
A comparison with a list of values.
Comparisons.ListComparison.Deserializer - Class in com.apple.foundationdb.record.query.expressions
Deserializer.
Comparisons.MultiColumnComparison - Class in com.apple.foundationdb.record.query.expressions
Comparison wrapping another one and answering true to Comparisons.MultiColumnComparison.hasMultiColumnComparand().
Comparisons.MultiColumnComparison.Deserializer - Class in com.apple.foundationdb.record.query.expressions
Deserializer.
Comparisons.NullComparison - Class in com.apple.foundationdb.record.query.expressions
A unary predicate for special nullity checks, such as NULL and NOT NULL.
Comparisons.NullComparison.Deserializer - Class in com.apple.foundationdb.record.query.expressions
Deserializer.
Comparisons.OpaqueEqualityComparison - Class in com.apple.foundationdb.record.query.expressions
A predicate for comparisons to things unknown or opaque to the planner.
Comparisons.OpaqueEqualityComparison.Deserializer - Class in com.apple.foundationdb.record.query.expressions
Deserializer.
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.ParameterComparison.Deserializer - Class in com.apple.foundationdb.record.query.expressions
Deserializer.
Comparisons.ParameterComparisonBase - 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.SimpleComparison.Deserializer - Class in com.apple.foundationdb.record.query.expressions
Deserializer.
Comparisons.SimpleComparisonBase - 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
A Comparisons.TextComparison that checks for all prefixes.
Comparisons.TextWithMaxDistanceComparison - Class in com.apple.foundationdb.record.query.expressions
A Comparisons.TextComparison that must be satisfied within a certain number of text tokens.
Comparisons.Type - Enum in com.apple.foundationdb.record.query.expressions
The type for a Comparisons.Comparison predicate.
Comparisons.ValueComparison - Class in com.apple.foundationdb.record.query.expressions
A comparison with a Value, as opposed to a literal constant in the query.
Comparisons.ValueComparison.Deserializer - Class in com.apple.foundationdb.record.query.expressions
Deserializer.
ComparisonsProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
A property for collecting all ScanComparisons for the sub tree the property is evaluated on.
ComparisonsProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.ComparisonsProperty
 
CompatibleTypeEvolutionPredicate - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
A predicate to be used as part of a QueryPlanConstraint which can determine if a given plan can be executed under the types currently defined in the schema.
CompatibleTypeEvolutionPredicate(Map<String, CompatibleTypeEvolutionPredicate.FieldAccessTrieNode>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
Constructs a new CompatibleTypeEvolutionPredicate instance.
CompatibleTypeEvolutionPredicate.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Deserializer.
CompatibleTypeEvolutionPredicate.FieldAccessTrieNode - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Trie to capture the paths this value needs to check for compatible type evolution.
CompatibleTypeEvolutionPredicate.FieldAccessTrieNodeBuilder - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
compatibleWith(RecordStoreState) - Method in class com.apple.foundationdb.record.RecordStoreState
Determines if it is safe to use queries and other operations planned with the passed RecordStoreState with a record store that has the current state.
compensate(PartialMatch, Map<CorrelationIdentifier, ComparisonRange>, PullUp, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
compensate(PartialMatch, Map<CorrelationIdentifier, ComparisonRange>, PullUp, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
compensate(PartialMatch, Map<CorrelationIdentifier, ComparisonRange>, PullUp, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
compensate(PartialMatch, Map<CorrelationIdentifier, ComparisonRange>, PullUp, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
compensate(PartialMatch, Map<CorrelationIdentifier, ComparisonRange>, PullUp, CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
compensate(PartialMatch, Map<CorrelationIdentifier, ComparisonRange>, PullUp, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
compensate(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.FieldValueCompensation
 
compensate(Value) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueCompensation
 
compensate(Map<CorrelationIdentifier, ComparisonRange>, PullUp, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
compensateCompleteMatch() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
compensateExistential(Map<CorrelationIdentifier, ComparisonRange>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
compensateForScanComparisons(List<KeyExpression>) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
compensateRecordConstructorRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.PullUpValueRuleSet
 
CompensateRecordConstructorRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that computes compensation for a record constructor and all matched values for children of this record constructor.
CompensateRecordConstructorRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.CompensateRecordConstructorRule
 
compensateToOrderedBytesValueRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExtractFromIndexKeyValueRuleSet
 
CompensateToOrderedBytesValueRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that matches a Value (with the argument values).
CompensateToOrderedBytesValueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.CompensateToOrderedBytesValueRule
 
Compensation - Interface in com.apple.foundationdb.record.query.plan.cascades
Interface for all kinds of compensation.
Compensation.ForMatch - Class in com.apple.foundationdb.record.query.plan.cascades
Regular compensation class for matches based on query predicates.
Compensation.WithSelectCompensation - Interface in com.apple.foundationdb.record.query.plan.cascades
Interface for Compensations that map original QueryPredicates to compensating QueryPredicates.
compensationCanBeDeferred() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
Determine if compensation can be applied at a later time, e.g.
CompilableRange(Set<Comparisons.Comparison>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.CompilableRange
 
compile(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.CompilableRange
Evaluates this into a Range under the provided EvaluationContext.
compileTimeEval(EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
compileTimeEval(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
compileTimeEval(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
complete(byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Create a FDBRecordVersion that is complete and has the given serialized bytes.
complete(byte[], boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Create a FDBRecordVersion that is complete and has the given serialized bytes.
complete(byte[], int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Create a FDBRecordVersion that is complete and has the given global and local versions.
completeMatch() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PartialMatchMatchers
Matches any PartialMatch that is complete.
CompletionExceptionLogHelper - Class in com.apple.foundationdb.record.logging
Helper class for helping with logging of CompletionExceptions.
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 the CompletionExceptionLogHelper.maxSuppressedCount.
COMPLEXITY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
ComponentWithChildren - Interface in com.apple.foundationdb.record.query.expressions
A QueryComponent that has child components.
ComponentWithComparison - Interface in com.apple.foundationdb.record.query.expressions
A QueryComponent that uses a Comparisons.Comparison on the record.
ComponentWithNoChildren - Interface in com.apple.foundationdb.record.query.expressions
A QueryComponent that does not have any child components.
ComponentWithSingleChild - Interface in com.apple.foundationdb.record.query.expressions
A QueryComponent with exactly one child component.
compose(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Compute the composition of two AliasMaps.
compose(TranslationMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap.Builder
 
compose(QueryPlanConstraint) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
compose(Iterable<TranslationMap>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap
 
compose(Function<? super QueryPlanConstraint, ? extends BooleanWithConstraint>) - Method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
Monadic method to compose this by applying a Function to the recorded plan constraint if applicable.
composeConstraints(Collection<QueryPlanConstraint>) - Static method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
COMPOSED_BITMAP_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.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 from multiple IndexTypes.BITMAP_VALUE indexes with common group and position keys.
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 of BITMAP_VALUE indexes.
ComposedBitmapIndexQueryPlan.ComposerBase - Class in com.apple.foundationdb.record.query.plan.bitmap
Plan extension of ComposedBitmapIndexCursor.Composer.
composedBitmapPlan(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
composeFieldValueOverFieldValueRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.DefaultValueSimplificationRuleSet
 
ComposeFieldValueOverFieldValueRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that composes a field access and an underlying field access to a concatenated field access.
ComposeFieldValueOverFieldValueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComposeFieldValueOverFieldValueRule
 
composeFieldValueOverRecordConstructorRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.DefaultValueSimplificationRuleSet
 
ComposeFieldValueOverRecordConstructorRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that composes a field access and an underlying record construction, that is, it simplifies a field access over a record construction by replacing it with the field itself, for example
(("Hello" as a, "World" as b).b is transformed to "World".
ComposeFieldValueOverRecordConstructorRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComposeFieldValueOverRecordConstructorRule
 
composer(BindingMatcher<ComposedBitmapIndexQueryPlan.ComposerBase>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
ComposerBase() - Constructor for class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan.ComposerBase
 
composeWithConstraint(QueryPlanConstraint) - Method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
Method to compose this boolean with a QueryPlanConstraint.
composeWithOther(BooleanWithConstraint) - Method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
Method to compose this boolean with another BooleanWithConstraint.
composition(String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
compress(TransformedRecordSerializer.TransformState, StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
 
COMPRESS_SERIALIZED_RECORD - Enum constant in enum 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_DEPENDS_ON - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
COMPUTATION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeIcon
 
COMPUTATION_RULES - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
COMPUTATION_WITH_CNF_DEPENDS_ON - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateWithCnfRuleSet
 
COMPUTATION_WITH_CNF_RULES - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateWithCnfRuleSet
 
COMPUTATION_WITH_DNF_DEPENDS_ON - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateWithDnfRuleSet
 
COMPUTATION_WITH_DNF_RULES - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateWithDnfRuleSet
 
compute() - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
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, Set<? extends StoreTimer.Event>) - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Aggregate
Compute the value for this aggregate.
compute(Value, ARGUMENT, AliasMap, Set<CorrelationIdentifier>, ValueComputationRuleSet<ARGUMENT, RESULT>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.Simplification
Main function that simplifies the given value using the ValueComputationRuleSet passed in.
compute(Value, Value, Set<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.MaxMatchMap
Computes the maximum sub-Values in queryValue that have an exact match in the candidateValue.
compute(Value, Value, Set<CorrelationIdentifier>, ValueEquivalence) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.MaxMatchMap
Computes the maximum sub-Values in queryValue that have an exact match in the candidateValue.
compute(Equivalence.Wrapper<K>, BiFunction<? super Equivalence.Wrapper<K>, ? super Equivalence.Wrapper<V>, ? extends Equivalence.Wrapper<V>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
compute(D, BiFunction<D, N, N>) - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNodeBuilder
 
computeAliases(Iterable<? extends T>, Function<T, CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.DependencyUtils
Static helper to compute a set of CorrelationIdentifiers from a collection of elements of type T using the given element-to-alias function.
computeAliasToElementMap(Iterable<? extends T>, Function<T, CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.DependencyUtils
Static helper to compute the alias-to-element map based on a collection of elements and on the element-to-alias function tht are both passed in.
computeBoundParameterPrefixMap(MatchInfo) - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
Computes a map from CorrelationIdentifier to ComparisonRange that is physically compatible with a scan over the materialized version of the match candidate, so e.g.
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
computeChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
computeCompensationFunction(PartialMatch, QueryPredicate, Map<CorrelationIdentifier, ComparisonRange>, PullUp) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
Return a PredicateMultiMap.PredicateCompensationFunction that reapplies this predicate.
computeCompensationFunction(PartialMatch, QueryPredicate, Map<CorrelationIdentifier, ComparisonRange>, List<PredicateMultiMap.PredicateCompensationFunction>, PullUp) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
computeCompensationFunction(PartialMatch, QueryPredicate, Map<CorrelationIdentifier, ComparisonRange>, List<PredicateMultiMap.PredicateCompensationFunction>, PullUp) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
Overloaded method to compute compensation for this existential predicate.
computeCompensationFunction(PartialMatch, QueryPredicate, Map<CorrelationIdentifier, ComparisonRange>, List<PredicateMultiMap.PredicateCompensationFunction>, PullUp) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.LeafQueryPredicate
 
computeCompensationFunction(PartialMatch, QueryPredicate, Map<CorrelationIdentifier, ComparisonRange>, List<PredicateMultiMap.PredicateCompensationFunction>, PullUp) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
computeCompensationFunction(PartialMatch, QueryPredicate, Map<CorrelationIdentifier, ComparisonRange>, List<PredicateMultiMap.PredicateCompensationFunction>, PullUp) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
computeCompensationFunction(PartialMatch, QueryPredicate, Map<CorrelationIdentifier, ComparisonRange>, List<PredicateMultiMap.PredicateCompensationFunction>, PullUp) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
computeCompensationFunction(PartialMatch, Map<CorrelationIdentifier, ComparisonRange>, PullUp) - Method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateCompensation
 
computeCompensationFunctionForLeaf(PullUp) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
This method is overridden to always throw as ExistsPredicate.computeCompensationFunction(PartialMatch, QueryPredicate, Map, List, PullUp) does that work without delegating to this method (unlike its super which does exactly that).
computeCompensationFunctionForLeaf(PullUp) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.LeafQueryPredicate
 
computeCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
computeDependsOnMap(Iterable<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
 
computeDependsOnMap(Iterable<? extends Quantifier>, Map<CorrelationIdentifier, Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
 
computeDependsOnMap(Set<CorrelationIdentifier>, Function<T, CorrelationIdentifier>, Map<CorrelationIdentifier, T>, Function<T, ? extends Collection<T>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.DependencyUtils
Static helper to compute a dependency map from CorrelationIdentifier to CorrelationIdentifier based on a set of aliases and mappings between CorrelationIdentifier and type T.
computeDependsOnMapWithAliases(Set<CorrelationIdentifier>, Map<CorrelationIdentifier, T>, Function<T, Set<CorrelationIdentifier>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.DependencyUtils
Static helper to compute a dependency map from CorrelationIdentifier to CorrelationIdentifier based on a set of aliases and mappings between CorrelationIdentifier and type T.
computeDigest() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingDigest
 
computeDirectionToSortOrder(Class<SO>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
 
computeFieldAccesses(List<Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
computeFlowedColumns() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
computeFlowedColumns() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Existential
 
computeFlowedColumns() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach
 
computeFlowedColumns() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
computeHashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
computeHashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
computeHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart
 
computeHashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
computeIfAbsent(Equivalence.Wrapper<K>, Function<? super Equivalence.Wrapper<K>, ? extends Equivalence.Wrapper<V>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
computeIfAbsent(D, Function<D, N>) - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNodeBuilder
 
computeIfAbsent(Map<K, V>, K, Function<K, V>) - Static method in class com.apple.foundationdb.record.util.MapUtils
In older versions of java ConcurrentHashMap.computeIfAbsent() has an issue where threads can contend on reads even when the value is present.
computeIfPresent(Equivalence.Wrapper<K>, BiFunction<? super Equivalence.Wrapper<K>, ? super Equivalence.Wrapper<V>, ? extends Equivalence.Wrapper<V>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
computeIndexEntryToLogicalRecord(Collection<RecordType>, CorrelationIdentifier, Type, List<Value>, List<Value>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.ScanWithFetchMatchCandidate
 
computeInverseMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.AliasMapBackedValueEquivalence
 
computeInverseMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence
 
computeInverseMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ConstantValueEquivalence
 
computeInverseMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ThenEquivalence
 
computeInverseMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ValueMap
 
computeMatchedOrderingParts(MatchInfo, List<CorrelationIdentifier>, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
computeMatchedOrderingParts(MatchInfo, List<CorrelationIdentifier>, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
Compute a list of OrderingPart.MatchedOrderingParts which forms a bridge to relate KeyExpressions and QueryPredicates.
computeMatchedOrderingParts(MatchInfo, List<CorrelationIdentifier>, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.ValueIndexLikeMatchCandidate
This synthesizes a list of OrderingPart.MatchedOrderingParts from the partial match and the ordering information passed in.
computeMatchedOrderingParts(MatchInfo, List<CorrelationIdentifier>, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
computeNext() - Method in class com.apple.foundationdb.record.query.combinatorics.EnumeratingIterable.SingleIterator
 
computeNext() - Method in class com.apple.foundationdb.record.query.plan.cascades.PreOrderIterator
 
computeNextResult(boolean) - Method in class com.apple.foundationdb.record.cursors.AsyncIteratorCursor
 
computeNextResultStates() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ComparatorCursor
Compute the set of next result states.
computeNextResultStates() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.IntersectionMultiCursor
Compute the next result states for the cursor based on the status of the existing states.
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
 
computeOrderingFromScanComparisons(ScanComparisons, boolean, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
computeOrderingFromScanComparisons(ScanComparisons, boolean, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
computeOrderingFromScanComparisons(ScanComparisons, boolean, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.ValueIndexLikeMatchCandidate
 
computeOrderingFromScanComparisons(ScanComparisons, boolean, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
computePrimaryKeyValuesMaybe(KeyExpression, Type) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
computePromotionsTrie(Type, Type, MessageHelpers.TransformationTrieNode) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
computeRecordsRange() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
computeResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
computeSargedComparisons(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
 
computeSemanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AbstractQueryPredicate
 
computeSemanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndOrPredicate
 
computeSemanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
computeSemanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
computeSemanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
computeSemanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
computeSemanticHashCode() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.LeafQueryPredicate
Default implementation to be mixed in.
computeSemanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
computeSemanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
computeSemanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
computeToOrderedBytesValueRule(Function<TupleOrdering.Direction, O>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.OrderingValueComputationRuleSet
 
ComputeToOrderedBytesValueRule<O extends OrderingPart.SortOrder,P extends OrderingPart<O>> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that computes the underlying order of a Value tree rooted at a ToOrderedBytesValue.
ComputeToOrderedBytesValueRule(Function<TupleOrdering.Direction, O>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComputeToOrderedBytesValueRule
 
computeTrieForFieldPaths(Collection<FieldValue.FieldPath>, Map<FieldValue.FieldPath, ? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
Method to compute a trie from a collection of lexicographically-ordered field paths.
computeUnmatchedForEachQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.Compensation.ForMatch
 
computeUsingMatchedOrderingParts(OrderingPart.MatchedSortOrder) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.OrderingValueComputationRuleSet
 
computeUsingRequestedOrderingParts(OrderingPart.RequestedSortOrder) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.OrderingValueComputationRuleSet
 
ComputingMatcher<T,M,R> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.graph
This class implements a GenericMatcher which matches two sets of elements of type T to compute a result of type Iterable<BoundMatch<R>>.
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 - Enum constant in enum 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
Shortcut 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.
concatOrderings(Ordering, Ordering) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
Helper method to concatenate the ordering key parts of the participating orderings in iteration order.
concatOrderings(Collection<Ordering>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
Helper method to concatenate the ordering key parts of the participating orderings in iteration order.
ConditionalUponPathPredicate(ImmutableIntArray) - Constructor for class com.apple.foundationdb.record.query.plan.AvailableFields.ConditionalUponPathPredicate
 
Conditions(List<Comparisons.Comparison>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys.Conditions
 
ConditionSelectorValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
This returns the index of the first implication that is satisfied.
ConditionSelectorValue(Iterable<? extends Value>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
ConditionSelectorValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
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
 
CONFLICTS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Count failed due to conflict.
conjuncts(QueryPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
constant() - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
CONSTANT - Enum constant in enum com.apple.foundationdb.record.Bindings.Internal
 
constantEquivalenceWithEvaluationContext(EvaluationContext) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence
 
ConstantObjectValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
Represents a constant value that references a constant in __CONST__ binding of EvaluationContext.
ConstantObjectValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
ConstantPredicate - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
A predicate with a constant boolean value.
ConstantPredicate(IndexPredicate.ConstantPredicate.ConstantValue) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.ConstantPredicate
 
ConstantPredicate(PlanSerializationContext, PConstantPredicate) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
ConstantPredicate(ConstantPredicate) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.ConstantPredicate
 
ConstantPredicate(RecordMetaDataProto.ConstantPredicate) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.ConstantPredicate
 
ConstantPredicate(Boolean) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
ConstantPredicate.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Deserializer.
ConstantValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A wrapper around a constant.
ConstantValue(Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
ConstantValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
ConstantValueEquivalence(EvaluationContext) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ConstantValueEquivalence
 
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
 
CONSTITUENT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
CONSTRAINTS - Static variable in class com.apple.foundationdb.record.query.plan.QueryPlanInfoKeys
 
ConstraintsMap - Class in com.apple.foundationdb.record.query.plan.cascades
A map to keep track of constraining attributes for an expression reference.
ConstraintsMap() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
Default constructor.
constructGroupBy(Quantifier, GraphExpansion) - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexExpansionVisitor
 
constructGroupBy(Quantifier, GraphExpansion) - Method in class com.apple.foundationdb.record.query.plan.cascades.BitmapAggregateIndexExpansionVisitor
 
consume() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
 
ContainerMatcher<T,C extends Iterable<? extends T>> - Interface in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Tag interface used for overloads for matchers.
contains(ReadTransactionContext, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.InstrumentedRankedSet
 
contains(Tuple) - Method in class com.apple.foundationdb.record.TupleRange
Method to compute if a given Tuple is contained within this tuple range.
contains(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
contains(String) - Method in class com.apple.foundationdb.record.query.expressions.Text
Checks if the field contains a token.
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.
containsAll(Set<? extends T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PrimitiveMatchers
 
containsAllInMemo(Reference, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
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.
containsAsync(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Determine if a key is in a range that has been inserted into the range set.
containsAttribute(PlannerConstraint<T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
Method to return if a particular attribute is contained in the map.
containsBinding(String) - Method in class com.apple.foundationdb.record.Bindings
 
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(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
containsExpressionInReference(BindingMatcher<? extends Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ContainsExpressionInReferenceMatcher
 
ContainsExpressionInReferenceMatcher - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A typed matcher that matches the current expression if the current expression is contained in a group reference binding designated by another BindingMatcher (which was bound earlier on a reference).
containsInMemo(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
containsKey(BindingMatcher<?>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings
Checks whether there is an object bound to key.
containsKey(QueryPlanInfo.QueryPlanInfoKey<T>) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo
Returns TRUE if the given key exists in the info table.
containsKey(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
containsKey(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentityMap
 
containsKeyUnwrapped(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
containsMapping(CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
 
containsNonUniqueNull() - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
Check for NULL value that inhibits unique indexes.
containsParameter(String) - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph
 
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.
containsPosition(RTree.Point) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.And
 
containsPosition(RTree.Point) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds
Method to compute if the point handed in is contained by this scan bounds object.
containsPosition(RTree.Point) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.Hypercube
 
containsPosition(RTree.Point) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.Or
 
containsPosition(RTree.Point) - Method in interface com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.SpatialPredicate
 
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.cascades.AliasMap
 
containsSourceAlias(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap
 
containsTarget(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.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
 
containsValue(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
context - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreBase
 
context - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
 
contextExecutor - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
CONTINUATION - Enum constant in enum com.apple.foundationdb.record.EndpointType
 
CONTINUE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.DesiredAction
 
CONTINUED_BUILD - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
convertOrNull(Key.Evaluated) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
copy(int, int, long, IsolationLevel, ExecuteState, boolean, CursorStreamingMode, boolean) - Method in class com.apple.foundationdb.record.ExecuteProperties
Create a new instance with these fields, copying any additional fields from subclasses.
copy(Descriptors.Descriptor, Message.Builder, IndexEntry) - Method in interface com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Copier
 
copy(Descriptors.Descriptor, Message.Builder, IndexEntry) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier
 
copy(Descriptors.Descriptor, Message.Builder, IndexEntry) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldWithValueCopier
 
copy(Descriptors.Descriptor, Message.Builder, IndexEntry) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.MessageCopier
 
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.
copyOf(BiMap<CorrelationIdentifier, CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Factory method to create an alias map that is a copy of an BiMap passed in.
copyOf(Iterable<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
copyTo(LocatableResolver) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingReplicator
Copy the mappings stored in a LocatableResolver to the specified replica.
copyToAsync(LocatableResolver) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverMappingReplicator
Copy the mappings stored in a LocatableResolver to the specified replica.
Correlated<S extends Correlated<S>> - Interface in com.apple.foundationdb.record.query.plan.cascades
A correlated entity is one which can only be evaluated as a function of some input (usually a Quantifier from its relational parent).
Correlated.BoundEquivalence<S extends Correlated<S>> - Class in com.apple.foundationdb.record.query.plan.cascades
Helper class to wrap extenders of Correlated to provide standard equivalence and hash code functionality under a given AliasMap.
CORRELATION - Enum constant in enum com.apple.foundationdb.record.Bindings.Internal
 
CorrelationIdentifier - Class in com.apple.foundationdb.record.query.plan.cascades
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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
 
COUNT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
 
COUNT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
 
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_CLEAR_WHEN_ZERO - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
 
COUNT_DISTINCT - Static variable in class com.apple.foundationdb.record.FunctionNames
 
COUNT_NOT_NULL - Enum constant in enum 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_NOT_NULL_CLEAR_WHEN_ZERO - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
 
COUNT_STAR - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
 
COUNT_UPDATES - Enum constant in enum 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.
Counter(boolean) - Constructor for class com.apple.foundationdb.record.provider.common.StoreTimer.Counter
 
Counter(int, long) - Constructor for class com.apple.foundationdb.record.provider.common.StoreTimer.Counter
 
Counter(int, long, boolean) - Constructor for class com.apple.foundationdb.record.provider.common.StoreTimer.Counter
 
counters - Variable in class com.apple.foundationdb.record.provider.common.StoreTimer
 
countExpressions(Class<? extends RelationalExpression>, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.FindExpressionProperty
 
countExpressions(Set<Class<? extends RelationalExpression>>, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.FindExpressionProperty
 
CountFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.CountValue.CountFn
 
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
 
countNormalizedConjuncts(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.NormalizedResidualPredicateProperty
 
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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
 
countUpdates(KeyExpression) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
 
CountValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A counting aggregate value.
CountValue(boolean, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
CountValue(CountValue.PhysicalOperator, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
CountValue(CountValue.PhysicalOperator, Value, String) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
CountValue(Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
CountValue.CountFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The count(x) function.
CountValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
CountValue.PhysicalOperator - Enum in com.apple.foundationdb.record.query.plan.cascades.values
The counting argument type.
CountValue.SumAccumulator - Class in com.apple.foundationdb.record.query.plan.cascades.values
Sum partial counts in the appropriate mode.
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.cascades.explain.NodeInfo
 
COVERING_SPATIAL_INDEX_SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
coveringIndexPlan() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
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
create() - Static method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
create(FDBDatabase, Transaction) - Method in interface com.apple.foundationdb.record.provider.foundationdb.TransactionListener
Called immediately upon the creation of a new transaction.
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(FDBRecordStoreBase<M>, KeyExpression, List<Function<byte[], RecordCursor<QueryResult>>>, byte[], int, boolean, Supplier<String>, Supplier<Integer>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ComparatorCursor
Create a comparator cursor from several compatibly-ordered cursors.
create(AbstractRule<RESULT, CALL, BASE, ? extends BASE>, BASE, BASE, PlannerBindings) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.simplification.Simplification.RuleCallCreator
 
create(Value, O) - Method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.OrderingPartCreator
 
create(FileSortAdapter<K, V>, Function<byte[], RecordCursor<V>>, StoreTimer, byte[], int, int) - Static method in class com.apple.foundationdb.record.sorting.FileSortCursor
 
create(MemorySortAdapter<K, V>, Function<byte[], RecordCursor<V>>, StoreTimer, BiFunction<MemorySortAdapter<K, V>, StoreTimer, MemoryScratchpad<K, V, M>>, byte[]) - Static method in class com.apple.foundationdb.record.sorting.MemorySortCursor
 
create(BiMap<Equivalence.Wrapper<K>, Equivalence.Wrapper<V>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
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>>>, byte[], FDBStoreTimer, int, boolean, Supplier<String>, Supplier<Integer>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ComparatorCursor
Create a comparator cursor from several compatibly-ordered 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of times a record store is created in the database.
createAccumulator(TypeRepository) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.AggregateValue
Create a new accumulator from the Value.
createAccumulator(TypeRepository) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
createAccumulator(TypeRepository) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
createAccumulator(TypeRepository) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
createAccumulator(TypeRepository) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
createAsync() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
Opens a new FDBRecordStore instance in the given path with the given meta-data.
createBaseRef(Set<String>, Collection<RecordType>, Set<String>, Collection<RecordType>, AccessHint) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
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.IntersectionMultiCursor
 
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.IntersectionMultiCursor
 
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
 
createDam(MemorySortAdapter<K, V>, Function<byte[], RecordCursor<V>>, StoreTimer, byte[]) - Static method in class com.apple.foundationdb.record.sorting.MemorySortCursor
 
createExponentialDelay() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
Construct an ExponentialDelay based on this runner's configuration.
createFromOrdering(Ordering) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Ordering.MergeOperator
 
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
 
createInTransaction(FDBRecordContext, String, ResolverCreateHooks) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Allocate a new value within the context of a single transaction.
createInverseValueMaybe(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
createInverseValueMaybe(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
createInverseValueMaybe(Value) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value.InvertableValue
Create the inverse value of this value if it can be constructed.
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
 
createOrdering(SetMultimap<Value, Ordering.Binding>, PartiallyOrderedSet<Value>, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Ordering.MergeOperator
 
createOrOpen() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
createOrOpen(FDBRecordStoreBase.StoreExistenceCheck) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
createOrOpenAsync() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
Opens a FDBRecordStore instance 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 a FDBRecordStore instance 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.DimensionsKeyExpression
 
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.LongArithmethicFunctionKeyExpression
 
createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
 
createsDuplicates() - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
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.cascades.AggregateIndexMatchCandidate
 
createsDuplicates() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
createsDuplicates() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
createsDuplicates() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
createsDuplicates() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
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
 
CreatesDynamicTypesValue - Interface in com.apple.foundationdb.record.query.plan.cascades.values
A Value that creates dynamic types on the fly and therefore needs special consideration when dealing with protobuf descriptors.
createSort(MemorySortAdapter<K, V>, Function<byte[], RecordCursor<V>>, StoreTimer, byte[]) - Static method in class com.apple.foundationdb.record.sorting.MemorySortCursor
 
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.
createTempTable() - Method in class com.apple.foundationdb.record.query.plan.cascades.TempTable.Factory
 
createVisitor() - Method in interface com.apple.foundationdb.record.query.plan.cascades.PlanProperty
 
createVisitor() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty
 
createVisitor() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty
 
createVisitor() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty
 
createVisitor() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty
 
createVisitor() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty
 
crossProduct(Collection<? extends Iterable<T>>) - Static method in class com.apple.foundationdb.record.query.combinatorics.CrossProduct
Create a EnumeratingIterable based on a set and a function describing the depends-on relationships between items in the given set.
CrossProduct - Class in com.apple.foundationdb.record.query.combinatorics
Utility class to provide helpers related to enumeration of cross products.
CURR_ATTEMPT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
current() - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
CURRENT_FOR_CONTINUATION - Static variable in interface com.apple.foundationdb.record.PlanHashable
 
CURRENT_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
 
CURRENT_LEGACY - Static variable in interface com.apple.foundationdb.record.PlanHashable
 
CurrentAliasDefinitionToken(int, CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.CurrentAliasDefinitionToken
 
currentModifiedRecordAlias() - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
CURSOR_ELAPSED_MILLIS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
CURSOR_TIME_LIMIT_MILLIS - Enum constant in enum 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 a BaseCursor.
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 opening RecordCursors.
cutOffIfNeeded(int, CharSequence) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
CYAN - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 

D

DAM_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
DANGLING - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.IndexScrubbingTools.ScrubbingType
 
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.cascades.explain.NodeIcon
 
dataAccessForMatchPartition(CascadesRuleCall, Set<RequestedOrdering>, Collection<? extends PartialMatch>) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.AbstractDataAccessRule
Method that does the leg work to create the appropriate expression dag for data access using value indexes or value index-like scans (primary scans).
DataAccessRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that utilizes index matching information compiled by CascadesPlanner to create one or more expressions for data access.
DataAccessRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.DataAccessRule
 
database - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
 
database - Variable in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
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.
DatabaseObjectDependenciesPredicate - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
A predicate to be used as part of a QueryPlanConstraint which can determine if a given plan can be executed under the currently available database objects.
DatabaseObjectDependenciesPredicate.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Deserializer.
DatabaseObjectDependenciesPredicate.UsedIndex - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Helper class to capture the name together and the last modified version of an index.
databases - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
DataNodeWithInfo(NodeInfo, Type, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.DataNodeWithInfo
 
DataNodeWithInfo(NodeInfo, Type, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.DataNodeWithInfo
 
Debugger - Interface in com.apple.foundationdb.record.query.plan.cascades.debug
This interface functions as a stub providing hooks which can be called from the planner logic during planning.
Debugger.AbstractEventWithState - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Abstract event class to capture rootReference amd taskStack.
Debugger.AdjustMatchEvent - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Events of this class are generated when the planner attempts to adjust an existing match.
Debugger.Event - Interface in com.apple.foundationdb.record.query.plan.cascades.debug
Tag interface for all events.
Debugger.EventWithCurrentGroupReference - Interface in com.apple.foundationdb.record.query.plan.cascades.debug
Interface for events that hold a group ref.
Debugger.EventWithRule - Interface in com.apple.foundationdb.record.query.plan.cascades.debug
Events that are created by a or as part of a transformation rule.
Debugger.EventWithState - Interface in com.apple.foundationdb.record.query.plan.cascades.debug
Interface for events that hold a root reference.
Debugger.ExecutingTaskEvent - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Events of this class are generated every time the planner executes a task.
Debugger.ExploreExpressionEvent - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Events of this class are generated when the planner explores an expression.
Debugger.ExploreGroupEvent - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Events of this class are generated when the planner explores a group.
Debugger.InsertIntoMemoEvent - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Events of this class are generated when the planner attempts to insert a new expression into the memoization structures of the planner.
Debugger.Location - Enum in com.apple.foundationdb.record.query.plan.cascades.debug
Enum to indicate where an event happened.
Debugger.OptimizeGroupEvent - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Events of this class are generated when the planner optimizes a group.
Debugger.OptimizeInputsEvent - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Events of this class are generated when the planner optimizes inputs.
Debugger.Shorthand - Enum in com.apple.foundationdb.record.query.plan.cascades.debug
Shorthands to identify a kind of event.
Debugger.TransformEvent - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Events of this class are generated when the planner transforms an expression using a rule.
Debugger.TransformRuleCallEvent - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Events of this class are generated when the planner calls a transformation rule.
Debugger.TranslateCorrelationsEvent - Class in com.apple.foundationdb.record.query.plan.cascades.debug
Events of this class are generated when the planner creates new expressions as part of rebasing or as part of a translation of correlations in a graph.
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 - Enum constant in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Events
The amount of time spent decompressing serialized bytes.
deconstructRecord(Value) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.Values
Expand a record value into its field values.
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 - Enum constant in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Events
The amount of time spent decrypting serialized bytes.
deepCopyIfNeeded(TypeRepository, Type, Object) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
Given the possible mix of messages originating from precompiled classes as well as messages that are instances of DynamicMessage, we need to make sure that we actually create a cohesive object structure when one message is integrated into the other when a new record is formed.
deepCopyMessageIfNeeded(Descriptors.Descriptor, Message) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
This method provides a structural deep copy of the Message passed in.
DEFAULT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.StateCacheabilityOnOpen
By default, the state cacheability is not changed when the store is opened.
DEFAULT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.VersionstampSaveBehavior
Match the behavior dictated by the meta-data.
DEFAULT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBTraceFormat
Use the system default.
DEFAULT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBTransactionPriority
The default priority level for most transactions.
DEFAULT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
 
DEFAULT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy
 
DEFAULT - Static variable in interface com.apple.foundationdb.record.query.IndexQueryabilityFilter
The default index queryability filter which uses all indexes except those with the IndexOptions.ALLOWED_FOR_QUERY_OPTION set to false.
DEFAULT - Static variable in class com.apple.foundationdb.record.query.plan.cascades.PlannerRuleSet
 
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.CipherPool
 
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, from LocatableResolver retrieval 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_EXPLAIN_LEVEL - Static variable in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
Highest Explain level that all tokens get created at that do not override their explain level.
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.cascades.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.OnlineIndexOperationConfig
Default synchronized session lease time in milliseconds.
DEFAULT_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
Default number of records to attempt to run in a single transaction.
DEFAULT_LOADER - Static variable in class com.apple.foundationdb.record.util.ServiceLoaderProvider
 
DEFAULT_MAX_ENTRIES - Static variable in class com.apple.foundationdb.record.provider.common.MappedPool
 
DEFAULT_MAX_FILE_COUNT - Static variable in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
DEFAULT_MAX_NUM_CONJUNCTS - Static variable in class com.apple.foundationdb.record.query.plan.cascades.rules.PredicateToLogicalUnionRule
 
DEFAULT_MAX_RECORD_COUNT_IN_MEMORY - Static variable in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
DEFAULT_MAX_RETRIES - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
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.OnlineIndexOperationConfig
Default interval to be logging successful progress in millis when building across transactions.
DEFAULT_RECORD_COUNT_PER_SECTION - Static variable in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
DEFAULT_RECORDS_PER_SECOND - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
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_SIZE_LIMIT - Static variable in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer
The default limit on the size of the normal form 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 indicate that transactions should use the system default.
DEFAULT_TRANSACTION_TIME_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
If/When the index operation exceeds this transaction time, it would attempt commiting and continuing the iteration in the following transactions.
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.OnlineIndexOperationConfig
Default transaction write size limit.
DefaultExplainFormatter - Class in com.apple.foundationdb.record.query.plan.explain
A formatter for tokens.
DefaultExplainFormatter(Supplier<ExplainSymbolMap>) - Constructor for class com.apple.foundationdb.record.query.plan.explain.DefaultExplainFormatter
 
DefaultExplainSymbolMap - Class in com.apple.foundationdb.record.query.plan.explain
Symbol table that uses the alias' string representation as symbol.
DefaultExplainSymbolMap() - Constructor for class com.apple.foundationdb.record.query.plan.explain.DefaultExplainSymbolMap
 
defaultOrderingPartRule(O) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.OrderingValueComputationRuleSet
 
DefaultOrderingPartRule<O extends OrderingPart.SortOrder,P extends OrderingPart<O>> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that computes the default order of a Value tree.
DefaultOrderingPartRule(O) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.DefaultOrderingPartRule
 
defaultPlannerConfiguration() - Static method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
 
defaultPlannerRuleSet() - Static method in class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
Returns the default set of transformation rules.
DefaultPlanSerializationRegistry - Class in com.apple.foundationdb.record.query.plan.serialization
Default implementation of a plan serialization registry.
DefaultPlanSerializationRegistry() - Constructor for class com.apple.foundationdb.record.query.plan.serialization.DefaultPlanSerializationRegistry
 
DefaultQueryPredicateRuleSet - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A set of rules for use by a planner that supports quickly finding rules that could match a given QueryPredicate.
DefaultQueryPredicateRuleSet() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
DefaultQueryPredicateRuleSet(Set<? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, List<QueryPlanConstraint>>, QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>, ? extends QueryPredicate>>, SetMultimap<? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, List<QueryPlanConstraint>>, QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>, ? extends QueryPredicate>, ? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, List<QueryPlanConstraint>>, QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>, ? extends QueryPredicate>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
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 the DefaultTextTokenizer.
DefaultTextTokenizerFactory() - Constructor for class com.apple.foundationdb.record.provider.common.text.DefaultTextTokenizerFactory
 
DefaultValueSimplificationRuleSet - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A set of rules for use by a planner that supports quickly finding rules that could match a given planner expression.
defineAndResolveType(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
defineProtoType(TypeRepository.Builder) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
Creates a synthetic protobuf descriptor that is equivalent to this Type.
defineProtoType(TypeRepository.Builder) - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Creates a synthetic protobuf descriptor that is equivalent to this Type.
defineProtoType(TypeRepository.Builder) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
defineProtoType(TypeRepository.Builder) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Creates a synthetic protobuf descriptor that is equivalent to this Type.
definesOnlyIdentities() - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Return if this alias map exclusively contains mappings of the shape x -> x.
degree(N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
delay() - Method in class com.apple.foundationdb.record.provider.foundationdb.runners.ExponentialDelay
 
DELAY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
delayedFuture(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.runners.ExponentialDelay
 
delayedTimer - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
 
delayedTimer - Variable in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
DELETE - Static variable in class com.apple.foundationdb.record.PipelineOperation
 
DELETE_INDEX_ENTRY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent deleting an entry from a secondary index.
DELETE_INDEX_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of index key-value pairs deleted.
DELETE_INDEX_KEY_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of keys for index key-value pairs deleted.
DELETE_INDEX_VALUE_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of values for index key-value pairs deleted.
DELETE_RECORD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken deleting records.
DELETE_RECORD_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of record key-value pairs deleted.
DELETE_RECORD_KEY_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of keys for record key-value pairs deleted.
DELETE_RECORD_VALUE_BYTES - Enum constant in enum 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
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
 
deleteExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
DeleteExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A logical version of RecordQueryDeletePlan.
DeleteExpression(Quantifier.ForEach, String) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
 
deleteFiles() - Method in class com.apple.foundationdb.record.sorting.FileSorter
 
deleteForTesting(FDBRecordContext, ScopedValue<Long>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
Remove an entry from the reverse directory, STRICTLY FOR TESTING.
deletePlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
deletePlan(Quantifier.Physical) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
Factory method to create a RecordQueryInsertPlan.
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
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
deleteReverseForTesting(FDBRecordContext, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
 
deleteReverseForTesting(FDBRecordContext, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Method used for corrupting the reverse directory in order to write tests for validating/repairing inconsistencies.
deleteReverseForTesting(FDBRecordContext, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
 
deleteReverseForTesting(FDBRecordContext, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
 
deleteReverseForTesting(FDBRecordContext, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
 
DELETES - Enum constant in enum 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 given KeySpacePath.
deleteStore(FDBRecordContext, Subspace) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Delete the record store at the given Subspace.
deleteTypedRecord(RecordSerializer<M>, Tuple, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
deleteWhere(Transaction, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.MultidimensionalIndexMaintainer
 
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.PermutedMinMaxIndexMaintainer
 
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
 
deMorganNotOverAndRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
deMorganNotOverOrRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
DeMorgansTheoremRule<P extends AndOrPredicate> - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A rule that matches a NotPredicate over an AndPredicate or OrPredicate and applies a transformation utilizing deMorgan's law.
DeMorgansTheoremRule(Class<P>, BindingMatcher<QueryPredicate>, BindingMatcher<NotPredicate>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DeMorgansTheoremRule
 
demote() - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedOrderingPart
 
DependencyUtils - Class in com.apple.foundationdb.record.query.plan.cascades.matching.graph
Helper methods useful for managing dependency sets using CorrelationIdentifiers.
DEPENDS_ON - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExtractFromIndexKeyValueRuleSet
 
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.
dereferenceConstant(CorrelationIdentifier, String) - Method in class com.apple.foundationdb.record.EvaluationContext
Dereferences the constant.
Derivations(List<Value>, List<Value>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.Derivations
 
DERIVATIONS - Static variable in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty
 
DerivationsProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
A property used to create and collect the derivations of data flowing in a plan.
DerivationsProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty
 
DerivationsProperty.Derivations - Class in com.apple.foundationdb.record.query.plan.cascades.properties
Cases class to capture the derivations that are being collected by the visitor.
DerivationsProperty.DerivationsVisitor - Class in com.apple.foundationdb.record.query.plan.cascades.properties
A visitor that determines the derivations of a RecordQueryPlan.
DerivationsVisitor() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
derived() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph
 
derived(boolean, LinkedIdentityMap<QueryPredicate, PredicateMultiMap.PredicateCompensationFunction>, Collection<? extends Quantifier>, Set<? extends Quantifier>, Set<CorrelationIdentifier>, PredicateMultiMap.ResultCompensationFunction) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
 
derivedFrom(StoreTimer) - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
Determine if this snapshot is derived from the provided timer.
DerivedValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value merges the input messages given to it into an output message.
DerivedValue(Iterable<? extends Value>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
DerivedValue(Iterable<? extends Value>, Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
DerivedValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
deriveForDistinctSetOperationFromOrderings(List<Ordering>, List<OrderingPart.ProvidedOrderingPart>, Ordering.MergeOperator<O>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
deriveOrderingPart(AliasMap, Set<CorrelationIdentifier>, OrderingPart.OrderingPartCreator<O, P>, OrderingValueComputationRuleSet<O, P>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
This method attempts to derive and then simplify (as much as possible) the ordering value that this value imposes if uses in an ordering context.
deriveRequestedOrderings(RequestedOrdering, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
Method to derive RequestedOrderings from this Ordering.
descendantPlans(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
descendantPlans(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
descending() - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Binding
 
DESCENDING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
 
DESCENDING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
Descending.
DESCENDING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
Descending.
DESCENDING_NULLS_FIRST - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
 
DESCENDING_NULLS_FIRST - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
Descending but with nulls before regular values.
DESCENDING_NULLS_FIRST - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
Descending but with nulls before regular values.
descendOnlyIf(Predicate<? super T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PreOrderIterator
 
describe() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
 
describe() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
 
describe() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
 
describe() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
describe() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
describe() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
describe() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
describe() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive
 
describe() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
describe() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
 
describe() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Typed
Returns a human-friendly textual representation of both the type-producing instance and its result set Type.
describesWrappedArray(Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.query.plan.cascades.NullableArrayTypeUtils
Check whether a descriptor describes a wrapped array.
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 - Enum constant in enum 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(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.SortedRecordSerializer
 
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(RecordSortingProto.SortedRecord) - Method in class com.apple.foundationdb.record.provider.foundationdb.SortedRecordSerializer
 
DESERIALIZE_PROTOBUF_RECORD - Enum constant in enum 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[]) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
deserializeKey(byte[]) - Method in interface com.apple.foundationdb.record.sorting.MemorySortAdapter
Convert serialized key back to key.
deserializeKey(byte[], int, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexBunchedSerializer
Deserializes a key using standard Tuple unpacking.
deserializeKeys(Tuple, byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.TextIndexBunchedSerializer
Deserializes the keys from a serialized entry list.
Deserializer() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.AvailableFields.ConditionalUponPathPredicate.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.AvailableFields.TruePredicate.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.CountValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MaxEverValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MinEverValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NotValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NullValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Avg.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.BitmapConstructAgg.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Max.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Min.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Sum.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.PickValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.ArrayCoercionBiFunction.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.PrimitiveCoercionBiFunction.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RankValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.BinaryRelOpValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.UnaryRelOpValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldWithValueCopier.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.MessageCopier.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.InComparandSource.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.InParameterSource.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.InValuesSource.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan.Deserializer
 
Deserializer() - Constructor for class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan.Deserializer
 
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
 
deserializeValue(byte[]) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
deserializeValue(byte[]) - Method in interface com.apple.foundationdb.record.sorting.MemorySortAdapter
Convert serialized value back into value.
dimensions(BindingMatcher<? extends ScanComparisons>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
DimensionsKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
A key expression that divides into three parts that represent the constituent parts of a multidimensional index.
DIR_NAME - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
DIR_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
DIR_VALUE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
DIRECT_ORDER_PRESERVING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.Ordering.OrderPreservingKind
 
directionalOrderingParts(List<Value>, RequestedOrdering, OrderingPart.ProvidedSortOrder) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.SetOperationsOrdering
Method that reduces this set-operation ordering to only directional ordering parts by using a comparison key, a RequestedOrdering and a default.
directionalOrderingParts(List<Value>, Map<Value, OrderingPart.RequestedSortOrder>, OrderingPart.ProvidedSortOrder) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.SetOperationsOrdering
Method that reduces this set-operation ordering to only directional ordering parts by using a comparison key, a RequestedOrdering and a default.
DIRECTORY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
DIRECTORY_NOT_FOR_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
Return value from pathFromKey to indicate that a given tuple value is not appropriate for a given directory.
DIRECTORY_READ - Enum constant in enum 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
A KeySpaceDirectory that maps a STRING value to a compact LONG value using the FDB directory layer.
DirectoryLayerDirectory(String) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
Constructor for DirectoryLayerDirectory.
DirectoryLayerDirectory(String, Object) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
Constructor for DirectoryLayerDirectory.
DirectoryLayerDirectory(String, Object, Function<KeySpacePath, KeySpacePath>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
Constructor for DirectoryLayerDirectory.
DirectoryLayerDirectory(String, Object, Function<KeySpacePath, KeySpacePath>, Function<FDBRecordContext, CompletableFuture<LocatableResolver>>, ResolverCreateHooks) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
Constructor for DirectoryLayerDirectory.
DirectoryLayerDirectory(String, Function<KeySpacePath, KeySpacePath>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
Constructor for DirectoryLayerDirectory.
DirectoryLayerDirectory(String, Function<KeySpacePath, KeySpacePath>, Function<FDBRecordContext, CompletableFuture<LocatableResolver>>, ResolverCreateHooks) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.DirectoryLayerDirectory
Constructor for DirectoryLayerDirectory.
DIRECTOY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
Deprecated.
DISABLED - Enum constant in enum com.apple.foundationdb.record.IndexState
Indicates that this store does not use this index.
DISABLED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
The detection of blocking in an asynchronous context is disabled.
disabledIfTooManyRecordsForRebuild(long, boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Utility method to be used to specify that new indexes should be IndexState.DISABLED if an index is not on new record types and there are too many records to build in-line.
disableTransformationRule(Class<? extends CascadesRule<?>>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Helper method to disable the planner transformation rule class passed in.
disableWriteLock() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Unlocks this LocatableResolver, so that calls to LocatableResolver.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.
DISCARD - Enum constant in enum com.apple.foundationdb.record.sorting.MemoryScratchpad.RecordCountInMemoryLimitMode
Map retains top getMaxRecordCountInMemory values and discards additional values.
DISCARDED_INTERSECTION_COMBINATIONS - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
 
dispatchFromProtoContainer(PlanSerializationContext, Message) - Static method in class com.apple.foundationdb.record.query.plan.serialization.PlanSerialization
Method that, given a protobuf container message (a P-message that contains a oneof of specific messages), extracts the specific message, and dispatches to the PlanDeserializer that can deserialize the particular specific message.
DISTINCT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering.Distinctness
 
DISTINCT_FILTER_DEPTH - Static variable in class com.apple.foundationdb.record.query.plan.cascades.properties.RelationalExpressionDepthProperty
 
DISTINCT_RECORDS - Static variable in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty
 
DistinctRecordsProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
An attribute used to indicate if a plan produces distinct records.
DistinctRecordsProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty
 
DistinctRecordsProperty.DistinctRecordsVisitor - Class in com.apple.foundationdb.record.query.plan.cascades.properties
A visitor that determines whether the expression may produce distinct records.
DistinctRecordsVisitor() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
distinctSeal() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
DIV - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
DIV_DD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_DF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_DI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_DL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_FD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_FF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_FI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_FL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_ID - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_IF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_II - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_IL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_LD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_LF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_LI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DIV_LL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
DivFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.DivFn
 
DIVIDE - Static variable in class com.apple.foundationdb.record.FunctionNames
 
DNF - Enum constant in enum com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer.Mode
 
DNF_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
DNF_SIZE_LIMIT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
dnfPredicateToRanges(QueryPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.IndexPredicateExpansion
Verifies that a given predicate is in a disjunctive normal form (DNF) and groups it into a mapping from a Value and list of corresponding RangeConstraints.
dnfRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateWithDnfRuleSet
 
DO_NOT_RE_INCREASE_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
If OnlineIndexOperationBaseBuilder.getIncreaseLimitAfter() is this value, the limit will not go back up, no matter how many successes there are.
DOCUMENT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
doEquivalent(S, S) - Method in class com.apple.foundationdb.record.query.plan.cascades.Correlated.BoundEquivalence
 
doHash(S) - Method in class com.apple.foundationdb.record.query.plan.cascades.Correlated.BoundEquivalence
 
doneOrThrottleDelayAndMaybeLogProgress(boolean, SubspaceProvider, List<Object>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
dot(Object) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.explain.Attribute
Static factory method to create a DOT attribute based on a reference to some object.
DOT - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
DotExporter<N extends PlannerGraph.Node,E extends PlannerGraph.Edge> - Class in com.apple.foundationdb.record.query.plan.cascades.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>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.DotExporter
Constructs a new DotExporter object with the given ID, label, attribute, and graph ID providers.
DOUBLE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
 
DOUBLE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
DOUBLE - Enum constant in enum com.apple.foundationdb.record.query.plan.planning.BindingFunction
 
doubleAverageState() - Static method in class com.apple.foundationdb.record.cursors.aggregate.AverageAccumulatorState
 
doublePropertyKey(String, double) - Static method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
 
DoubleState - Class in com.apple.foundationdb.record.cursors.aggregate
Accumulator state for Double types.
DoubleState(PrimitiveAccumulatorOperation) - Constructor for class com.apple.foundationdb.record.cursors.aggregate.DoubleState
 
doWithReadLock(LockIdentifier, Supplier<CompletableFuture<T>>) - Method in class com.apple.foundationdb.record.locking.LockRegistry
Attempts to get access for read access on the resource represented by the id to perform an atomic operation.
doWithReadLock(LockIdentifier, Supplier<CompletableFuture<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
 
doWithWriteLock(LockIdentifier, Supplier<CompletableFuture<T>>) - Method in class com.apple.foundationdb.record.locking.LockRegistry
Attempts to get access for write access on the resource represented by the id to perform an atomic operation.
doWithWriteLock(LockIdentifier, Supplier<CompletableFuture<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
 
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.
dryRunDeleteRecordAsync(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
dryRunDeleteRecordAsync(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
 
dryRunDeleteRecordAsync(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
dryRunSaveRecordAsync(Message, FDBRecordStoreBase.RecordExistenceCheck, FDBRecordVersion, FDBRecordStoreBase.VersionstampSaveBehavior) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
dryRunSaveRecordAsync(M, FDBRecordStoreBase.RecordExistenceCheck) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
 
dryRunSaveRecordAsync(M, FDBRecordStoreBase.RecordExistenceCheck, FDBRecordVersion, FDBRecordStoreBase.VersionstampSaveBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
 
dryRunSaveRecordAsync(M, FDBRecordStoreBase.RecordExistenceCheck, FDBRecordVersion, FDBRecordStoreBase.VersionstampSaveBehavior) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
dryRunSaveWithSplitOnlySetSizeInfo(Subspace, Tuple, byte[], FDBRecordVersion, boolean, boolean, SplitHelper.SizeInfo) - Static method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper
 
dualOrder() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
DURATION_MILLIS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
DynamicEnum(int, String) - Constructor for class com.apple.foundationdb.record.util.ProtoUtils.DynamicEnum
 
DynamicMessageRecordSerializer - Class in com.apple.foundationdb.record.provider.common
Serialize records using default Protobuf serialization using DynamicMessage.
DynamicMessageRecordSerializer() - Constructor for class com.apple.foundationdb.record.provider.common.DynamicMessageRecordSerializer
 

E

EARLIEST_ADDED_START_TIMESTAMP - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
Edge() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Edge
 
Edge(String) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Edge
 
Edge(String, Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Edge
 
Edge(Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Edge
 
edgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
edgeConnecting(N, N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
edgeConnectingOrNull(EndpointPair<N>) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
edgeConnectingOrNull(N, N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
edgeOrder() - Method in class com.google.common.graph.StableStandardMutableNetwork
 
edges() - Method in class com.google.common.graph.StableStandardMutableNetwork
 
edgesConnecting(EndpointPair<N>) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
edgesConnecting(N, N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
eligibleElements() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet.EligibleSet
 
eligibleSet() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
eliminateArithmeticValueWithConstantRule(O) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.OrderingValueComputationRuleSet
 
EliminateArithmeticValueWithConstantRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that eliminates an arithmetic operation.
EliminateArithmeticValueWithConstantRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.EliminateArithmeticValueWithConstantRule
 
elminateArithmeticValueWithConstantRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.RequestedOrderingValueSimplificationRuleSet
 
emitEvent(Debugger.Location) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
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.combinatorics.PartiallyOrderedSet
 
empty() - Static method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph
 
empty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
empty() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.CollectionMatcher
 
empty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings
Return an empty set of bindings.
empty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
empty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMap
 
empty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.Derivations
 
empty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
empty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
 
empty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence
 
empty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
Get an instance representing an empty value.
empty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
empty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap
 
empty() - Static method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo
 
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 - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.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.cascades.ComparisonRange
 
EMPTY - Static variable in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
EMPTY_BINDINGS - Static variable in class com.apple.foundationdb.record.Bindings
 
EMPTY_FLAGS - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
EMPTY_NO_MATCHES - Enum constant in enum 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_SCANS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Count the number of scans executed that returned no data.
EMPTY_SCHEMA - Static variable in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
 
EMPTY_UNKNOWN - Enum constant in enum com.apple.foundationdb.record.query.expressions.Field.OneOfThemEmptyMode
An empty repeated field causes oneOfThem predicates to return UNKNOWN, like a scalar NULL value.
EMPTY_VALUE - Static variable in class com.apple.foundationdb.record.metadata.Index
 
emptyArray(Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue
 
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
A RecordCursor that always returns zero items.
EmptyCursor(Executor) - Constructor for class com.apple.foundationdb.record.cursors.EmptyCursor
 
emptyIterable() - Static method in interface com.apple.foundationdb.record.query.combinatorics.EnumeratingIterable
 
EmptyKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
A single empty key.
emptyMap() - Static method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Factory method to create an empty alias map.
emptyRange() - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
Returns an empty RangeConstraints instance, i.e.
EmptyValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value that evaluates to empty.
EmptyValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
enableAssertions - Variable in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
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 this LocatableResolver into a write locked state which will prevent any new entries from being created.
encapsulate(BuiltInFunction<T>, List<? extends Typed>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.EncapsulationFunction
Produces a Typed object that is able to carry out a computation against a list of arguments.
encapsulate(List<? extends Typed>) - Method in class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
 
encapsulate(List<? extends Typed>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfFunction
 
EncapsulationFunction<T extends Typed> - Interface in com.apple.foundationdb.record.query.plan.cascades
A functional interface that provides an encapsulation of a runtime computation against a set of arguments.
encloses(RangeConstraints, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
checks whether this range encloses another RangeConstraints under an EvaluationContext.
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 - Enum constant in enum 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() - Static method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
END - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
END - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
 
END - Static variable in class com.apple.foundationdb.record.RecordCursorEndContinuation
 
END_TUPLE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
endAnySession() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
Synchronous/blocking version of SynchronizedSessionRunner.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 - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
EndpointType - Enum in com.apple.foundationdb.record
The type of one of the endpoints of a TupleRange.
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 of SynchronizedSessionRunner.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.
enforceStampOverwrite() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
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
 
entries() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap
 
entrySet() - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Returns the set of entries in this map.
entrySet() - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
entrySet() - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentityMap
 
Enum(boolean, List<Type.Enum.EnumValue>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
Enum(boolean, List<Type.Enum.EnumValue>, String) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
ENUM - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
enumerate(EnumeratingIterator<CorrelationIdentifier>, List<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.ComputingMatcher
Method to enumerate the permutations on this side against the permutation of the other side in order to form matches (bijective mappings between the permutations).
enumerate(EnumeratingIterator<CorrelationIdentifier>, List<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.FindingMatcher
Method to enumerate the permutations on this side against the permutation of the other side in order to form matches (bijective mappings between the permutations).
enumerateCompatibleRequestedOrderings(RequestedOrdering) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
Method to, given a constraining RequestedOrdering, enumerates all ordering sequences supported by this ordering that are compatible with the given RequestedOrdering.
enumerateConstraintAliases(AliasMap, List<? extends Quantifier>, Function<Quantifier, Collection<AliasMap>>, Set<CorrelationIdentifier>, Set<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
Method to enumerate the bound aliases due to constraints.
enumerateIndexAggregateFunctionCandidates(String) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
Method to create a stream of enumerated IndexAggregateFunctions that represent the bound versions of this function call.
enumerateSatisfyingComparisonKeyValues(RequestedOrdering) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.SetOperationsOrdering
 
enumerateUnboundCorrelatedTo(AliasMap, RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Method to enumerate all bindings of unbound correlations of this and some other expression.
EnumeratingIterable<T> - Interface in com.apple.foundationdb.record.query.combinatorics
Iterable that provides special iterators of type EnumeratingIterator.
EnumeratingIterable.EmptyIterable<T> - Class in com.apple.foundationdb.record.query.combinatorics
An implementation of EnumeratingIterable that is optimized to work for empty input sets.
EnumeratingIterable.SingleIterable<T> - Class in com.apple.foundationdb.record.query.combinatorics
An implementation of EnumeratingIterable that is optimized to work for single item input sets.
EnumeratingIterable.SingleIterator<T> - Class in com.apple.foundationdb.record.query.combinatorics
A single element iterator.
EnumeratingIterator<T> - Interface in com.apple.foundationdb.record.query.combinatorics
An iterator extending Iterator providing the ability to skip a certain prefix.
EnumerationFunction<R> - Interface in com.apple.foundationdb.record.query.plan.cascades.matching.graph
Functional interface to allow implementors to provide use case-specific logic when permutations are enumerated by BaseMatcher.match(com.apple.foundationdb.record.query.plan.cascades.matching.graph.EnumerationFunction<R>, boolean).
EnumValue(String, int) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum.EnumValue
 
enumValuesFromProto(List<Descriptors.EnumValueDescriptor>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
equalities(CollectionMatcher<Comparisons.Comparison>) - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
EQUALITY - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.ComparisonRange.Type
 
EQUALITY - Enum constant in enum com.apple.foundationdb.record.query.plan.ScanComparisons.ComparisonType
 
EQUALITY - Enum constant in enum 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.locking.LockIdentifier
 
equals(Object) - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
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.IndexAggregateFunctionCall
 
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.ObjectPlanHash
 
equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRawRecord
 
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 this FDBRecordVersion mathces 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.IndexScanComparisons
 
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.KeySpaceTreeResolver.ResolvedAndRemainder
 
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.ResolverKeyValue
 
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.ResolverValidator.ValidatedEntry
 
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.TimeWindowLeaderboardIndexMaintainer.TimeWindowRankAndEntry
 
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.leaderboard.TimeWindowScanComparisons
 
equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
equals(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
 
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.BoundRecordQuery
 
equals(Object) - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
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.InvertedFunctionComparison
 
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.OpaqueEqualityComparison
 
equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
equals(Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
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.Comparisons.ValueComparison
 
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.QueryKeyExpressionWithOneOfComparison
 
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.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
equals(Object) - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph
 
equals(Object) - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph.Relationship
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Define equality based on the equality of the backing bimap.
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.Column
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.Correlated.BoundEquivalence
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.CorrelationIdentifier
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.AbstractNode
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUnionExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUniqueExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.IndexAccessHint
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentityMap
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Binding
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedOrderingPart
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.MappingKey
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndOrPredicate
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate.UsedIndex
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum.EnumValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.Accessor
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.ArrayCoercionBiFunction
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.PrimitiveCoercionBiFunction
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldWithValueCopier
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.MessageCopier
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
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.RecordQueryDefaultOnEmptyPlan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
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.RecordQueryFirstOrDefaultPlan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
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.RecordQueryInUnionPlan
 
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.RecordQueryMapPlan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
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.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
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.plans.RelativeProbabilityPlanSelector
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo.QueryPlanInfoKey
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortKey
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.plan.TextScan
 
equals(Object) - Method in class com.apple.foundationdb.record.query.RecordQuery
 
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 this RecordStoreState specifies 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.util.pair.ComparablePair
 
equals(Object) - Method in class com.apple.foundationdb.record.util.pair.ImmutablePair
 
equals(Object) - Method in class com.apple.foundationdb.record.util.pair.NonnullPair
 
equals(Object) - Method in class com.apple.foundationdb.record.util.ProtoUtils.DynamicEnum
 
equals(Object) - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNode
 
equals(Object) - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNodeBuilder
 
equals(Object) - Method in class com.apple.foundationdb.record.ValueRange
 
EQUALS - Enum constant in enum com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison.ComparisonType
 
EQUALS - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
EQUALS - Enum constant in enum com.apple.foundationdb.record.query.ParameterRelationshipGraph.RelationshipType
 
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
 
EqualsFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.EqualsFn
 
equalsForChildren(QueryPredicate, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndOrPredicate
 
equalsForChildren(QueryPredicate, ValueEquivalence) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
equalsInList(T) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
equalsObject(T) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PrimitiveMatchers
Matcher that matches if the object passed in is equal to the object being matched.
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.
equalsParameter(String) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression.OneOfThem
 
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.QueryKeyExpression.OneOfThem
 
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.cascades.expressions.DeleteExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUnionExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUniqueExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.TypeFilterExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
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.RecordQueryDefaultOnEmptyPlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
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.RecordQueryFirstOrDefaultPlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
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.RecordQueryIntersectionPlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
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.RecordQueryMapPlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
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.RecordQuerySelectorPlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
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.plans.TempTableInsertPlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
equalsWithoutChildren(RelationalExpression, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
equalsWithoutChildren(QueryPredicate, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
equalsWithoutChildren(QueryPredicate, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
equalsWithoutChildren(QueryPredicate, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
equalsWithoutChildren(QueryPredicate, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
equalsWithoutChildren(QueryPredicate, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
equalsWithoutChildren(QueryPredicate, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
Performs algebraic equality between this and other, if other is also a PredicateWithValueAndRanges.
equalsWithoutChildren(QueryPredicate, ValueEquivalence) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
equalsWithoutChildren(QueryPredicate, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
equalsWithoutChildren(Value) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
equalsWithoutChildren(Value) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
equalsWithoutChildren(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
erased() - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Creates a new erased Type.Record type instance and returns it.
eraseIndexingTypeStampTestOnly() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
 
ERROR - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
ERROR - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.IndexOrphanBehavior
Throw an exception when an orphaned entry is hit.
ERROR - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.DesiredAction
 
ERROR_CODE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
ERROR_IF_DISABLED_CONTINUE_IF_WRITE_ONLY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
Continue build only if the index is write-only and the requested method matches the previous one; Never rebuild.
ERROR_IF_EXISTS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
Throw if the record already exists.
ERROR_IF_EXISTS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.StoreExistenceCheck
Throw if the record store already exists.
ERROR_IF_NO_INFO_AND_HAS_RECORDS_OR_INDEXES - Enum constant in enum 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 - Enum constant in enum 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
Throw if the record does not already exist.
ERROR_IF_NOT_EXISTS - Enum constant in enum 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 - Enum constant in enum 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 - Enum constant in enum 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
 
ESCAPE_CHAR_OF_LIKE_OPERATOR_IS_NOT_SINGLE_CHAR - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
ESCHEW_RECORD_COMPRESSION - Enum constant in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Counts
The number of times that record compression was not effective and the record was kept uncompressed.
ESTIMATE_SIZE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time estimating the size of a key range.
estimateRecordsSizeAsync() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Compute an estimated size of all records in the store in bytes.
estimateRecordsSizeAsync(TupleRange) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
estimateRecordsSizeAsync(TupleRange) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Compute an estimated size in bytes of all records in the store within the given primary key range.
estimateRecordsSizeAsync(TupleRange) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
estimateStoreSizeAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
estimateStoreSizeAsync() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Compute an estimated size of the store in bytes.
estimateStoreSizeAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
eval() - Method in class com.apple.foundationdb.record.query.expressions.AsyncBoolean
 
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.InvertedFunctionComparison
 
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.OpaqueEqualityComparison
 
eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
eval(FDBRecordStoreBase<?>, EvaluationContext, Object) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.BinaryRelOpValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.UnaryRelOpValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value.IndexOnlyValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value.NonEvaluableValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
eval(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
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, Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
eval(Object, Object) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
eval(List<Object>) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
evalAsync(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>) - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
Asynchronous version of eval.
evalComparison(Comparisons.Type, Object, Object) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons
 
evalFilter(FDBRecordStoreBase<M>, EvaluationContext, QueryResult) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
 
evalFilter(FDBRecordStoreBase<M>, EvaluationContext, QueryResult) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
evalFilter(FDBRecordStoreBase<M>, EvaluationContext, QueryResult) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
evalFilterAsync(FDBRecordStoreBase<M>, EvaluationContext, QueryResult) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
 
evalFilterAsync(FDBRecordStoreBase<M>, EvaluationContext, QueryResult) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
evalFilterAsync(FDBRecordStoreBase<M>, EvaluationContext, QueryResult) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
evalForOneOfQuery(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in interface com.apple.foundationdb.record.metadata.expressions.QueryableKeyExpression
 
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
 
evalInitialToPartial(Object) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
 
evalInitialToPartial(Object) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
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.QueryKeyExpressionWithOneOfComparison
 
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 of evalMessage.
evalMessageAsync(FDBRecordStoreBase<M>, EvaluationContext, FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
 
evalPartialToFinal(Object) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
 
evalPartialToFinal(Object) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
evalPartialToPartial(Object, Object) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
 
evalPartialToPartial(Object, Object) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
evalToPartial(FDBRecordStoreBase<M>, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.AggregateValue
 
evalToPartial(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
evalToPartial(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
evalToPartial(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
evalToPartial(FDBRecordStoreBase<M>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
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(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
evaluate(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.ComparisonsProperty
 
evaluate(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.FieldWithComparisonCountProperty
 
evaluate(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.NormalizedResidualPredicateProperty
 
evaluate(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.RelationalExpressionDepthProperty
 
evaluate(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.TypeFilterCountProperty
 
evaluate(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.UnmatchedFieldsCountProperty
 
evaluate(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.UsedTypesProperty
 
evaluate(Quantifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
evaluate(Quantifiers.AliasResolver, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.RecordTypesProperty
 
evaluate(Quantifiers.AliasResolver, Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.RecordTypesProperty
 
evaluate(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
evaluate(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.FieldWithComparisonCountProperty
 
evaluate(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.NormalizedResidualPredicateProperty
 
evaluate(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.RecordTypesProperty
 
evaluate(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.ReferencesAndDependenciesProperty
 
evaluate(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.UsedTypesProperty
 
evaluate(RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
evaluate(RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
evaluate(RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
evaluate(RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
evaluate(Iterable<? extends Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.ReferencesAndDependenciesProperty
 
evaluate(Set<Class<? extends RelationalExpression>>, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.FindExpressionProperty
 
evaluateAggregateFunction(EvaluationContext, List<String>, IndexAggregateFunction, TupleRange, IsolationLevel) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Evaluate an IndexAggregateFunction against 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.PermutedMinMaxIndexMaintainer
 
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 an IndexAggregateFunction against a group value.
evaluateAggregateFunction(List<String>, IndexAggregateFunction, TupleRange, IsolationLevel) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Evaluate an IndexAggregateFunction against a range of the store.
evaluateAggregateFunction(List<String>, IndexAggregateFunction, TupleRange, IsolationLevel, IndexQueryabilityFilter) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
evaluateAggregateFunction(List<String>, IndexAggregateFunction, TupleRange, IsolationLevel, IndexQueryabilityFilter) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Evaluate an IndexAggregateFunction against a range of the store.
evaluateAggregateFunction(List<String>, IndexAggregateFunction, TupleRange, IsolationLevel, IndexQueryabilityFilter) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
evaluateAtExpression(RelationalExpression, List<PartiallyOrderedSet<Reference>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.ReferencesAndDependenciesProperty
 
evaluateAtExpression(RelationalExpression, List<PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
evaluateAtExpression(RelationalExpression, List<QueryPredicate>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.NormalizedResidualPredicateProperty
 
evaluateAtExpression(RelationalExpression, List<CardinalitiesProperty.Cardinalities>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
evaluateAtExpression(RelationalExpression, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.FieldWithComparisonCountProperty
 
evaluateAtExpression(RelationalExpression, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.RelationalExpressionDepthProperty
 
evaluateAtExpression(RelationalExpression, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.TypeFilterCountProperty
 
evaluateAtExpression(RelationalExpression, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.UnmatchedFieldsCountProperty
 
evaluateAtExpression(RelationalExpression, List<Map<Class<? extends RelationalExpression>, Set<RelationalExpression>>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.FindExpressionProperty
 
evaluateAtExpression(RelationalExpression, List<Set<Comparisons.Comparison>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.ComparisonsProperty
 
evaluateAtExpression(RelationalExpression, List<Set<Type>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.UsedTypesProperty
 
evaluateAtExpression(RelationalExpression, List<Set<String>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.RecordTypesProperty
 
evaluateAtExpression(RelationalExpression, List<T>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.ExpressionProperty
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.cascades.ExpressionProperty
Evaluate the property at the given quantifier, using the result of evaluating the property at the reference the quantifier ranges over.
evaluateAtRef(Reference, List<PartiallyOrderedSet<Reference>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.ReferencesAndDependenciesProperty
 
evaluateAtRef(Reference, List<PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
evaluateAtRef(Reference, List<QueryPredicate>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.NormalizedResidualPredicateProperty
 
evaluateAtRef(Reference, List<CardinalitiesProperty.Cardinalities>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
evaluateAtRef(Reference, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.FieldWithComparisonCountProperty
 
evaluateAtRef(Reference, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.RelationalExpressionDepthProperty
 
evaluateAtRef(Reference, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.TypeFilterCountProperty
 
evaluateAtRef(Reference, List<Integer>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.UnmatchedFieldsCountProperty
 
evaluateAtRef(Reference, List<Map<Class<? extends RelationalExpression>, Set<RelationalExpression>>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.FindExpressionProperty
 
evaluateAtRef(Reference, List<Set<Comparisons.Comparison>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.ComparisonsProperty
 
evaluateAtRef(Reference, List<Set<Type>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.UsedTypesProperty
 
evaluateAtRef(Reference, List<Set<String>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.RecordTypesProperty
 
evaluateAtRef(Reference, List<T>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.ExpressionProperty
Evaluate the property at the given reference, using the results of evaluating the property at its members.
EVALUATED_INDEX - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
EVALUATED_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
evaluateDerivations(RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty
 
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
The evaluateFunction method implements the function execution.
evaluateFunction(FDBRecord<M>, Message, Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression
 
evaluateFunction(FDBRecord<M>, Message, Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
evaluateIndex(FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
 
evaluateIndex(FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
Apply the key and value expressions to a record.
evaluateIndex(FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
Apply the key and value expressions to a record.
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 a IndexRecordFunction against a record.
evaluateIndexRecordFunction(EvaluationContext, IndexRecordFunction<T>, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
evaluateInverse(Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.InvertibleFunctionKeyExpression
Return all possible pre-images for the given function result.
evaluateInverseInternal(Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.InvertibleFunctionKeyExpression
 
evaluateInverseInternal(Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
evaluateMessage(FDBRecord<M>, Message) - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
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
 
evaluateMessageSingleton(FDBRecord<M>, Message) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
Evaluate against a given record producing a list of evaluated keys.
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 a RecordFunction against a record.
evaluateRecordFunction(RecordFunction<T>, FDBRecord<M>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Evaluate a RecordFunction against 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 a StoreRecordFunction against 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 a StoreRecordFunction against 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 for EvaluationContext.
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 existing EvaluationContext.
evalWithoutStore(EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
evalWithoutStore(EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
evaluates computation of the expression without a store and returns the result immediately.
event - Variable in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
 
exactly(BindingMatcher<? extends T>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ListMatcher
 
exactly(List<? extends BindingMatcher<? extends T>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ListMatcher
 
exactlyInAnyOrder(BindingMatcher<? extends T>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.SetMatcher
 
exactlyInAnyOrder(Collection<? extends BindingMatcher<? extends T>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.SetMatcher
 
exactlyPlans(BindingMatcher<? extends RecordQueryPlan>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
exactlyPlansInAnyOrder(BindingMatcher<? extends RecordQueryPlan>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
exactlyPlansInAnyOrder(Collection<? extends BindingMatcher<? extends RecordQueryPlan>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
exactlySubsumedBy(RelationalExpression, AliasMap, IdentityBiMap<Quantifier, PartialMatch>, TranslationMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Helper method that can be called by sub classes to defer subsumption in a way that the particular expression only matches if it is semantically equivalent.
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 this LocatableResolver into a write locked state which will prevent any new entries from being created.
execute() - Method in interface com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner.Task
 
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 interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
Execute this query plan.
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
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
Execute children and compare results.
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
Execute this plan, returning a RecordCursor to QueryResult result.
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithIndex
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySelectorPlan
Select a plan and execute it.
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
executePlan(FDBRecordStoreBase<M>, EvaluationContext, byte[], ExecuteProperties) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
ExecuteProperties - Class in com.apple.foundationdb.record
Limits on the execution of a query.
ExecuteProperties.Builder - Class in com.apple.foundationdb.record
A builder for ExecuteProperties.
executeQuery(RecordQueryPlan) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Execute a query.
executeQuery(RecordQueryPlan, byte[], EvaluationContext, ExecuteProperties) - 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, ByteScanLimiter) - Constructor for class com.apple.foundationdb.record.ExecuteState
Creates an execute state with a supplied set of resource limiters.
ExecutingTaskEvent(Reference, Deque<CascadesPlanner.Task>, Debugger.Location, CascadesPlanner.Task) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExecutingTaskEvent
 
executor - Variable in class com.apple.foundationdb.record.cursors.AsyncIteratorCursor
 
exhausted() - Static method in class com.apple.foundationdb.record.RecordCursorResult
Obtain the static result that a cursor can return when it is completely exhausted.
exhaustive() - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
 
existential(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Shorthand to create an existential quantifier ranging over a reference.
existential(Reference, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Shorthand to create an existential quantifier ranging over a reference using a given alias.
existentialBuilder() - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Create a builder for an existential quantifier containing relational expressions.
ExistentialBuilder() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Existential.ExistentialBuilder
 
existentialQuantifier() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
existentialQuantifier(BindingMatcher<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
existentialQuantifier(CollectionMatcher<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
ExistentialQuantifierEdge() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ExistentialQuantifierEdge
 
ExistentialQuantifierEdge(String, Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ExistentialQuantifierEdge
 
ExistentialQuantifierEdge(Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ExistentialQuantifierEdge
 
existentialQuantifierOverRef(BindingMatcher<? extends Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
existentialQuantifiers(Iterable<Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.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
 
ExistsFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue.ExistsFn
 
ExistsPredicate - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
An existential predicate that is true if the inner correlation produces any values, and false otherwise.
ExistsPredicate(CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
ExistsPredicate.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Deserializer.
existsSubTupleForOrdinalPath(Tuple, ImmutableIntArray) - Static method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
 
ExistsValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value that checks whether an item exists in its child quantifier expression or not.
ExistsValue(CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
ExistsValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
ExistsValue.ExistsFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
A function that checks whether an item exists in a RelationalExpression.
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
Expand this key expression into a data flow graph.
expand(KeyExpressionVisitor<S, R>) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpressionWithValue
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
 
expand(KeyExpressionVisitor<S, R>) - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>) - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
Expand this query component into a data flow graph.
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.AndComponent
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.EmptyComparison
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.NestedField
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.OrComponent
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
Expand this query component into a data flow graph.
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithOneOfComparison
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
 
expand(Quantifier.ForEach, Supplier<Quantifier.ForEach>, List<String>) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
 
expand(Supplier<Quantifier.ForEach>, KeyExpression, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexExpansionVisitor
Creates a new match candidate representing the aggregate index.
expand(Supplier<Quantifier.ForEach>, KeyExpression, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.ExpansionVisitor
Method that expands a data structure into a data flow graph.
expand(Supplier<Quantifier.ForEach>, KeyExpression, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryAccessExpansionVisitor
 
expand(Supplier<Quantifier.ForEach>, KeyExpression, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexExpansionVisitor
 
expand(Supplier<Quantifier.ForEach>, KeyExpression, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexExpansionVisitor
We expand a rank index into a QGM representing the nature of the index as relational-algebra.
expandFusedFieldValueRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MaxMatchMapSimplificationRuleSet
 
ExpandFusedFieldValueRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that decomposes a FieldValue that uses multiple steps into two FieldValues as follows:
ExpandFusedFieldValueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExpandFusedFieldValueRule
 
expandRecordRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MaxMatchMapSimplificationRuleSet
 
ExpandRecordRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that expands a Value of type Type.Record into a record constructor over its constituent parts as follows:
ExpandRecordRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExpandRecordRule
 
ExpansionVisitor<S extends KeyExpressionVisitor.State> - Interface in com.apple.foundationdb.record.query.plan.cascades
A sub interface of KeyExpressionVisitor that fixes the return type to be a GraphExpansion and adds an API to cause the expansion of a metadata-based data access structure to a data flow graph that can then be used for matching.
EXPECTED - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
EXPECTED_CHILD_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
EXPECTED_COLUMN_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
EXPECTED_INDEX - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
EXPECTED_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
EXPECTED_VALUE_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
EXPEXP - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
 
EXPGROUP - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
 
explain() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
explain() - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScanParameters
Get a short summary of the scan, not including the scan type.
explain() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons
 
explain() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
explain() - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextWithMaxDistanceComparison
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
explain() - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
explain() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
Returns a human-friendly textual representation of this QueryPredicate.
explain() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.CompilableRange
 
explain() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
explain() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Returns a human-friendly textual representation of this Value.
explain() - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
explain() - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
explain() - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
explain() - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
explain() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithExplain
 
explain() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction
 
explain() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression
 
explain() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues
 
explain() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
explain(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.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.cascades.explain.PlannerGraphProperty
Generate the explain of the planner expression that is passed in.
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.BinaryRelOpValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.UnaryRelOpValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
explain(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
explainExtraction(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.Extractor
 
ExplainFormatter - Interface in com.apple.foundationdb.record.query.plan.explain
A formatter for tokens.
explainFunctionArguments(Iterable<Supplier<ExplainTokensWithPrecedence>>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
ExplainLevel - Class in com.apple.foundationdb.record.query.plan.explain
Explain level.
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AllOfMatcher
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AnyMatcher
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AnyOfMatcher
 
explainMatcher(Class<?>, String, String) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
Method that explain what this matcher does.
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ContainsExpressionInReferenceMatcher
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.InstanceMatcher
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ListMatcher
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MultiMatcher.AllMatcher
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MultiMatcher.SomeMatcher
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.NotMatcher
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.OptionalIfPresentMatcher
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.SetMatcher
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcher
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcherWithExtractAndDownstream
 
explainMatcher(Class<?>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcherWithPredicate
 
ExplainPlannerGraphRewritable - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Interface to allow RelationalExpressions to rewrite their own explain graph representation.
ExplainPlanVisitor - Class in com.apple.foundationdb.record.query.plan.explain
Visitor that produces a string representation of a RecordQueryPlan.
ExplainPlanVisitor(int) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
ExplainSelfContainedSymbolMap - Class in com.apple.foundationdb.record.query.plan.explain
Formatting for Value.explain().
ExplainSelfContainedSymbolMap() - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainSelfContainedSymbolMap
 
explainSuffix() - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
ExplainSymbolMap - Interface in com.apple.foundationdb.record.query.plan.explain
Interface for simple symbol maps for the purpose of mapping an alias as supplied by the planner to a human-readable string symbol.
ExplainTokens - Class in com.apple.foundationdb.record.query.plan.explain
Class to hold information about a list of tokens.
ExplainTokens() - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
ExplainTokens.AliasDefinitionToken - Class in com.apple.foundationdb.record.query.plan.explain
An alias definition token.
ExplainTokens.AliasReferenceToken - Class in com.apple.foundationdb.record.query.plan.explain
An alias reference token.
ExplainTokens.BracketLikeToken - Class in com.apple.foundationdb.record.query.plan.explain
A brackets token.
ExplainTokens.CommaLikeToken - Class in com.apple.foundationdb.record.query.plan.explain
A comma-like token.
ExplainTokens.CurrentAliasDefinitionToken - Class in com.apple.foundationdb.record.query.plan.explain
Token that registers an alias explicitly to some symbol.
ExplainTokens.IdentifierToken - Class in com.apple.foundationdb.record.query.plan.explain
An identifier token.
ExplainTokens.KeywordToken - Class in com.apple.foundationdb.record.query.plan.explain
A keyword token.
ExplainTokens.LineBreakOrSpaceToken - Class in com.apple.foundationdb.record.query.plan.explain
A line break or whitespace token.
ExplainTokens.NestedToken - Class in com.apple.foundationdb.record.query.plan.explain
A nested token.
ExplainTokens.OptionalWhitespaceToken - Class in com.apple.foundationdb.record.query.plan.explain
An optional whitespace token.
ExplainTokens.PopToken - Class in com.apple.foundationdb.record.query.plan.explain
A pop token.
ExplainTokens.PushToken - Class in com.apple.foundationdb.record.query.plan.explain
A push token.
ExplainTokens.Token - Class in com.apple.foundationdb.record.query.plan.explain
Generic token structure.
ExplainTokens.TokenKind - Enum in com.apple.foundationdb.record.query.plan.explain
A token enumeration that is used intermittently when something is explained.
ExplainTokens.ToStringToken - Class in com.apple.foundationdb.record.query.plan.explain
A ToString token.
ExplainTokens.WhitespaceToken - Class in com.apple.foundationdb.record.query.plan.explain
A whitespace token.
ExplainTokensWithPrecedence - Class in com.apple.foundationdb.record.query.plan.explain
Holder class for the result of a call to Value.explain() and derivatives.
ExplainTokensWithPrecedence.Precedence - Enum in com.apple.foundationdb.record.query.plan.explain
Precedence which informs the explain logic whether to put parentheses around explain terms or not.
EXPLICIT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
 
explodeExpression() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
ExplodeExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A table function expression that "explodes" a repeated field into a stream of its values.
ExplodeExpression(Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
explodeField(Quantifier.ForEach, List<String>) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
 
explodeField(Quantifier.ForEach, List<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
explodePlan() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
ExploreExpressionEvent(Reference, Deque<CascadesPlanner.Task>, Debugger.Location, Reference, RelationalExpression) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreExpressionEvent
 
ExploreGroupEvent(Reference, Deque<CascadesPlanner.Task>, Debugger.Location, Reference) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreGroupEvent
 
ExponentialDelay - Class in com.apple.foundationdb.record.provider.foundationdb.runners
This class maintains a delay that should be used when retrying transactional operations that have failed due to something retriable.
ExponentialDelay(long, long, ScheduledExecutorService) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.runners.ExponentialDelay
 
ExporterContext(ImmutableNetwork<N, E>, PrintWriter) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter.ExporterContext
 
exportGraph(ImmutableNetwork<N, E>, Writer) - Method in class com.apple.foundationdb.record.query.plan.cascades.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.cascades.explain.PlannerGraphProperty
Creates a serialized format of this graph as a dot-compatible definition.
exportToDot(AbstractPlannerGraph<PlannerGraph.Node, PlannerGraph.Edge>, Set<PlannerGraph.Node>, Function<GraphExporter.ClusterProvider<PlannerGraph.Node, PlannerGraph.Edge>, Collection<GraphExporter.Cluster<PlannerGraph.Node, PlannerGraph.Edge>>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.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.cascades.explain.PlannerGraphProperty
Creates a serialized format of this graph as a gml-compatible definition.
ExpressionProperty<T> - Interface in com.apple.foundationdb.record.query.plan.cascades
An interface for certain Cascades-style properties, which are measurable features of an expression other than the structure of the expression tree.
ExpressionToTuplePathVisitor - Class in com.apple.foundationdb.record.query.plan
Visitor to find mappings of KeyExpressions to tuple access paths that are encoded as AvailableFields.FieldData.
ExpressionToTuplePathVisitor(KeyExpression, IndexKeyValueToPartialRecord.TupleSource, int, BitSet) - Constructor for class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
ExpressionToTuplePathVisitor.Result - Class in com.apple.foundationdb.record.query.plan
Result class.
ExpressionToTuplePathVisitor.State - Class in com.apple.foundationdb.record.query.plan
State class.
EXTENDED_DIRECTORY_LAYER_CREATE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent adding a new entry to an ExtendedDirectoryLayer.
EXTENDED_DIRECTORY_LAYER_READ - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent reading an entry from an ExtendedDirectoryLayer.
ExtendedDirectoryLayer - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
An implementation of LocatableResolver that uses a key format that is compatible with the ScopedDirectoryLayer to 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.
extractEqualityBoundFields(QueryComponent) - Static method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
Helper method to extract a set of key expressions that are bound through an equality comparison in the query component passed in.
extractFieldPaths(QueryComponent, Predicate<ComponentWithComparison>) - Static method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
Helper method to extract a set of key expressions that are bound through some comparison in the query component passed in.
extractFromIndexEntryMaybe(Value, AliasMap, Set<CorrelationIdentifier>, IndexKeyValueToPartialRecord.TupleSource, ImmutableIntArray) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Method that computes the Value tree that is needed to extract and subsequently transforms the data of a field coming from an index entry before it can be put into a partial record.
ExtractFromIndexKeyValueRuleSet - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A set of rules to be used to create a Value tree to extract an item from an index entry and perform necessary adjustments prior to constructing the partial record in IndexKeyValueToPartialRecord.
ExtractFromIndexKeyValueRuleSet() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExtractFromIndexKeyValueRuleSet
 
Extractor<T,U> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Interface for the unapply function using in a variety of matchers.
Extractor(Unapply<T, U>, UnaryOperator<String>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.structure.Extractor
 
Extractor(UnapplyWithConfiguration<T, U>, UnaryOperator<String>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.structure.Extractor
 

F

Factory() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.TempTable.Factory
 
FAIL - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
FAILED_TRANSACTIONS_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
FAILED_TRANSACTIONS_COUNT_IN_RUNNER - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
failure(E) - Static method in class com.apple.foundationdb.record.util.Result
Create an unsuccessful result wrapping an error.
FAILURE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
 
FallbackCursor<T> - Class in com.apple.foundationdb.record.cursors
Provide an alternative cursor in case the primary cursor fails.
FallbackCursor(RecordCursor<T>, Function<RecordCursorResult<T>, RecordCursor<T>>) - Constructor for class com.apple.foundationdb.record.cursors.FallbackCursor
Creates a new fallback cursor.
FallbackCursor.FallbackExecutionFailedException - Exception in com.apple.foundationdb.record.cursors
Exception thrown when the fallback cursor fails.
FallbackExecutionFailedException(String, Throwable) - Constructor for exception com.apple.foundationdb.record.cursors.FallbackCursor.FallbackExecutionFailedException
 
FALSE - Enum constant in enum com.apple.foundationdb.record.metadata.IndexPredicate.ConstantPredicate.ConstantValue
 
FALSE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.predicates.Proposition
 
FALSE - Static variable in interface com.apple.foundationdb.record.query.IndexQueryabilityFilter
 
FALSE - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
falseValue() - Static method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
Factory method to return a false.
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 - Enum constant in enum 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 FDB Database, 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
Abstract class for a factory that manages FDBDatabase instances.
FDBDatabaseFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
FDBDatabaseFactoryImpl - Class in com.apple.foundationdb.record.provider.foundationdb
A singleton maintaining a list of FDBDatabase instances, indexed by their cluster file location.
FDBDatabaseFactoryImpl() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
FDBDatabaseRunner - Interface in com.apple.foundationdb.record.provider.foundationdb
A context for running against an FDBDatabase with retrying of transient exceptions.
FDBDatabaseRunner.RunnerClosed - Exception in com.apple.foundationdb.record.provider.foundationdb
Exception thrown when FDBDatabaseRunner has been closed but tries to do work.
FDBDatabaseRunnerImpl - Class in com.apple.foundationdb.record.provider.foundationdb
The standard implementation of FDBDatabaseRunner.
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.FDBStoreLockTakenException - Exception in com.apple.foundationdb.record.provider.foundationdb
Transaction failed due to a lock already taken.
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.
FDBIndexedRawRecord - Class in com.apple.foundationdb.record.provider.foundationdb
A raw record that has been loaded via an index.
FDBIndexedRawRecord(IndexEntry, MappedKeyValue) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRawRecord
Wrap a stored record with an index entry that pointed to it.
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.
FDBLatencySource - Enum in com.apple.foundationdb.record.provider.foundationdb
Indicates which FDB API calls are to have latency injected into them via FDBDatabaseFactory.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 the FDBLocalityProvider interface that uses foundationDB's LocalityUtil API to discover the storage locations of keys within a cluster.
FDBMetaDataStore - Class in com.apple.foundationdb.record.provider.foundationdb
Serialization of RecordMetaData into 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, FDBStoreTimer) - 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
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 an FDBRecordContext.
FDBRecordContextConfig.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
A builder of FDBRecordContextConfigs 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, FDBRecordStore.StateCacheabilityOnOpen, FDBRecordStoreBase.UserVersionChecker, PlanSerializationRegistry) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
FDBRecordStore.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
A builder for FDBRecordStore.
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.
FDBRecordStore.StateCacheabilityOnOpen - Enum in com.apple.foundationdb.record.provider.foundationdb
Enum controlling how the store state cacheability flag should be changed when the store is opened.
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 for FDBRecordStoreBase.
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 (via FDBRecordStoreBase.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.
FDBRecordStoreProperties - Class in com.apple.foundationdb.record
Property keys for the FDBRecordStore and related classes.
FDBRecordStoreStateCache - Interface in com.apple.foundationdb.record.provider.foundationdb.storestate
A cache for FDBRecordStoreStateCacheEntry objects.
FDBRecordStoreStateCacheEntry - Class in com.apple.foundationdb.record.provider.foundationdb.storestate
Information needed to initialize an FDBRecordStore that is not stored within the record store's RecordMetaData.
FDBRecordStoreStateCacheFactory - Interface in com.apple.foundationdb.record.provider.foundationdb.storestate
A factory interface for FDBRecordStoreStateCaches.
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 FDB DirectoryLayer.
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 an FDBRecordContext and occupy some Subspace in 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 for FDBStoredRecord.
FDBStoredRecordBuilder() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
 
FDBStoredRecordBuilder(FDBStoredRecord<M>) - 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
 
FDBStoreLockTakenException(String, Exception) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreLockTakenException
 
FDBStoreRetriableException(FDBException) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreRetriableException
 
FDBStoreRetriableException(String, FDBException) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBExceptions.FDBStoreRetriableException
 
FDBStoreTimer - Class in com.apple.foundationdb.record.provider.foundationdb
A StoreTimer associated with FDBRecordStore operations.
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
Standard StoreTimer.Count events.
FDBStoreTimer.DetailEvents - Enum in com.apple.foundationdb.record.provider.foundationdb
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
Standard StoreTimer.Wait events.
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
 
FDBStoreTransactionIsTooOldException(String, 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
 
FDBSystemOperations - Class in com.apple.foundationdb.record.provider.foundationdb
View of an FoundationDB database used for accessing system and special keys.
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 FDB Transaction.
FDBTransactionContext(FDBDatabase, Transaction, FDBStoreTimer, 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 for FDBTypedRecordStore.
FETCH_DEPTH - Static variable in class com.apple.foundationdb.record.query.plan.cascades.properties.RelationalExpressionDepthProperty
 
FETCH_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
FETCHES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
Time for FDB fetches.
fetchFromPartialRecord(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
fetchFromPartialRecord(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
fetchFromPartialRecordPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
fetchIndexRecords(FDBRecordStoreBase<M>, EvaluationContext, Function<byte[], RecordCursor<IndexEntry>>, byte[], ExecuteProperties) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithIndex
 
fetchIndexRecords(FDBRecordStoreBase<M>, RecordCursor<IndexEntry>, ExecuteProperties) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords.FetchIndexRecordsFunction
 
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 - Enum constant in enum 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(Type, Optional<String>, Optional<Integer>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
Constructs a new field.
Field(String) - Constructor for class com.apple.foundationdb.record.query.expressions.Field
 
FIELD_ACCESS_INPUT_NON_RECORD_TYPE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
FIELD_COMPARATOR - Static variable in class com.apple.foundationdb.record.provider.foundationdb.cursors.KeyComparisons
 
FIELD_NAME - Enum constant in enum 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.
FieldAccessTrieNodeBuilder(Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.FieldAccessTrieNodeBuilder
 
FieldAccessTrieNodeBuilder(Type, Map<FieldValue.ResolvedAccessor, CompatibleTypeEvolutionPredicate.FieldAccessTrieNodeBuilder>, Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.FieldAccessTrieNodeBuilder
 
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
 
fieldName(Object) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Constructs a field name for a given field suffix.
FieldPath(List<FieldValue.ResolvedAccessor>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
fieldValue(BindingMatcher<V>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
FieldValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value representing the contents of a (non-repeated, arbitrarily-nested) field of a quantifier.
FieldValue.Accessor - Class in com.apple.foundationdb.record.query.plan.cascades.values
Helper class to hold information about a particular field access.
FieldValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
FieldValue.FieldPath - Class in com.apple.foundationdb.record.query.plan.cascades.values
A list of fields forming a path.
FieldValue.ResolvedAccessor - Class in com.apple.foundationdb.record.query.plan.cascades.values
A resolved FieldValue.Accessor that now also holds the resolved Type.
FieldValueCompensation - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A compensation that utilizes a field access.
FieldValueCompensation(FieldValue.FieldPath) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.FieldValueCompensation
 
FieldValueCompensation(FieldValue.FieldPath, ValueCompensation) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.FieldValueCompensation
 
fieldValuesFromPredicates() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionWithPredicates
 
fieldValuesFromPredicates(Collection<? extends QueryPredicate>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionWithPredicates
Return all FieldValues contained in the predicates handed in.
fieldValuesFromPredicates(Collection<? extends QueryPredicate>, Predicate<PredicateWithValue>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionWithPredicates
Return all FieldValues contained in the predicates handed in.
fieldValueWithFieldNames(BindingMatcher<V>, CollectionMatcher<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
fieldValueWithFieldNames(BindingMatcher<V>, String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
fieldValueWithFieldNames(String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
fieldValueWithFieldPath(BindingMatcher<V>, CollectionMatcher<Integer>, CollectionMatcher<Type>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
fieldValueWithLastFieldName(BindingMatcher<V>, BindingMatcher<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
FieldWithComparison - Class in com.apple.foundationdb.record.query.expressions
A QueryComponent that implements a Comparisons.Comparison against 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.cascades.properties
A property that counts the number of FieldWithComparisons that appear in a planner expression tree.
FieldWithComparisonCountProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.FieldWithComparisonCountProperty
 
FILE_SORT_FILE_BYTES - Enum constant in enum com.apple.foundationdb.record.sorting.SortEvents.Counts
 
FILE_SORT_LOAD_RECORD - Enum constant in enum com.apple.foundationdb.record.sorting.SortEvents.Events
 
FILE_SORT_MERGE_FILES - Enum constant in enum com.apple.foundationdb.record.sorting.SortEvents.Events
 
FILE_SORT_OPEN_FILE - Enum constant in enum com.apple.foundationdb.record.sorting.SortEvents.Events
 
FILE_SORT_SAVE_RECORD - Enum constant in enum com.apple.foundationdb.record.sorting.SortEvents.Events
 
FILE_SORT_SKIP_RECORD - Enum constant in enum com.apple.foundationdb.record.sorting.SortEvents.Events
 
FILE_SORT_SKIP_SECTION - Enum constant in enum com.apple.foundationdb.record.sorting.SortEvents.Events
 
FileSortAdapter<K,V> - Interface in com.apple.foundationdb.record.sorting
Provide various options for FileSorter and FileSortCursor.
FileSortCursor<K,V> - Class in com.apple.foundationdb.record.sorting
Sort records in memory and / or in files, then return them in order.
FileSorter<K,V> - Class in com.apple.foundationdb.record.sorting
Write sorted keyed values into Files.
FileSorter(FileSortAdapter<K, V>, StoreTimer, Executor) - Constructor for class com.apple.foundationdb.record.sorting.FileSorter
 
FileSorter.LoadResult - Class in com.apple.foundationdb.record.sorting
filter - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
 
filter(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
filter(BiPredicate<ComponentWithComparison, String>) - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
 
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(Predicate<? super QueryPlanConstraint>) - Method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
Monadic method to filter this by applying a Predicate to the recorded plan constraint if applicable.
FILTER - Enum constant in enum 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.NoOpIndexMaintainer
 
filteredIndexEntries(FDBIndexableRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
Filter out index keys according to IndexMaintenanceFilter.
filteredIndexEntries(FDBIndexableRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
Similar to IndexMaintainer.evaluateIndex(FDBRecord), but returns null if the record should be filtered out.
filterElements(Predicate<T>) - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
Method that computes a new partially-ordered set that only retains elements that pass the filtering predicate.
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.
filterMappings(BiPredicate<CorrelationIdentifier, CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Filter the bindings of this alias map using some bi-predicate that is handed in.
filterPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
filterPlan(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
FilterSatisfiedMask - Class in com.apple.foundationdb.record.query.plan.planning
A mask that can be applied over a QueryComponent to 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 another FilterSatisfiedMask to 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
 
finalizeGroup() - Method in class com.apple.foundationdb.record.cursors.aggregate.StreamGrouping
 
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 the key tuple, starting at position keyIndex.
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.
findCompleteMatches() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.FindingMatcher
findCompleteMatches() - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.graph.PredicatedMatcher
Find complete matches.
findCompleteMatches(Set<CorrelationIdentifier>, Function<CorrelationIdentifier, Set<CorrelationIdentifier>>, Set<CorrelationIdentifier>, Function<CorrelationIdentifier, Set<CorrelationIdentifier>>, MatchPredicate<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Find complete matches between two sets of aliases, given their depends-on sets and a MatchPredicate.
findException(Throwable, Class<T>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
FindExpressionProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
A property that determines finds all occurrences of expressions of interest in a planner graph.
FindExpressionProperty(Set<Class<? extends RelationalExpression>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.FindExpressionProperty
 
findExpressions(Class<? extends RelationalExpression>, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.FindExpressionProperty
 
findExpressions(Set<Class<? extends RelationalExpression>>, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.FindExpressionProperty
 
findFieldDescriptor(MessageOrBuilder) - Method in class com.apple.foundationdb.record.query.expressions.BaseField
 
findFieldDescriptorOnMessage(MessageOrBuilder, int) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
 
findFieldDescriptorOnMessage(MessageOrBuilder, String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
 
findFieldDescriptorOnMessageByOrdinal(MessageOrBuilder, int) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
 
findFilterReferencedFields(QueryComponent, Set<KeyExpression>) - Static method in class com.apple.foundationdb.record.query.plan.visitor.FilterVisitor
 
findImpliedMappings(ValueEquivalence, QueryPredicate, Iterable<? extends QueryPredicate>, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
Method to find all mappings of this predicate in an Iterable of candidate predicates.
FindingMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.graph
This class implements a PredicatedMatcher which matches two sets of elements of type T to compute an Iterable of AliasMaps.
findInnerQuantifier(SelectExpression, Collection<? extends Quantifier>, Set<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughInLikeSelectRule
 
findLeaderboard(int, long, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
 
findMatches() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.FindingMatcher
findMatches() - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.graph.PredicatedMatcher
Find matches.
findMatches(AliasMap, Collection<? extends Quantifier>, Collection<? extends Quantifier>, MatchPredicate<Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
Method to find matches between the given set of quantifiers and the given set of other quantifiers using an alias map and a matchPredicate.
findMatches(RelationalExpression, AliasMap, MatchPredicate<Quantifier>, RelationalExpression.CombinePredicate) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Find matches between this expression and another given expression under the bindings given by the AliasMap passed in.
findMatches(Set<CorrelationIdentifier>, Function<CorrelationIdentifier, Set<CorrelationIdentifier>>, Set<CorrelationIdentifier>, Function<CorrelationIdentifier, Set<CorrelationIdentifier>>, MatchPredicate<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Find matches (including partial matches) between two sets of aliases, given their depends-on sets and a MatchPredicate.
findReferencingExpressions(ImmutableList<? extends Reference>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
finish() - Method in interface com.apple.foundationdb.record.cursors.aggregate.AccumulatorState
Finalize the accumulation operation and return the result.
finish() - Method in interface com.apple.foundationdb.record.cursors.aggregate.AggregateAccumulator
Calculate and return the result from the accumulated state.
finish() - Method in class com.apple.foundationdb.record.cursors.aggregate.AverageAccumulatorState
 
finish() - Method in class com.apple.foundationdb.record.cursors.aggregate.DoubleState
 
finish() - Method in class com.apple.foundationdb.record.cursors.aggregate.FloatState
 
finish() - Method in class com.apple.foundationdb.record.cursors.aggregate.IntegerState
 
finish() - Method in class com.apple.foundationdb.record.cursors.aggregate.LongState
 
finish() - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.graph.MatchAccumulator
Compute and return a result based on the internal state of the instance.
finish() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Accumulator
 
finish() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue.SumAccumulator
 
finish() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.NumericAccumulator
 
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 first FDBRecordVersion that 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 first FDBRecordVersion that could be written at the given global version.
firstMissingRangeAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Return the first missing range in the set.
firstMissingRangeAsync(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Find the first missing range between begin and end.
firstOrDefault(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
firstOrDefaultPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
firstOrDefaultPlan(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
FirstOrDefaultValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value that returns the first element of the input array passed in.
FirstOrDefaultValue(Value, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
FirstOrDefaultValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
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.
fixed(Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Binding
 
FIXED - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
Fixed sort order which indicates that something restrict records to only ever be of exactly one value.
fixedBinding(Collection<Ordering.Binding>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
flatMap(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
flatMap(Iterable<T>, Function<? super T, ? extends Iterable<R>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.IterableHelpers
Flat-maps given function to the given iterable and returns a new iterable.
flatMapPipelined(Function<byte[], ? extends RecordCursor<T>>, BiFunction<T, byte[], ? extends RecordCursor<V>>, byte[], int) - Static method in interface com.apple.foundationdb.record.RecordCursor
Apply a given cursor generating function to each result from an outer cursor and chain the results together.
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
Apply a given cursor generating function to each result from an outer cursor and chain the results together.
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
 
flatMapPlan(BindingMatcher<? extends RecordQueryPlan>, BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
flatMapPlan(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
flatMapResult(BindingMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
flatten() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
Flattens the path into a list of KeySpacePath entries, 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 of ResolvedKeySpacePath entries, with the root of the path located at position 0.
flattenedResults(Value, Value) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
flipIfReverse(boolean) - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
 
FLOAT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
 
FLOAT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
FLOAT - Enum constant in enum com.apple.foundationdb.record.query.plan.planning.BindingFunction
 
floatAverageState() - Static method in class com.apple.foundationdb.record.cursors.aggregate.AverageAccumulatorState
 
FloatState - Class in com.apple.foundationdb.record.cursors.aggregate
Accumulator state for Float types.
FloatState(PrimitiveAccumulatorOperation) - Constructor for class com.apple.foundationdb.record.cursors.aggregate.FloatState
 
fold(TreeLike.NonnullFunction<T, M>, TreeLike.NonnullBiFunction<M, Iterable<? extends F>, F>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Method that performs a tree fold over the tree-like rooted at this using the given map and fold functions.
foldConstantRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.FoldingValueSimplificationRuleSet
 
FoldConstantRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that detects a value that evaluates to one constant value given the a set of aliases that are considered being bound to constant objects.
FoldConstantRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.FoldConstantRule
 
FoldingValueSimplificationRuleSet - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A set of rules for simplifying Value trees used to expression ordering constraints.
foldNullable(Function<T, M>, BiFunction<M, Iterable<? extends F>, F>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Method that performs a tree fold over the tree-like rooted at this using the given map and fold functions.
FOR_CONTINUATION - Enum constant in enum com.apple.foundationdb.record.PlanHashable.PlanHashKind
 
FOR_EXPLAIN - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
Indicates if this property is computed for the purpose of creating an explain of the execution plan.
forbidRecordScan() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
forBinding(String, Object) - Static method in class com.apple.foundationdb.record.EvaluationContext
Create a new EvaluationContext with a single binding.
forBindings(Bindings) - Static method in class com.apple.foundationdb.record.EvaluationContext
Create a new EvaluationContext around a given set of Bindings from parameter names to values.
forBindingsAndTypeRepository(Bindings, TypeRepository) - Static method in class com.apple.foundationdb.record.EvaluationContext
Create a new EvaluationContext around a given set of Bindings and a TypeRepository.
FORCE_BUILD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
Rebuild the index anyway, no matter if it is disabled or write-only or readable.
forceAllocate(String, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator
 
forcePut(Equivalence.Wrapper<K>, Equivalence.Wrapper<V>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
forcePutUnwrapped(K, V) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
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.
forComparisonKey(KeyExpression, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
 
forConfiguration(BooleanPredicateNormalizer.Mode, RecordQueryPlannerConfiguration) - Static method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer
Obtain a normalizer for the given planner configuration.
forConfiguration(RecordQueryPlannerConfiguration) - Static method in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
Obtain a normalizer for the given planner configuration.
forDebugging() - Static method in class com.apple.foundationdb.record.query.plan.explain.DefaultExplainFormatter
 
forDebugging() - Static method in class com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter
 
forEach(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Shorthand to create a for-each quantifier ranging over a reference.
forEach(Reference, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Shorthand to create a for-each quantifier ranging over a reference using a given alias.
forEach(BiConsumer<? super Equivalence.Wrapper<K>, ? super Equivalence.Wrapper<V>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
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.cascades.Quantifier
Create a builder for a for-each quantifier containing relational expressions.
ForEachBuilder() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach.ForEachBuilder
 
forEachMapping(BiConsumer<CorrelationIdentifier, CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Call an action for each mapping contained in this alias map.
forEachParentExpression(Reference, BiConsumer<Reference, RelationalExpression>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal
 
forEachQuantifier() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
forEachQuantifier(BindingMatcher<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
forEachQuantifier(CollectionMatcher<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
ForEachQuantifierEdge() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ForEachQuantifierEdge
 
ForEachQuantifierEdge(String, boolean, Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ForEachQuantifierEdge
 
ForEachQuantifierEdge(String, Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ForEachQuantifierEdge
 
ForEachQuantifierEdge(Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ForEachQuantifierEdge
 
forEachQuantifierOverPlans(CollectionMatcher<RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
forEachQuantifierOverRef(BindingMatcher<? extends Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
forEachQuantifiers(Iterable<Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
Create a list of for-each quantifiers from a list of references to range over.
forEachQuantifierWithDefaultOnEmpty() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
forEachQuantifierWithDefaultOnEmptyOverRef(BindingMatcher<? extends Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
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.
forEachUnwrapped(BiConsumer<? super K, ? super V>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
forEachWithNullOnEmpty(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Shorthand to create a for-each quantifier ranging over a reference using a given alias.
forEachWithNullOnEmpty(Reference, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Shorthand to create a for-each quantifier ranging over a reference using a given alias.
forExplain() - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
forFunctionalExpansion() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
forIndex(Index) - Method in class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
Construct a plan for generating synthetic records for a given index.
forIndexBuild(FDBRecordStore, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Create a range set for an index's build.
forInternalShow(boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
forInternalShow(boolean, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
forJavaEnum(Class<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
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 - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
formatLiteral(Type, String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
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
 
forQueries(List<Value>, Quantifier.ForEach, List<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
forRecordQuery(RecordQueryPlannerConfiguration, RecordMetaData, RecordStoreState, RecordQuery) - Static method in class com.apple.foundationdb.record.query.plan.cascades.MetaDataPlanContext
 
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
 
forRootReference(RecordQueryPlannerConfiguration, RecordMetaData, RecordStoreState, Reference, Optional<Collection<String>>, IndexQueryabilityFilter) - Static method in class com.apple.foundationdb.record.query.plan.cascades.MetaDataPlanContext
 
forScrubbingIndex(FDBRecordStore, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Create a range set for scrubbing the entries of an index.
forScrubbingRecords(FDBRecordStore, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Create a range set for scrubbing the records of an index.
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.
forType(UnnestedRecordType) - Method in class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
 
forTypeRepository(TypeRepository) - Static method in class com.apple.foundationdb.record.EvaluationContext
 
forUnnestedConstituent(UnnestedRecordType, UnnestedRecordType.NestedConstituent) - Method in class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
Construct a plan for generating synthetic records from the parent constituent of an unnested record type.
FORWARD_SCAN - Static variable in class com.apple.foundationdb.record.ScanProperties
 
FOUND_INDEX - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
FoundSplitWithoutStartException(long, boolean) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.SplitHelper.FoundSplitWithoutStartException
 
from(byte[], Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.query.plan.cascades.TempTable
Deserializes a byte buffer to a corresponding TempTable.
from(byte[], Function<PTempTable, TempTable>) - Static method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor.Continuation
Parses a continuation byte[], using a given TempTable deserializer, into a RecursiveUnionCursor.Continuation.
from(byte[], Function<PTempTable, TempTable>, Function<byte[], RecordCursor<QueryResult>>) - Static method in class com.apple.foundationdb.record.cursors.TempTableInsertCursor
Creates a new instance of TempTableInsertCursor.
from(InvertibleFunctionKeyExpression, Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
Create an inverted function comparison from an invertible function and a pre-existing comparison.
from(PTempTable, Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.query.plan.cascades.TempTable
Deserializes a PTempTable message to a corresponding TempTable.
from(StoreTimer) - Static method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot
Creates an immutable snapshot of a StoreTimer.
from(StoreTimer.Counter) - Static method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot.CounterSnapshot
Creates an immutable snapshot of a StoreTimer.Counter.
from(Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
from(Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
from(RelationalExpression...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
from(BindingMatcher<T>, T) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings
Build a new set of bindings containing a single binding from the given key to the given bindable.
from(Quantifier.ForEach) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach.ForEachBuilder
 
from(Quantifier.Physical, List<? extends InSource>, KeyExpression, int, Bindings.Internal) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
Construct a new in-union plan based on an existing physical quantifier.
from(Quantifier.Physical, List<? extends InSource>, List<OrderingPart.ProvidedOrderingPart>, boolean, int, Bindings.Internal) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
Construct a new in-union plan based on an existing physical quantifier.
from(ConstantObjectValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
Derives a OfTypeValue object from a given ConstantObjectValue.
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(RecordQueryPlan, List<? extends InSource>, KeyExpression, boolean, int, Bindings.Internal) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
Construct a new in-union plan.
from(ScanComparisons) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
from(RecordCursorProto.RecursiveCursorContinuation, Function<PTempTable, TempTable>) - Static method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor.Continuation
Creates a new RecursiveUnionCursor.Continuation instance from a serialized continuation protobuf message and a temporary table deserializer.
from(ByteString, Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.query.plan.cascades.TempTable
Deserializes a PTempTable message to a corresponding TempTable.
from(Descriptors.Descriptor, byte[]) - Static method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
 
from(Descriptors.Descriptor, PQueryResult) - Static method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
 
from(Descriptors.Descriptor, ByteString) - Static method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
 
from(Collection<? extends RelationalExpression>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
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<? extends Reference>, List<OrderingPart.ProvidedOrderingPart>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
Construct a new union of two or more compatibly-ordered plans.
from(List<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
 
from(List<? extends 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<? extends 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(List<? extends RecordQueryPlan>, KeyExpression, int) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
Factory method to create a new instance of the Comparator plan.
from(List<? extends RecordQueryPlan>, KeyExpression, int, boolean) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
Factory method to create a new instance of the Comparator plan.
from(List<? extends RecordQueryPlan>, PlanSelector) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySelectorPlan
Factory method that takes in a PlanSelector.
from(List<? extends RecordQueryPlan>, List<Integer>) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySelectorPlan
Factory method that takes in a list of relative probabilities and created a selection policy based on them.
from(List<QueryComponent>) - Static method in class com.apple.foundationdb.record.query.expressions.OrComponent
 
from(Q) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Builder
 
fromAliasMap(AliasMap) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence
 
fromBindingMatcher(BindingMatcher<Collection<E>>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.CollectionMatcher
 
fromBoolean(boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
Helper method to dispatch to BooleanWithConstraint.falseValue() or BooleanWithConstraint.alwaysTrue() based on a boolean value handed in.
fromBytes(byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Create a FDBRecordVersion from the given serialized bytes.
fromBytes(byte[], boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Create a FDBRecordVersion from the given serialized bytes.
fromCode(Object) - Static method in enum com.apple.foundationdb.record.IndexState
 
fromCoercionBiFunctionProto(PlanSerializationContext, PCoercionBiFunction) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.CoercionBiFunction
 
fromComparison(Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.metadata.IndexComparison
Returns an equivalent IndexComparison object from a Comparisons.Comparison.
fromComparisonKeyFunctionProto(PlanSerializationContext, PComparisonKeyFunction) - Static method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction
 
fromComparisonProto(PlanSerializationContext, PComparison) - Static method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
fromCopierProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PCopier) - Static method in interface com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Copier
 
fromCopyIfPredicateProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PCopyIfPredicate) - Static method in interface com.apple.foundationdb.record.query.plan.AvailableFields.CopyIfPredicate
 
fromDescriptor(Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Translates a protobuf Descriptors.Descriptor to a corresponding Type.Record object.
fromDescriptor(Descriptors.FieldDescriptor) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
Convert a field descriptor into a expression.
fromDirection(TupleOrdering.Direction) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
 
fromDirection(TupleOrdering.Direction) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
 
fromDirection(TupleOrdering.Direction) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
 
fromDirectionProto(PDirection) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.OrderedBytesHelpers
 
fromExpressions(Iterable<? extends Reference>, Function<Reference, Q>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
Create a list of quantifiers given a list of references these quantifiers should range over.
fromFieldDescriptorsMap(boolean, Map<String, Descriptors.FieldDescriptor>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Creates a new Type.Record type instance using the given map of field names to their protobuf Descriptors.FieldDescriptors.
fromFieldDescriptorsMap(Map<String, Descriptors.FieldDescriptor>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Creates a new nullable Type.Record type instance using the given map of field names to their protobuf Descriptors.FieldDescriptors.
fromFields(boolean, List<Type.Record.Field>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Creates a new Type.Record type instance using the given list of Type.Record.Fields.
fromFields(List<Type.Record.Field>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Creates a new nullable Type.Record type instance using the given list of Type.Record.Fields.
fromFieldsWithName(String, boolean, List<Type.Record.Field>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
fromFilter(QueryComponent, BiPredicate<ComponentWithComparison, String>) - Static method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
 
fromFuture(CompletableFuture<Void>) - Static method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext.CommitCheckAsync
Create a commit check based on the given future.
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.
fromFuture(Executor, Supplier<CompletableFuture<T>>, byte[]) - Static method in interface com.apple.foundationdb.record.RecordCursor
Get a new cursor that has the contents of the lazily-evaluated future as its only record.
fromIndex(RecordType, Index, PlannableIndexTypes, KeyExpression, RecordQueryPlanWithIndex) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields
 
fromIndexDefinition(RecordMetaData, Index, boolean) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
fromIndexScanParametersProto(PlanSerializationContext, PIndexScanParameters) - Static method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScanParameters
 
fromInequalities(Iterable<Comparisons.Comparison>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
fromInSourceProto(PlanSerializationContext, PInSource) - Static method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
fromInt(int) - Static method in class com.apple.foundationdb.record.ByteArrayContinuation
Return a RecordCursorContinuation that wraps a byte array consisting of the given integer.
fromIsReverse(boolean) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
 
fromIsReverse(boolean) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
 
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 ordinary Iterator.
fromKey(Object) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
 
fromKeyExpressions(Collection<? extends KeyExpression>, CorrelationIdentifier, Type) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
fromKeyExpressions(Collection<? extends KeyExpression>, Quantifier) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
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 ordinary List.
fromList(List<T>, byte[]) - Static method in interface com.apple.foundationdb.record.RecordCursor
Get a new cursor from an ordinary List, skipping ahead according to the given continuation.
fromNodeAndChildGraphs(PlannerGraph.Node, List<? extends PlannerGraph>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph
 
fromNodeAndChildGraphs(PlannerGraph.Node, List<? extends PlannerGraph>, List<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph
 
fromNodeInnerAndTargetForModifications(PlannerGraph.Node, PlannerGraph, PlannerGraph) - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph
 
fromNullable(byte[]) - Static method in class com.apple.foundationdb.record.ByteArrayContinuation
Return a RecordCursorContinuation from a byte array.
fromObject(Object) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Returns an equivalent Type of a given Java object's type.
FromOrderedBytesAscNullsFirstFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue.FromOrderedBytesAscNullsFirstFn
 
FromOrderedBytesAscNullsLastFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue.FromOrderedBytesAscNullsLastFn
 
FromOrderedBytesDescNullsFirstFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue.FromOrderedBytesDescNullsFirstFn
 
FromOrderedBytesDescNullsLastFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue.FromOrderedBytesDescNullsLastFn
 
FromOrderedBytesValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value that produces a binary encoding that is comparable according to certain modes gives by TupleOrdering.Direction.
FromOrderedBytesValue(Value, TupleOrdering.Direction, Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
Constructs a new FromOrderedBytesValue instance.
FromOrderedBytesValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
FromOrderedBytesValue.FromOrderedBytesAscNullsFirstFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The FROM_ORDERED_BYTES_ASC_NULLS_FIRST function.
FromOrderedBytesValue.FromOrderedBytesAscNullsLastFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The FROM_ORDERED_BYTES_ASC_NULLS_LAST function.
FromOrderedBytesValue.FromOrderedBytesDescNullsFirstFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The FROM_ORDERED_BYTES_DESC_NULLS_FIRST function.
FromOrderedBytesValue.FromOrderedBytesDescNullsLastFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The FROM_ORDERED_BYTES_DESC_NULLS_LAST function.
fromPath(List<String>) - Static method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
Constructs a KeyExpression from a path.
fromPlan(RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
fromPlan(RecordMetaData, RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
fromPlanReferenceProto(PPlanReference) - Method in class com.apple.foundationdb.record.PlanSerializationContext
 
fromPlans(Iterable<? extends Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
Create a list of physical quantifiers given a list of references these quantifiers should range over.
fromPrimaryDefinition(RecordMetaData, Set<String>, KeyExpression, boolean) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
fromProto(PlanSerializationContext, PAndOrValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue.Deserializer
 
fromProto(PlanSerializationContext, PAndOrValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
fromProto(PlanSerializationContext, PAndPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate.Deserializer
 
fromProto(PlanSerializationContext, PAndPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
fromProto(PlanSerializationContext, PArithmeticValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.Deserializer
 
fromProto(PlanSerializationContext, PArithmeticValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
fromProto(PlanSerializationContext, PArithmeticValue.PPhysicalOperator) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
fromProto(PlanSerializationContext, PArrayCoercionBiFunction) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.ArrayCoercionBiFunction.Deserializer
 
fromProto(PlanSerializationContext, PArrayCoercionBiFunction) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.ArrayCoercionBiFunction
 
fromProto(PlanSerializationContext, PBinaryRelOpValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.BinaryRelOpValue.Deserializer
 
fromProto(PlanSerializationContext, PBinaryRelOpValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.BinaryRelOpValue
 
fromProto(PlanSerializationContext, PCoercionTrieNode) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.CoercionTrieNode
 
fromProto(PlanSerializationContext, PCollateValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue.Deserializer
 
fromProto(PlanSerializationContext, PCollateValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
fromProto(PlanSerializationContext, PComparison.PComparisonType) - Static method in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
fromProto(PlanSerializationContext, PComparisonKeyFunction.POnKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression.Deserializer
 
fromProto(PlanSerializationContext, PComparisonKeyFunction.POnKeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression
 
fromProto(PlanSerializationContext, PComparisonKeyFunction.POnValues) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues.Deserializer
 
fromProto(PlanSerializationContext, PComparisonKeyFunction.POnValues) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues
 
fromProto(PlanSerializationContext, PCompatibleTypeEvolutionPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.Deserializer
 
fromProto(PlanSerializationContext, PCompatibleTypeEvolutionPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
fromProto(PlanSerializationContext, PCompilableRange) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.CompilableRange
 
fromProto(PlanSerializationContext, PConditionSelectorValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue.Deserializer
 
fromProto(PlanSerializationContext, PConditionSelectorValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
fromProto(PlanSerializationContext, PConstantObjectValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue.Deserializer
 
fromProto(PlanSerializationContext, PConstantObjectValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
fromProto(PlanSerializationContext, PConstantPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate.Deserializer
 
fromProto(PlanSerializationContext, PConstantPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
fromProto(PlanSerializationContext, PConstantValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue.Deserializer
 
fromProto(PlanSerializationContext, PConstantValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
fromProto(PlanSerializationContext, PCountValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue.Deserializer
 
fromProto(PlanSerializationContext, PCountValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
fromProto(PlanSerializationContext, PCountValue.PPhysicalOperator) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
 
fromProto(PlanSerializationContext, PDatabaseObjectDependenciesPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate.Deserializer
 
fromProto(PlanSerializationContext, PDatabaseObjectDependenciesPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
fromProto(PlanSerializationContext, PDatabaseObjectDependenciesPredicate.PUsedIndex) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate.UsedIndex
 
fromProto(PlanSerializationContext, PDerivedValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue.Deserializer
 
fromProto(PlanSerializationContext, PDerivedValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
fromProto(PlanSerializationContext, PEmptyValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue.Deserializer
 
fromProto(PlanSerializationContext, PEmptyValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
fromProto(PlanSerializationContext, PExistsPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate.Deserializer
 
fromProto(PlanSerializationContext, PExistsPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
fromProto(PlanSerializationContext, PExistsValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue.Deserializer
 
fromProto(PlanSerializationContext, PExistsValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
fromProto(PlanSerializationContext, PFetchIndexRecords) - Static method in enum com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords
 
fromProto(PlanSerializationContext, PFieldAccessTrieNode) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.FieldAccessTrieNode
 
fromProto(PlanSerializationContext, PFieldPath) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
fromProto(PlanSerializationContext, PFieldPath.PResolvedAccessor) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
fromProto(PlanSerializationContext, PFieldValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.Deserializer
 
fromProto(PlanSerializationContext, PFieldValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
fromProto(PlanSerializationContext, PFirstOrDefaultValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue.Deserializer
 
fromProto(PlanSerializationContext, PFirstOrDefaultValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
fromProto(PlanSerializationContext, PFromOrderedBytesValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue.Deserializer
 
fromProto(PlanSerializationContext, PFromOrderedBytesValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
fromProto(PlanSerializationContext, PInComparandSource) - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource.Deserializer
 
fromProto(PlanSerializationContext, PInComparandSource) - Static method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
fromProto(PlanSerializationContext, PIndexAggregateFunction) - Static method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
 
fromProto(PlanSerializationContext, PIndexedValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue.Deserializer
 
fromProto(PlanSerializationContext, PIndexedValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
fromProto(PlanSerializationContext, PIndexEntryObjectValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue.Deserializer
 
fromProto(PlanSerializationContext, PIndexEntryObjectValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
fromProto(PlanSerializationContext, PIndexFetchMethod) - Static method in enum com.apple.foundationdb.record.IndexFetchMethod
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord) - Static method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PCopyIfPredicate.PConditionalUponPathPredicate) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.ConditionalUponPathPredicate.Deserializer
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PCopyIfPredicate.PConditionalUponPathPredicate) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields.ConditionalUponPathPredicate
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PCopyIfPredicate.PTruePredicate) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.TruePredicate.Deserializer
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PCopyIfPredicate.PTruePredicate) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields.TruePredicate
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PFieldCopier) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier.Deserializer
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PFieldCopier) - Static method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PFieldWithValueCopier) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldWithValueCopier.Deserializer
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PFieldWithValueCopier) - Static method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldWithValueCopier
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PMessageCopier) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.MessageCopier.Deserializer
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PMessageCopier) - Static method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.MessageCopier
 
fromProto(PlanSerializationContext, PIndexKeyValueToPartialRecord.PTupleSource) - Static method in enum com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.TupleSource
 
fromProto(PlanSerializationContext, PIndexScanComparisons) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons.Deserializer
 
fromProto(PlanSerializationContext, PIndexScanComparisons) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
fromProto(PlanSerializationContext, PIndexScanType) - Static method in class com.apple.foundationdb.record.IndexScanType
 
fromProto(PlanSerializationContext, PInOpValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue.Deserializer
 
fromProto(PlanSerializationContext, PInOpValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
fromProto(PlanSerializationContext, PInParameterSource) - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource.Deserializer
 
fromProto(PlanSerializationContext, PInParameterSource) - Static method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
fromProto(PlanSerializationContext, PInValuesSource) - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource.Deserializer
 
fromProto(PlanSerializationContext, PInValuesSource) - Static method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
fromProto(PlanSerializationContext, PInvertedFunctionComparison) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison.Deserializer
 
fromProto(PlanSerializationContext, PInvertedFunctionComparison) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
 
fromProto(PlanSerializationContext, PLightArrayConstructorValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue.Deserializer
 
fromProto(PlanSerializationContext, PLightArrayConstructorValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue
 
fromProto(PlanSerializationContext, PLikeOperatorValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue.Deserializer
 
fromProto(PlanSerializationContext, PLikeOperatorValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
fromProto(PlanSerializationContext, PListComparison) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison.Deserializer
 
fromProto(PlanSerializationContext, PListComparison) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
 
fromProto(PlanSerializationContext, PLiteralValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue.Deserializer
 
fromProto(PlanSerializationContext, PLiteralValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
fromProto(PlanSerializationContext, PMaxEverValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MaxEverValue.Deserializer
 
fromProto(PlanSerializationContext, PMaxEverValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MaxEverValue
 
fromProto(PlanSerializationContext, PMinEverValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MinEverValue.Deserializer
 
fromProto(PlanSerializationContext, PMinEverValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MinEverValue
 
fromProto(PlanSerializationContext, PMultiColumnComparison) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison.Deserializer
 
fromProto(PlanSerializationContext, PMultiColumnComparison) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
fromProto(PlanSerializationContext, PMultidimensionalIndexScanComparisons) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons.Deserializer
 
fromProto(PlanSerializationContext, PMultidimensionalIndexScanComparisons) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
fromProto(PlanSerializationContext, PNotPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate.Deserializer
 
fromProto(PlanSerializationContext, PNotPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
fromProto(PlanSerializationContext, PNotValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue.Deserializer
 
fromProto(PlanSerializationContext, PNotValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
fromProto(PlanSerializationContext, PNullComparison) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison.Deserializer
 
fromProto(PlanSerializationContext, PNullComparison) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
 
fromProto(PlanSerializationContext, PNullValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue.Deserializer
 
fromProto(PlanSerializationContext, PNullValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
fromProto(PlanSerializationContext, PNumericAggregationValue.PAvg) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Avg.Deserializer
 
fromProto(PlanSerializationContext, PNumericAggregationValue.PAvg) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Avg
 
fromProto(PlanSerializationContext, PNumericAggregationValue.PBitmapConstructAgg) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.BitmapConstructAgg.Deserializer
 
fromProto(PlanSerializationContext, PNumericAggregationValue.PBitmapConstructAgg) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.BitmapConstructAgg
 
fromProto(PlanSerializationContext, PNumericAggregationValue.PMax) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Max.Deserializer
 
fromProto(PlanSerializationContext, PNumericAggregationValue.PMax) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Max
 
fromProto(PlanSerializationContext, PNumericAggregationValue.PMin) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Min.Deserializer
 
fromProto(PlanSerializationContext, PNumericAggregationValue.PMin) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Min
 
fromProto(PlanSerializationContext, PNumericAggregationValue.PPhysicalOperator) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
fromProto(PlanSerializationContext, PNumericAggregationValue.PSum) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Sum.Deserializer
 
fromProto(PlanSerializationContext, PNumericAggregationValue.PSum) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Sum
 
fromProto(PlanSerializationContext, PObjectValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue.Deserializer
 
fromProto(PlanSerializationContext, PObjectValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
fromProto(PlanSerializationContext, POfTypeValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue.Deserializer
 
fromProto(PlanSerializationContext, POfTypeValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
fromProto(PlanSerializationContext, POpaqueEqualityComparison) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison.Deserializer
 
fromProto(PlanSerializationContext, POpaqueEqualityComparison) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison
 
fromProto(PlanSerializationContext, POrPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate.Deserializer
 
fromProto(PlanSerializationContext, POrPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
fromProto(PlanSerializationContext, PParameterComparison) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison.Deserializer
 
fromProto(PlanSerializationContext, PParameterComparison) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
 
fromProto(PlanSerializationContext, PParameterComparison.PBindingKind) - Static method in enum com.apple.foundationdb.record.Bindings.Internal
 
fromProto(PlanSerializationContext, PPatternForLikeValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue.Deserializer
 
fromProto(PlanSerializationContext, PPatternForLikeValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
fromProto(PlanSerializationContext, PPhysicalQuantifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
fromProto(PlanSerializationContext, PPickValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue.Deserializer
 
fromProto(PlanSerializationContext, PPickValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
fromProto(PlanSerializationContext, PPredicateWithValueAndRanges) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges.Deserializer
 
fromProto(PlanSerializationContext, PPredicateWithValueAndRanges) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
fromProto(PlanSerializationContext, PPrimitiveCoercionBiFunction) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.PrimitiveCoercionBiFunction.Deserializer
 
fromProto(PlanSerializationContext, PPrimitiveCoercionBiFunction) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.PrimitiveCoercionBiFunction
 
fromProto(PlanSerializationContext, PPromoteValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.Deserializer
 
fromProto(PlanSerializationContext, PPromoteValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
fromProto(PlanSerializationContext, PQuantifiedObjectValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue.Deserializer
 
fromProto(PlanSerializationContext, PQuantifiedObjectValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
fromProto(PlanSerializationContext, PQuantifiedRecordValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue.Deserializer
 
fromProto(PlanSerializationContext, PQuantifiedRecordValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
fromProto(PlanSerializationContext, PQueriedValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue.Deserializer
 
fromProto(PlanSerializationContext, PQueriedValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
fromProto(PlanSerializationContext, PQueryPlanConstraint) - Static method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
fromProto(PlanSerializationContext, PRangeConstraints) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
fromProto(PlanSerializationContext, PRankValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RankValue.Deserializer
 
fromProto(PlanSerializationContext, PRankValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.RankValue
 
fromProto(PlanSerializationContext, PRecordConstructorValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue.Deserializer
 
fromProto(PlanSerializationContext, PRecordConstructorValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
fromProto(PlanSerializationContext, PRecordConstructorValue.PColumn) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Column
 
fromProto(PlanSerializationContext, PRecordQueryAggregateIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryAggregateIndexPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
fromProto(PlanSerializationContext, PRecordQueryCoveringIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryCoveringIndexPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
fromProto(PlanSerializationContext, PRecordQueryDamPlan) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryDamPlan) - Static method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
fromProto(PlanSerializationContext, PRecordQueryDefaultOnEmptyPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryDefaultOnEmptyPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
fromProto(PlanSerializationContext, PRecordQueryDeletePlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryDeletePlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
fromProto(PlanSerializationContext, PRecordQueryExplodePlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryExplodePlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
fromProto(PlanSerializationContext, PRecordQueryFetchFromPartialRecordPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryFetchFromPartialRecordPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
fromProto(PlanSerializationContext, PRecordQueryFirstOrDefaultPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryFirstOrDefaultPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
fromProto(PlanSerializationContext, PRecordQueryFlatMapPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryFlatMapPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
fromProto(PlanSerializationContext, PRecordQueryInComparandJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryInComparandJoinPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
fromProto(PlanSerializationContext, PRecordQueryIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryIndexPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
fromProto(PlanSerializationContext, PRecordQueryInParameterJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryInParameterJoinPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
 
fromProto(PlanSerializationContext, PRecordQueryInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryInsertPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan
 
fromProto(PlanSerializationContext, PRecordQueryIntersectionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryIntersectionOnKeyExpressionPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan
 
fromProto(PlanSerializationContext, PRecordQueryIntersectionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryIntersectionOnValuesPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
fromProto(PlanSerializationContext, PRecordQueryInUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryInUnionOnKeyExpressionPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan
 
fromProto(PlanSerializationContext, PRecordQueryInUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryInUnionOnValuesPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
fromProto(PlanSerializationContext, PRecordQueryInValuesJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryInValuesJoinPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
 
fromProto(PlanSerializationContext, PRecordQueryMapPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryMapPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
fromProto(PlanSerializationContext, PRecordQueryPredicatesFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryPredicatesFilterPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
fromProto(PlanSerializationContext, PRecordQueryRangePlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryRangePlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
fromProto(PlanSerializationContext, PRecordQueryScanPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryScanPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
fromProto(PlanSerializationContext, PRecordQueryScoreForRankPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryScoreForRankPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
 
fromProto(PlanSerializationContext, PRecordQuerySortKey) - Static method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortKey
 
fromProto(PlanSerializationContext, PRecordQuerySortPlan) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQuerySortPlan) - Static method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
fromProto(PlanSerializationContext, PRecordQueryStreamingAggregationPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryStreamingAggregationPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
fromProto(PlanSerializationContext, PRecordQueryTypeFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryTypeFilterPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
fromProto(PlanSerializationContext, PRecordQueryUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryUnionOnKeyExpressionPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan
 
fromProto(PlanSerializationContext, PRecordQueryUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryUnionOnValuesPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
fromProto(PlanSerializationContext, PRecordQueryUnorderedDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryUnorderedDistinctPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
 
fromProto(PlanSerializationContext, PRecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryUnorderedPrimaryKeyDistinctPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
 
fromProto(PlanSerializationContext, PRecordQueryUnorderedUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryUnorderedUnionPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
 
fromProto(PlanSerializationContext, PRecordQueryUpdatePlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan.Deserializer
 
fromProto(PlanSerializationContext, PRecordQueryUpdatePlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
 
fromProto(PlanSerializationContext, PRecordTypeComparison) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison.Deserializer
 
fromProto(PlanSerializationContext, PRecordTypeComparison) - Static method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
fromProto(PlanSerializationContext, PRecordTypeValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue.Deserializer
 
fromProto(PlanSerializationContext, PRecordTypeValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
fromProto(PlanSerializationContext, PRecursiveUnionQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan.Deserializer
 
fromProto(PlanSerializationContext, PRecursiveUnionQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
fromProto(PlanSerializationContext, PScanComparisons) - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
fromProto(PlanSerializationContext, PScoreForRank) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.ScoreForRank
 
fromProto(PlanSerializationContext, PScoreForRank.PBindingFunction) - Static method in enum com.apple.foundationdb.record.query.plan.planning.BindingFunction
 
fromProto(PlanSerializationContext, PSimpleComparison) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison.Deserializer
 
fromProto(PlanSerializationContext, PSimpleComparison) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
 
fromProto(PlanSerializationContext, PSortedInComparandSource) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource.Deserializer
 
fromProto(PlanSerializationContext, PSortedInComparandSource) - Static method in class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource
 
fromProto(PlanSerializationContext, PSortedInParameterSource) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource.Deserializer
 
fromProto(PlanSerializationContext, PSortedInParameterSource) - Static method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
fromProto(PlanSerializationContext, PSortedInValuesSource) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource.Deserializer
 
fromProto(PlanSerializationContext, PSortedInValuesSource) - Static method in class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource
 
fromProto(PlanSerializationContext, PTempTableInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan.Deserializer
 
fromProto(PlanSerializationContext, PTempTableInsertPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
fromProto(PlanSerializationContext, PTempTableScanPlan) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan.Deserializer
 
fromProto(PlanSerializationContext, PTempTableScanPlan) - Static method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
fromProto(PlanSerializationContext, PThrowsValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue.Deserializer
 
fromProto(PlanSerializationContext, PThrowsValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
fromProto(PlanSerializationContext, PTimeWindowForFunction) - Static method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
 
fromProto(PlanSerializationContext, PTimeWindowScanComparisons) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons.Deserializer
 
fromProto(PlanSerializationContext, PTimeWindowScanComparisons) - Static method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons
 
fromProto(PlanSerializationContext, PToOrderedBytesValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue.Deserializer
 
fromProto(PlanSerializationContext, PToOrderedBytesValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
fromProto(PlanSerializationContext, PTransformationTrieNode) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.TransformationTrieNode
 
fromProto(PlanSerializationContext, PType.PAnyRecordType) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord.Deserializer
 
fromProto(PlanSerializationContext, PType.PAnyRecordType) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
 
fromProto(PlanSerializationContext, PType.PAnyType) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any.Deserializer
 
fromProto(PlanSerializationContext, PType.PAnyType) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
 
fromProto(PlanSerializationContext, PType.PArrayType) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array.Deserializer
 
fromProto(PlanSerializationContext, PType.PArrayType) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
 
fromProto(PlanSerializationContext, PType.PEnumType) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum.Deserializer
 
fromProto(PlanSerializationContext, PType.PEnumType) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
fromProto(PlanSerializationContext, PType.PEnumType.PEnumValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum.EnumValue
 
fromProto(PlanSerializationContext, PType.PNoneType) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None.Deserializer
 
fromProto(PlanSerializationContext, PType.PNoneType) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
fromProto(PlanSerializationContext, PType.PNullType) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null.Deserializer
 
fromProto(PlanSerializationContext, PType.PNullType) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
fromProto(PlanSerializationContext, PType.PPrimitiveType) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive.Deserializer
 
fromProto(PlanSerializationContext, PType.PPrimitiveType) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive
 
fromProto(PlanSerializationContext, PType.PRecordType) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Deserializer
 
fromProto(PlanSerializationContext, PType.PRecordType) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
fromProto(PlanSerializationContext, PType.PRecordType.PField) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
 
fromProto(PlanSerializationContext, PType.PRelationType) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation.Deserializer
 
fromProto(PlanSerializationContext, PType.PRelationType) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
 
fromProto(PlanSerializationContext, PType.PTypeCode) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
fromProto(PlanSerializationContext, PUnaryRelOpValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.UnaryRelOpValue.Deserializer
 
fromProto(PlanSerializationContext, PUnaryRelOpValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.UnaryRelOpValue
 
fromProto(PlanSerializationContext, PValueComparison) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison.Deserializer
 
fromProto(PlanSerializationContext, PValueComparison) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
fromProto(PlanSerializationContext, PValuePredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate.Deserializer
 
fromProto(PlanSerializationContext, PValuePredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
fromProto(PlanSerializationContext, PVariadicFunctionValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.Deserializer
 
fromProto(PlanSerializationContext, PVariadicFunctionValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
fromProto(PlanSerializationContext, PVariadicFunctionValue.PPhysicalOperator) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
fromProto(PlanSerializationContext, PVersionValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue.Deserializer
 
fromProto(PlanSerializationContext, PVersionValue) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
fromProto(PlanSerializationContext, M) - Method in interface com.apple.foundationdb.record.PlanDeserializer
Dispatch method to transform from M to T.
fromProto(RecordMetaDataProto.Comparison) - Static method in class com.apple.foundationdb.record.metadata.IndexComparison
Parses a RecordMetaDataProto.Comparison message into a corresponding IndexComparison object.
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.Predicate) - Static method in class com.apple.foundationdb.record.metadata.IndexPredicate
Parses a proto message into a corresponding predicate.
fromProto(RecordMetaDataProto.Value) - Static method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
 
fromProto(RecordPlannerConfigurationProto.PlannerConfiguration) - Static method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Deserialize a configuration object from its protobuf representation.
fromProto(RecordPlannerConfigurationProto.PlannerConfiguration.SortConfiguration) - Static method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryPlannerSortConfiguration
 
fromProto(TupleFieldsProto.NullableBool) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Protobuf NullableBool to a Java boolean.
fromProto(TupleFieldsProto.NullableBytes) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Protobuf NullableBytes to a Java ByteString.
fromProto(TupleFieldsProto.NullableDouble) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Protobuf NullableDouble to a Java double.
fromProto(TupleFieldsProto.NullableFloat) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Protobuf NullableFloat to a Java float.
fromProto(TupleFieldsProto.NullableInt32) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Protobuf NullableInt32 to a Java int.
fromProto(TupleFieldsProto.NullableInt64) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Protobuf NullableInt64 to a Java long.
fromProto(TupleFieldsProto.NullableString) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Protobuf NullableString to a Java String.
fromProto(TupleFieldsProto.UUID) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Protobuf UUID to a Java UUID.
fromProto(Message, Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a field's value from a message to a Tuple item.
fromProtobufType(Descriptors.FieldDescriptor.Type) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
Generates a Type.TypeCode that corresponds to the given protobuf DescriptorProtos.FieldDescriptorProto.Type.
fromProtoValue(RecordMetaDataProto.Value) - Static method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
 
fromQuantifiers(List<Quantifier.Physical>) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
 
fromQuantifiers(List<Quantifier.Physical>, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
fromQuantifiers(List<Quantifier.Physical>, KeyExpression, boolean) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
 
fromQuantifiers(List<Quantifier.Physical>, List<OrderingPart.ProvidedOrderingPart>, boolean) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
fromQuantifiers(List<Quantifier.Physical>, List<OrderingPart.ProvidedOrderingPart>, boolean, boolean) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
 
fromQueriedRecord(FDBQueriedRecord<?>) - Static method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
Create a new queriedRecord with the given element.
fromQueryPredicate(QueryPredicate) - Static method in class com.apple.foundationdb.record.metadata.IndexPredicate
Parses a QueryPredicate into an equivalent IndexPredicate.
fromQueryPredicateProto(PlanSerializationContext, PQueryPredicate) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
fromRecordQuery(RecordMetaData, RecordQuery) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
fromRecordQueryAndBindings(RecordQuery, Bindings) - Static method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph
Derive a relationship graph from a RecordQuery and a set of pre-bound parameters in handing in as a Bindings object.
fromRecordQueryPlanProto(PlanSerializationContext, PRecordQueryPlan) - Static method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
 
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 a Tuple and create the corresponding key from it.
fromTyped(List<? extends Typed>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Maps a List of Typed instances to a List of their Types.
fromTypeProto(PlanSerializationContext, PType) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
fromValueProto(PlanSerializationContext, PValue) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
fromVersionNumber(int) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.APIVersion
Get the APIVersion enum from the version number.
fromVersionstamp(Versionstamp) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Create a FDBRecordVersion from the given Versionstamp instance.
fromVersionstamp(Versionstamp, boolean) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Create a FDBRecordVersion from the given Versionstamp instance.
fullKey(Index, KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexExpansionVisitor
Compute the full key of an index (given that the index is a value index).
fullUnorderedScanExpression() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
FullUnorderedScanExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A planner expression representing a full, unordered scan of the records by primary key, which is the logical version of a RecordQueryScanPlan with ScanComparisons.EMPTY.
FullUnorderedScanExpression(Set<String>, Type, AccessHints) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
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 - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
FUNCTION_NAME - Static variable in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpressionFactoryJRE
 
FUNCTION_NAME_PREFIX - Static variable in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpressionFactory
 
FUNCTION_UNDEFINED_FOR_GIVEN_ARGUMENT_TYPES - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
FunctionCatalog - Class in com.apple.foundationdb.record.query.plan.cascades.values
A catalog of functions that provides BuiltInFunctions.
FunctionKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
A FunctionKeyExpression is a KeyExpression that is dynamically loaded and defined by a String name and a Key.Expression that 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 a Builder that can construct a KeyExpressionFunction via a provided generator.
FunctionKeyExpression.Builder - Class in com.apple.foundationdb.record.metadata.expressions
A builder is capable of producing an instance of a FunctionKeyExpression given the arguments to the function.
FunctionKeyExpression.Factory - Interface in com.apple.foundationdb.record.metadata.expressions
Implementations of FunctionKeyExpression.Factory are dynamically located by the FunctionKeyExpression.Registry and 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
The Registry maintains a mapping from a function name to a Builder capable 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 - Enum constant in enum 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
Internal constructor.

G

generateFilename() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
generateFilename() - Method in interface com.apple.foundationdb.record.sorting.FileSortAdapter
Get the name of a file to use for saving sorted records.
generateKey(FDBQueriedRecord<M>) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
generateKey(V) - Method in interface com.apple.foundationdb.record.sorting.MemorySortAdapter
Generate a sorting key for the given value.
genericMatcher(AliasMap, Collection<? extends Quantifier>, Collection<? extends Quantifier>, MatchFunction<Quantifier, M>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
Method to create a matcher between the given set of quantifiers and the given set of other quantifiers using an alias map and a matchFunction.
GenericMatcher<R> - Interface in com.apple.foundationdb.record.query.plan.cascades.matching.graph
Tag interface for generic matchers, that is instances of ComputingMatcher.
get() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext.PostCommit
 
get() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Return the expression contained in this reference.
get() - Method in class com.apple.foundationdb.record.RecordCursorResult
Return the value of this result.
get(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
get(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
get(FDBRecordContext, ScopedValue<Long>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
 
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(BindingMatcher<T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings
Retrieve the single bindable bound to key.
get(BindingMatcher<U>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.PlannerRuleCall
Return the bindable that is bound to the given key.
get(QueryPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap
 
get(QueryPlanInfo.QueryPlanInfoKey<T>) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo.Builder
 
get(QueryPlanInfo.QueryPlanInfoKey<T>) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo
Retrieve a value from the info table.
get(Class<? extends T>) - Method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
Retrieve the wrapped result by attempting it to cast it to the given class.
get(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
get(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentityMap
 
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 that asyncToSync() 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 that asyncToSync() 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken getting cached meta-data from a MetaDataCache.
GET_META_DATA_CACHE_VERSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken getting the current version from a MetaDataCache.
GET_READ_VERSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBLatencySource
GET_READ_VERSION - Enum constant in enum 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 - Enum constant in enum 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 - Enum constant in enum 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 - Enum constant in enum 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.
getAccessHints() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
getAccessHintSet() - Method in class com.apple.foundationdb.record.query.plan.cascades.AccessHints
 
getAccessHintType() - Method in interface com.apple.foundationdb.record.query.plan.cascades.AccessHint
Gets the type of the access hint.
getAccessHintType() - Method in class com.apple.foundationdb.record.query.plan.cascades.IndexAccessHint
 
getAccessHintType() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryAccessHint
 
getAccumulatedPredicateMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getActiveStateContinuation() - Method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor.Continuation
 
getActiveStateCursor() - Method in interface com.apple.foundationdb.record.cursors.RecursiveUnionCursor.RecursiveStateManager
Retrieve the currently active cursor, an active cursor is either the initial cursor or the recursive cursor.
getAdapter() - Method in class com.apple.foundationdb.record.sorting.MemoryScratchpad
 
getAdapter(FDBRecordStoreBase<M>, int) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortKey
Get a sort adapter used for a single invocation of a plan using this key.
getAdapterForDam(FDBRecordStoreBase<M>) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortKey
Get an adapter used for a single invocation of a plan using this key.
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.
getAdditionalCondition() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
 
getAdditionalErrorMessage() - Method in exception com.apple.foundationdb.record.query.plan.cascades.SemanticException
 
getAdditionalPlanConstraint() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
getAggregateAlias() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
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
 
getAggregateValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
getAggregateValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
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.expressions.Comparisons.ParameterComparisonBase
 
getAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
getAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
getAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
getAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
getAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
getAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
getAlias() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedValue
 
getAlias() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.AliasDefinitionToken
 
getAlias() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.AliasReferenceToken
 
getAlias() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.CurrentAliasDefinitionToken
 
getAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
 
getAliasMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BoundMatch
 
getAliasMapMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap
 
getAliasToElementMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
 
getAliasToQuantifierMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
getAll(BindingMatcher<T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings
Retrieve all objects bound to key if 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 from Index to IndexState for 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
 
getAllRecordTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
getAllRules() - Method in class com.apple.foundationdb.record.query.plan.cascades.PlannerRuleSet
 
getAndResetMergeRequiredIndexes() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingThrottle
 
getAnyValue() - Method in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
 
getAPartlyBuiltExceptionIfApplicable(Throwable) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
getAPIVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
Get the FDB API version that this database was created with.
getAPIVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Get the configured FDB API version.
getAPIVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
getAPIVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
Get the FDB API version associated with this transaction.
getApproximateSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getApproximateSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
getApproximateTransactionSize() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
 
getArgType() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
getArgument() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateComputationRuleCall
 
getArgument() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRuleCall
 
getArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
 
getArgumentValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
getArrowHead() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Edge
 
getArrowHead() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ExistentialQuantifierEdge
 
getArrowHead() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationTargetEdge
 
getArrowIndicator() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
 
getArrowIndicator() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
 
getArrowIndicator() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
 
getArrowIndicator() - Method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
Arrow indicator for pretty-printing the sort order.
getArrowTail() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Edge
 
getArrowTail() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationTargetEdge
 
getAsPlan() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Return the RecordQueryPlan contained in this reference.
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
 
getAttemptFailedInJoinAsUnionMaxSize() - 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 a RecordQueryInJoinPlan into a RecordQueryInUnionPlan.
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.AbstractEdge
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.AbstractNode
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.DataNodeWithInfo
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Edge
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.LogicalOperatorNode
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.LogicalOperatorNodeWithInfo
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Node
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.NodeWithInfo
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.OperatorNodeWithInfo
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.PartialMatchEdge
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceHeadNode
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceInternalEdge
 
getAttributes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceMemberNode
 
getAttributesMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.PlanPartition
 
getAttributeValue(PlanProperty<A>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PlanPartition
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
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.RecordQueryPredicatesFilterPlan
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
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
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
getAvailableFields() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
getAvailableRecordTypeNames() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
getAvailableRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
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.
getBaseAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor.ScalarVisitorState
 
getBaseAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getBaseQuantifier() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
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 a CompletableFuture that will contain the Subspace this 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
 
getBaseType() - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
getBaseType() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
getBaseType() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getBaseType() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
getBaseType() - Method in interface com.apple.foundationdb.record.query.plan.cascades.WithBaseQuantifierMatchCandidate
 
getBegin() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
getBindable() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformEvent
 
getBindable() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformRuleCallEvent
 
getBinding(Bindings.Internal, CorrelationIdentifier) - 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.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 current Bindings.
getBindingAliasMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
getBindingMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
getBindingName() - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
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.cascades.CascadesRuleCall
 
getBindings() - Method in interface com.apple.foundationdb.record.query.plan.cascades.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.
getBindings() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
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
 
getBoundAliasesMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
 
getBoundAliasMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getBoundaryKeys(Transaction, byte[], byte[]) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBLocalityProvider
Return a CloseableAsyncIterator of keys k such that begin <= k < end and k is 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.
getBoundParameterPrefixMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getBoundPlaceholders() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getBoundValues(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
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
 
getBuilders() - Method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression.LongArithmethicFunctionKeyExpressionFactory
 
getBuilders() - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpressionFactory
 
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
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
getCachedMetaData() - Method in interface com.apple.foundationdb.record.provider.foundationdb.MetaDataCache
Get cached RecordMetaData object.
getCachedSerialized() - Method in interface com.apple.foundationdb.record.provider.foundationdb.MetaDataCache
Get cached serialized meta-data.
getCandidatePredicate() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
getCandidatePredicate() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.MappingKey
 
getCandidateRef() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getCandidateValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.MaxMatchMap
 
getCardinality() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty.Cardinality
 
getCheckIndexingMethodFrequencyMilliseconds() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
If negative, avoid checks.
getChild() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
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.cascades.predicates.NotPredicate
 
getChild() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicateWithChild
Method to retrieve the only child predicate.
getChild() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
getChild() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.ValueWithChild
Method to retrieve the only child value.
getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
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.RecordQueryStreamingAggregationPlan
 
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.plan.plans.TempTableInsertPlan
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
getChild() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
getChild(int) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
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
 
getChildCompensation() - Method in class com.apple.foundationdb.record.query.plan.cascades.Compensation.ForMatch
 
getChildCompensation() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
 
getChildContinuations() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
 
getChildPartialMatchMaybe(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
getChildPartialMatchMaybe(Quantifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
getChildQuantifiedRecordValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
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 class com.apple.foundationdb.record.metadata.IndexPredicate.AndPredicate
 
getChildren() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.OrPredicate
 
getChildren() - Method in interface com.apple.foundationdb.record.query.expressions.ComponentWithChildren
 
getChildren() - Method in class com.apple.foundationdb.record.query.expressions.OrComponent
Children for this component, at least 2 of them.
getChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndOrPredicate
 
getChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.LeafQueryPredicate
 
getChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicateWithChild
Method to retrieve a list of children values.
getChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Method to retrieve a list of children values.
getChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractValue
 
getChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.LeafValue
Method to retrieve a list of children values.
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.RecordQueryChooserPlanBase
 
getChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
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) RecordQueryPlan children 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.RecordQueryRecursiveUnionPlan
 
getChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
 
getChildren() - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNode
 
getChildren() - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNodeBuilder
 
getChildren() - Method in interface com.apple.foundationdb.record.util.TrieNode
 
getChildrenMap() - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNode
 
getChildrenMap() - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNodeBuilder
 
getChildrenMap() - Method in interface com.apple.foundationdb.record.util.TrieNode
 
getChildrenRefs() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
 
getChildStream() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
getClassToTypeCodeMap() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Returns a map from Java Class to corresponding Type.TypeCode.
getClearWhenZero(Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
 
getClusterAttributeProvider() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter.Cluster
 
getClusterFile() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
Get the path to the cluster file that this database was created with.
getClusterFilePath(FDBDatabaseRunner) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBSystemOperations
Get the file system path to the cluster file used.
getClusterFilePathAsync(FDBDatabaseRunner) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBSystemOperations
Get the file system path to the cluster file used.
getClusterProvider() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter
 
getCoercionTrie() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getCollatorRegistry() - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
 
getCollatorRegistry() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
getCollectionValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
getCollectionValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
getColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.DataNodeWithInfo
 
getColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Edge
 
getColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ExistentialQuantifierEdge
 
getColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ForEachQuantifierEdge
 
getColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Node
 
getColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceEdge
 
getColumns() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
 
getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
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.LongArithmethicFunctionKeyExpression
 
getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
 
getColumnSize() - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
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
 
getColumnSize() - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
getColumnSize() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
getColumnSize() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
getColumnSize() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getColumnSize() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
getCommitCheck(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Fetches a previously installed pre-commit check by name.
getCommitChecks(Predicate<FDBRecordContext.CommitCheckAsync>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Get all commit checks that have been added to the transaction that conform to the given predicate.
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
 
getCommittedVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
getCommonPrimaryKey() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
getCommonPrimaryKey() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
getCommonPrimaryKey(Index) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Return the common primary key for a given index.
getCommonPrimaryKeyLength(Index) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Return the length of the common primary key for a given index.
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.InvertedFunctionComparison
 
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.OpaqueEqualityComparison
 
getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
getComparand(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
getComparandConversionFunction() - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
 
getComparandConversionFunction() - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
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.
getComparandValue() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
getComparandWithRealEquals() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
 
getComparator(Tuple) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
getComparator(K) - Method in interface com.apple.foundationdb.record.sorting.MemorySortAdapter
 
getCompareAndClearParam() - Method in interface com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation
Get a value that causes the index entry to be removed if the result of the mutation matches.
getCompareAndClearParam() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
 
getComparison() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.ValuePredicate
 
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.QueryKeyExpressionWithOneOfComparison
 
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.plan.cascades.Ordering.Binding
 
getComparison() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
getComparison() - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
getComparisonFunction() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.CoalesceFn
 
getComparisonFunction() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
getComparisonKey() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
getComparisonKey() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression
 
getComparisonKey() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
 
getComparisonKeyExpression() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan
 
getComparisonKeyExpression() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan
 
getComparisonKeyExpression() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan
 
getComparisonKeyFunction() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.IntersectionMultiCursor
 
getComparisonKeyFunction() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan
 
getComparisonKeyFunction() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
getComparisonKeyFunction() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
getComparisonKeyFunction() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan
 
getComparisonKeyFunction() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
getComparisonKeyFunction() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
getComparisonKeyFunction() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan
 
getComparisonKeyFunction() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
getComparisonKeyFunction() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
 
getComparisonKeyOrderingParts() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
getComparisonKeyOrderingParts() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
getComparisonKeyOrderingParts() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithComparisonKeyValues
 
getComparisonKeyOrderingParts() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
getComparisonKeyProvidedOrderingParts() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
getComparisonKeyValues() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
getComparisonKeyValues() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
getComparisonKeyValues() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithComparisonKeyValues
 
getComparisonKeyValues() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues
 
getComparisonKeyValues() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
getComparisonRange() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange.MergeResult
 
getComparisonRange() - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedOrderingPart
 
getComparisonRangeOptional() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
getComparisonRanges() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
getComparisonRanges() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
getComparisonRanges() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
getComparisonRanges() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithComparisons
 
getComparisonRanges() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
getComparisonRanges() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredMatch
Make callers get the info in a more readable way.
getComparisonRangeType() - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedOrderingPart
 
getComparisons() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
getComparisons() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithComparisons
Return all comparisons this predicate uses.
getComparisons() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
getComparisons() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
Computes a list of Comparisons.Comparison from this RangeConstraints.
getComparisons() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
getComparisons() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithComparisons
 
getComparisons() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.ScoreForRank
 
getComparisons() - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
 
getComparisonType() - Method in class com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison
 
getComparisonType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue
 
getComparisonType(Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
getCompensatedAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.Compensation.ForMatch
 
getCompensatedAliases() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
 
getCompensatedAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
Return a set of aliases that this partial match is responsible for covering, that is either the matches replacement or compensation will take care of the aliases in the returned set.
getCompletedGroupResult() - Method in class com.apple.foundationdb.record.cursors.aggregate.StreamGrouping
Get the last completed group result.
getCompleteMatchMatcher() - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.AbstractDataAccessRule
 
getCompleteResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
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.RecordQueryAbstractDataModificationPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
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.RecordQueryInUnionPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
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.RecordQueryStreamingAggregationPlan
 
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
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
getComplexity() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
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
 
getComputationDependsOn() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRuleSet.TransformedRules
 
getComputationRules() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRuleSet.TransformedRules
 
getComputationValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getConfig() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Get the FDBRecordContextConfig used to open this context.
getConfig() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
 
getConfig(Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.MultiDimensionalIndexHelper
Parse standard options into RTree.Config.
getConfig(Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper
Parse standard options into RankedSet.Config.
getConfigLoader() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Get the function used by the online indexer to load the config parameters on fly.
getConfigLoaderInvocationCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
getConfiguration() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
 
getConfiguration() - Method in interface com.apple.foundationdb.record.query.plan.QueryPlanner
 
getConfiguration() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
 
getConjunctedFilter() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
 
getConjunctedPredicate() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
getConnectionString(FDBDatabaseRunner) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBSystemOperations
Get the connection string used to connect to the FDB cluster.
getConnectionStringAsync(FDBDatabaseRunner) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBSystemOperations
Get the connection string used to connect to the FDB cluster.
getConstantAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
getConstantId() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
getConstituent(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
Get a constituent record of this record if it is a synthetic record type.
getConstituent(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBSyntheticRecord
 
getConstituentName() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
Get the name of this constituent if it comes from a synthetic record.
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
 
getConstituentToPathMap(RecordType, int) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields
 
getConstraint() - Method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
 
getConstraint() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
getConstraint() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
getConstraint() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
getConstraint() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
getConstraint() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithConstraint
 
getConstraintDependencies() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRule
 
getConstraintOptional(PlannerConstraint<T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
Method to return an optional constraint given the kind of constraint attribute key passed in.
getConstraintsMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
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.provider.foundationdb.keyspace.KeySpaceTreeResolver
 
getContext() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
getContext() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
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.provider.foundationdb.cursors.MergeCursorState
 
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.ComparatorCursor
 
getContinuationObject() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.IntersectionMultiCursor
 
getContinuationObject() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
Produce a RecordCursorContinuation for this cursor.
getContinuationObject() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ProbableIntersectionCursor
 
getContinuationObject() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnionCursor
 
getContinuations() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorContinuation
 
getCopyIfPredicate() - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.FieldData
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
getCorrelatedTo() - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
getCorrelatedTo() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Correlated
Returns the set of CorrelationIdentifiers this entity is correlated to.
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
getCorrelatedTo() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionWithChildren
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AbstractQueryPredicate
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractValue
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
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 class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
getCorrelatedTo() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUnionExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUniqueExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
getCorrelatedToWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionWithChildren
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AbstractQueryPredicate
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
getCorrelatedToWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractValue
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
getCorrelatedToWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedValue
 
getCorrelatedToWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
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.RecordQueryFirstOrDefaultPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
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.plans.TempTableInsertPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
getCorrelatedToWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
getCorrelationOrder() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Method to compute the correlation order as a PartiallyOrderedSet.
getCorrelationOrder() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionWithChildren
 
getCorrelationOrder() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
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.
getCount(Debugger.Location) - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Stats
 
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.
getCoveredPrimaryKeyPositions() - Method in class com.apple.foundationdb.record.metadata.Index
 
getCoveringIndexEntryToPartialRecordFunction(FDBRecordStoreBase<M>, String, String, IndexKeyValueToPartialRecord, boolean) - Static method in class com.apple.foundationdb.record.query.plan.plans.QueryPlanUtils
The method to get a function from an IndexEntry to a FDBQueriedRecord representing a partial record.
getCumulativeValue() - Method in class com.apple.foundationdb.record.provider.common.StoreTimer.Counter
Get the cumulative value of the associated event.
getCumulativeValue() - Method in class com.apple.foundationdb.record.provider.common.StoreTimerSnapshot.CounterSnapshot
Get the cumulative size of the associated event.
getCurrent() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
getCurrentOrdinal() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
getCurrentPropertiesForPlan(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.PropertiesMap
Returns the properties currently stored in the properties map for the given plan.
getCurrentReference() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.AdjustMatchEvent
 
getCurrentReference() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.EventWithCurrentGroupReference
Getter.
getCurrentReference() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreExpressionEvent
 
getCurrentReference() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreGroupEvent
 
getCurrentReference() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeGroupEvent
 
getCurrentReference() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeInputsEvent
 
getCurrentReference() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformEvent
 
getCurrentReference() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformRuleCallEvent
 
getCurrentState() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
 
getCurrentState() - Method in interface com.apple.foundationdb.record.query.plan.cascades.KeyExpressionVisitor
Method to return the (immutable) current state.
getCurrentState() - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
getCurrentState() - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
getCurrentType() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.FieldAccessTrieNodeBuilder
 
getCurrentVersionAsync(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.MetaDataCache
Get a version to use for cache validation of -1 to skip validation.
getCursor() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
 
getCursor(TupleRange, FDBRecordStore, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexScrubbingToolsDangling
 
getCursor(TupleRange, FDBRecordStore, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexScrubbingToolsMissing
 
getCursor(TupleRange, FDBRecordStore, int) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScrubbingTools
Return a cursor that can be iterated by the indexing process.
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.KeyCheckingTransaction
 
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
 
getDatabase(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
getDatacenterId() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
 
getDatacenterId() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
getDatum() - Method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
Retrieve the wrapped result.
getDBVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Retrieves the part of the version that corresponds to the database commit version.
getDeadlineTimeMillis() - Method in class com.apple.foundationdb.record.AsyncLoadingCache
Get the deadline time imposed on cache loading in milliseconds.
getDebugger() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
getDebuggerMaybe() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
getDefault() - Static method in enum com.apple.foundationdb.record.provider.foundationdb.APIVersion
Get the default API 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 default CursorStreamingMode for new ScanProperties.
getDefaultCursorStreamingMode() - Method in class com.apple.foundationdb.record.ExecuteProperties
Get the default CursorStreamingMode for new ScanProperties.
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 limit BooleanNormalizer.DEFAULT_SIZE_LIMIT.
getDefaultInstance() - Static method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryPlannerSortConfiguration
 
getDefaultInstanceForCnf() - Static method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer
Obtain a (cnf-) normalizer with the default size limit BooleanPredicateNormalizer.DEFAULT_SIZE_LIMIT.
getDefaultInstanceForDnf() - Static method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer
Obtain a (dnf-) normalizer with the default size limit BooleanPredicateNormalizer.DEFAULT_SIZE_LIMIT.
getDefaultPredicateCompensation(QueryPredicate) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
Return a PredicateMultiMap.PredicateCompensation that reapplies this predicate.
getDefaultValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
 
getDeferredRanges() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
Returns deferred ranges, i.e.
getDelegate() - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
getDeleteBefore() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
 
getDelimiter() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
 
getDelimiter() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
 
getDelimiter() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
 
getDependencyMap() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
getDependsOn() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.AbstractEdge
 
getDependsOnMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
 
getDescription() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.AdjustMatchEvent
 
getDescription() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Event
Getter.
getDescription() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExecutingTaskEvent
 
getDescription() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreExpressionEvent
 
getDescription() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreGroupEvent
 
getDescription() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
getDescription() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeGroupEvent
 
getDescription() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeInputsEvent
 
getDescription() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformEvent
 
getDescription() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformRuleCallEvent
 
getDescription() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TranslateCorrelationsEvent
 
getDescription() - Method in class com.apple.foundationdb.record.query.plan.cascades.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.cascades.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.
getDimensionRanges() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.Hypercube
 
getDimensionsKeyExpression(KeyExpression) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.MultidimensionalIndexMaintainer
Traverse from the root of a key expression of a multidimensional index to the DimensionsKeyExpression.
getDimensionsScanComparisons() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
getDimensionsSize() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
getDimensionsSubKey() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
getDirection() - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
getDirection() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
getDirection() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
getDirectionalSortOrderOrDefault(S) - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart
 
getDirectories() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
Returns the available root directories in the KeySpace.
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.KeySpaceTreeResolver.Resolved
 
getDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedPath
 
getDirectory() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRoot
 
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.
getDistinctness() - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
 
getDouble(int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
 
getDownstream() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MultiMatcher
 
getDownstream() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcherWithExtractAndDownstream
 
getDuration() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.TimeWindowSpec
 
getDynamicTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
getDynamicTypes() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
getDynamicTypes() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionWithPredicates
 
getDynamicTypes() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Iterates over the entire expression tree collecting a set of all dynamically-generated types.
getDynamicTypes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getDynamicTypes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
getDynamicTypes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
getDynamicTypes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
getDynamicTypes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
getDynamicTypes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
getDynamicTypes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
getEdgeAttributeProvider() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter
 
getEdgeID(E) - Method in class com.apple.foundationdb.record.query.plan.cascades.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.cascades.explain.GraphExporter
 
getEdgeLabel(Attribute) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.DotExporter
 
getElementToAliasFn() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
 
getElementType() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
Returns the array element Type.
getElementType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue
 
getElementTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Returns the list of Type.Record.Field Types.
getEmptyInstance() - Static method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyStorage
 
getEmptyMode() - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
 
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.
getEncapsulationFunction() - Method in class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
 
getEncryptionCipherName() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
getEncryptionCipherName() - Method in interface com.apple.foundationdb.record.sorting.FileSortAdapter
Get name of cipher to use for encrypting.
getEncryptionKey() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
getEncryptionKey() - Method in interface com.apple.foundationdb.record.sorting.FileSortAdapter
Get whether files should be encrypted.
getEnd() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
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
 
getEntry() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer.TimeWindowRankAndEntry
 
getEntryPrimaryKey(Tuple) - Method in class com.apple.foundationdb.record.metadata.Index
Get the primary key portion of an index entry.
getEntryPrimaryKeyPositions(int) - Method in class com.apple.foundationdb.record.metadata.Index
Get the primary key positions of an index entry.
getEntrySize(KeyExpression) - Method in class com.apple.foundationdb.record.metadata.Index
The number of columns stored for an index entry.
getEnumDescriptor(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Gets the protobuf message descriptor for the given message type.
getEnumDescriptor(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Gets the protobuf enum descriptor for the given enum type.
getEnumTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Returns the enum types registered with the schema.
getEnumValue(String, int) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Gets the enum value for the given enum type and number.
getEnumValue(String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Gets the enum value for the given enum type and name.
getEnumValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
getEqualitiesSize() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
getEquality() - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
 
getEquality(FDBRecordStoreBase<?>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
 
getEqualityBoundValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
getEqualityComparison() - Method in class com.apple.foundationdb.record.query.plan.cascades.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
 
getEquivalenceMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
getError() - Method in class com.apple.foundationdb.record.util.Result
The error encountered by the operation, if not successful.
getErrorCode() - Method in exception com.apple.foundationdb.record.query.plan.cascades.SemanticException
 
getEstimatedRangeSizeBytes(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getEstimatedRangeSizeBytes(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getEstimatedRangeSizeBytes(Range) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getEstimatedRangeSizeBytes(Range) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getEvaluationContext() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
getEventClassStatsMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.StatsMaps
 
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.
getExclusiveLimitValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
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.aggregate.AggregateCursor
 
getExecutor() - Method in class com.apple.foundationdb.record.cursors.AsyncLockCursor
 
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.FallbackCursor
 
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.AsyncIteratorCursor
 
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
Deprecated.
 
getExecutor() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
 
getExecutor() - Method in class com.apple.foundationdb.record.cursors.MapResultCursor
 
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.RangeCursor
 
getExecutor() - Method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor
 
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.cursors.TempTableInsertCursor
 
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.InstrumentedTransaction
 
getExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
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
 
getExecutor() - Method in class com.apple.foundationdb.record.sorting.FileSortCursor
 
getExecutor() - Method in class com.apple.foundationdb.record.sorting.MemorySortCursor
 
getExistentialAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
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.
getExpectedStamp() - Method in exception com.apple.foundationdb.record.provider.foundationdb.IndexingBase.PartlyBuiltException
 
getExpectedStampString() - Method in exception com.apple.foundationdb.record.provider.foundationdb.IndexingBase.PartlyBuiltException
 
getExpectedType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
getExplainLevel() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
getExplainTokens() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence
 
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.cascades.explain.GraphExporter.ExporterContext
 
getExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.AdjustMatchEvent
 
getExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreExpressionEvent
 
getExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
getExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeInputsEvent
 
getExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TranslateCorrelationsEvent
 
getExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.LogicalOperatorNode
 
getExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.LogicalOperatorNodeWithInfo
 
getExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.OperatorNodeWithInfo
 
getExpression() - Method in interface com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.WithExpression
 
getExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal.ReferencePath
 
getExpression() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
Get the expression that satisfied this filter.
getExpressionMatcher() - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.AbstractDataAccessRule
 
getExpressionRules(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.PlannerRuleSet
 
getExpressionRules(RelationalExpression, Predicate<CascadesRule<? extends RelationalExpression>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PlannerRuleSet
 
getExpressionToFieldDataMap() - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor.Result
 
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
 
getExtractor() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcherWithExtractAndDownstream
 
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
 
getFetchIndexRecords() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
getFetchIndexRecords() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
getFetchIndexRecords() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithIndex
 
getFetchIndexRecords() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
 
getField() - Method in class com.apple.foundationdb.record.query.plan.cascades.Column
 
getField(int) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
getFieldAccessors() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
getFieldBuilder(String) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
 
getFieldDescriptorMapFromNames(Collection<String>) - Method in class com.apple.foundationdb.record.RecordMetaData
 
getFieldDescriptorMapFromTypes(Collection<RecordType>) - Static method in class com.apple.foundationdb.record.RecordMetaData
 
getFieldIndex() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
Returns the field index.
getFieldIndexOptional() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
Returns the field index.
getFieldIndexToOrdinalMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
getFieldName() - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
 
getFieldName() - Method in class com.apple.foundationdb.record.query.expressions.BaseField
 
getFieldName() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
Returns the field name.
getFieldNameFieldMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Returns a mapping from Type.Record.Field names to their Types.
getFieldNameOptional() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
Returns the field name.
getFieldNamePrefix() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
getFieldNamePrefix() - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor.ScalarVisitorState
 
getFieldNameToOrdinalMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
getFieldOnMessage(MessageOrBuilder, Descriptors.FieldDescriptor) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
 
getFieldOnMessage(MessageOrBuilder, String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
Get the value of the field with the given field name on the given message.
getFieldOnMessageByOrdinal(MessageOrBuilder, int) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
 
getFieldOrdinals() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
getFieldOrdinals() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
getFieldOrNull(M, Predicate<M>, Function<M, T>) - Static method in class com.apple.foundationdb.record.query.plan.serialization.PlanSerialization
Helper method to check for a field's existence in the protobuf message passed in.
getFieldOrThrow(M, Predicate<M>, Function<M, T>) - Static method in class com.apple.foundationdb.record.query.plan.serialization.PlanSerialization
Helper method to check for a field's existence in the protobuf message passed in.
getFieldPath() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.ValuePredicate
 
getFieldPath() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
getFieldPath() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.FieldValueCompensation
 
getFieldPathNames() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
getFieldPathNamesMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
getFieldPathTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
getFieldPrefix() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
getFieldPrefix() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
getFields() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Returns the list of Type.Record Type.Record.Fields.
getFieldType() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
Returns the field Type.
getFieldTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
getFieldValue(MessageOrBuilder) - Method in class com.apple.foundationdb.record.query.expressions.BaseField
 
getFieldValueForFieldNames(MessageOrBuilder, List<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
Get the value of the (nested) field on the path from the message defined by fieldNames.
getFieldValueForFieldOrdinals(MessageOrBuilder, ImmutableIntArray) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
 
getFileDescriptorSet() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Returns the internal file descriptor set of this schema.
getFilePosition() - Method in class com.apple.foundationdb.record.sorting.SortedFileReader
 
getFiles() - Method in class com.apple.foundationdb.record.sorting.FileSorter
 
getFillColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.DataNodeWithInfo
 
getFillColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.LogicalOperatorNode
 
getFillColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.LogicalOperatorNodeWithInfo
 
getFillColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationLogicalOperatorNode
 
getFillColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationOperatorNodeWithInfo
 
getFillColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Node
 
getFillColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceHeadNode
 
getFillColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceMemberNode
 
getFillColor() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.TemporaryDataNodeWithInfo
 
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.planning.InExtractor
 
getFilter() - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
 
getFilter() - Method in class com.apple.foundationdb.record.query.RecordQuery
 
getFilters() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
 
getFirstComparison() - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
 
getFloat(int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
 
getFlowedColumns() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
getFlowedObjectType() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
getFlowedObjectValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
getFlowedTypeForSetOperation(Iterable<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
 
getFlowedValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
getFontName() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Edge
 
getFontName() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Node
 
getFontSize() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Edge
 
getFontSize() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Node
 
getFontSize() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceHeadNode
 
getFontSize() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceMemberNode
 
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.
getForOrdinalPath(Tuple, ImmutableIntArray) - Static method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
 
getFullKeyExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
getFullKeyExpression() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
This method returns a key expression that can be used to actually compute the keys of this candidate for a given record.
getFullKeyExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
getFullKeyExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getFullKeyExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
getFunction() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
 
getFunction() - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
 
getFunctionName() - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
 
getFunctionName() - Method in class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
 
getFunctionName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue
 
getFunctionName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfFunction
 
getFunctionSingleton(Class<? extends BuiltInFunction<? extends Typed>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FunctionCatalog
Get the loaded representative function singleton for a function class.
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.cascades.explain.GraphExporter
 
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
 
getGroupedExpression() - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
 
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
 
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
 
getGroupingCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
getGroupingExpressions() - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
 
getGroupingKey(KeyExpression) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
 
getGroupingKeyAlias() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
getGroupingKeyExpression() - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
 
getGroupingSubKey() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
 
getGroupingValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
getGroupingValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
getGroupingValueMaybe() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
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
How the upper boundary key of the range is to be interpreted by the scan.
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.
getHookForAsyncToSync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
 
getIconId() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
getId() - Method in class com.apple.foundationdb.record.query.plan.cascades.CorrelationIdentifier
 
getId() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeIcon
 
getId() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
getIdentifier() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.IdentifierToken
 
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.cascades.explain.AbstractPlannerGraph.AbstractNode
 
getIfDisabled() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
The desired action if the index is disabled.
getIfMismatchPrevious() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
The desired action if the index is in partly built, but the requested policy mismatches the previous one.
getIfReadable() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
The desired action if the index is in readable mode (i.e.
getIfWriteOnly() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
The desired action if the index is in write only mode.
getInAlias() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
getInAlias(InSource) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
getInBindings() - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
 
getIncreaseLimitAfter() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
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.OnlineIndexOperationConfig.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.OnlineIndexOperationConfig
Get the number of successful range builds before re-increasing the number of records to process in a single transaction.
getIndependentQuantifiersPartitioning() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
Returns the partitioning of independent Quantifiers (via their aliases).
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.FDBIndexedRawRecord
Get the index for this record.
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.IndexingCommon
 
getIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedIndexKeyspace
 
getIndex() - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons.RankComparison
 
getIndex() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.CandidateScan
 
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
getIndexBuildStateAsync(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Get the progress of building the given index.
getIndexDeferredMaintenanceControl() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
For some indexes, there are index maintenance operations that could be either done inline, during a record update operation, or later in the background.
getIndexEntry() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRawRecord
Get the index entry for this record.
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 class com.apple.foundationdb.record.query.plan.plans.QueryResult
 
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
 
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.
getIndexesSince(int) - Method in class com.apple.foundationdb.record.RecordMetaData
Get all indexes in the meta-data that were modified after the given version.
getIndexesToBuild() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Get unbuilt indexes for this store that should be built.
getIndexesToBuildSince(int) - Method in class com.apple.foundationdb.record.RecordMetaData
Get all indexes in the meta-data that were modified after the given version that should be built.
getIndexFetchMethod() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
getIndexFetchMethod() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Whether the planner should use IndexPrefetch operations for the index scan plans.
getIndexFromSubspaceKey(Object) - Method in class com.apple.foundationdb.record.RecordMetaData
Get the index that uses the given subspace key.
getIndexKeyValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getIndexKeyValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
getIndexKeyValueToPartialRecord() - Method in class com.apple.foundationdb.record.query.plan.cascades.ScanWithFetchMatchCandidate.IndexEntryToLogicalRecord
 
getIndexMaintainer(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Get the maintainer for a given index.
getIndexMaintainer(Index) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Returns the index maintainer for a given index.
getIndexMaintainer(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
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.MultidimensionalIndexMaintainerFactory
 
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.PermutedMinMaxIndexMaintainerFactory
 
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 the index filter to be used by the record store.
getIndexMaintenanceFilter() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
 
getIndexName() - Method in exception com.apple.foundationdb.record.provider.foundationdb.IndexingBase.PartlyBuiltException
 
getIndexName() - Method in class com.apple.foundationdb.record.query.plan.cascades.IndexAccessHint
 
getIndexName() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
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
 
getIndexOptional(Class<?>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
getIndexPlan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
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 whether RecordQueryIndexPlan is preferred over RecordQueryScanPlan even when it does not satisfy any additional conditions.
getIndexScanPreference() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Get whether RecordQueryIndexPlan is preferred over RecordQueryScanPlan even when it does not satisfy any additional conditions.
getIndexScrubbingTools(IndexScrubbingTools.ScrubbingType) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainer
 
getIndexScrubbingTools(IndexScrubbingTools.ScrubbingType) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
 
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 to IndexState that is underlying this RecordStoreState.
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.
getIndexTypeName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
getIndexTypeName() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.IndexableAggregateValue
 
getIndexTypeName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MaxEverValue
 
getIndexTypeName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MinEverValue
 
getIndexTypeName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.BitmapConstructAgg
 
getIndexTypeName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Max
 
getIndexTypeName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Min
 
getIndexTypeName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Sum
 
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.MultidimensionalIndexMaintainerFactory
 
getIndexTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainerFactory
 
getIndexTypes() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.PermutedMinMaxIndexMaintainerFactory
 
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.MultidimensionalIndexMaintainerFactory
 
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.PermutedMinMaxIndexMaintainerFactory
 
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
 
getIndexValueValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getInequalityComparisons() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
getInequalityComparisons() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
getInfixNotation() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
getInfoAttributeMap(Set<NodeInfo>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
getInfoId() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.NodeWithInfo
 
getInfoId() - Method in interface com.apple.foundationdb.record.query.plan.cascades.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.OnlineIndexOperationBaseBuilder
Get the initial delay between transaction retry attempts.
getInitialDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
 
getInitialLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Get the initial number of records to process in one transaction.
getInitialLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
Get the initial number of records to process in one transaction.
getInitialMergesCountLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
Get the initial merges count limit for OnlineIndexer.mergeIndex() and the indexing process.
getInitialStateQuantifier() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
getInitialToPartialFunction() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
 
getInitialToPartialFunction() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
getInListValues() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
 
getInner() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
getInner() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
getInner() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
getInner() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
getInner() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
getInner() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
getInner() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
getInner() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
getInnerKey() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
 
getInnerPlan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getInnerPlan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
getInnerPlan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
getInnerPlan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
getInnerPlan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
getInnerPlan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
getInnerPlan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
getInnerQuantifier() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
getInnerQuantifier() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
getInnerQuantifier() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
getInnerType() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
Returns the values Type.
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.
getInSession(Object, Class<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Retrieve a value from the session in the FDBRecordContext.
getInSource() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
getInSources() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
getInvariableCollator(TextCollatorRegistry, KeyExpression) - Static method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
 
getInvariableCollator(TextCollatorRegistry, Value, Value) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
getInvertibleFunction() - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.FieldData
 
getInvertibleFunction() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier
 
getIsolationLevel() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
getIsolationLevel() - Method in class com.apple.foundationdb.record.ExecuteProperties
 
getIterator() - Method in class com.apple.foundationdb.record.query.plan.cascades.TempTable
Returns an iterator of the underlying buffer, note that this iterator is not synchronized.
getJavaClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
Returns the corresponding Java Class of the Type instance.
getJavaClass() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Returns the corresponding Java Class of the Type instance.
getJavaClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
Returns the corresponding Java Class of the Type instance.
getJavaClass() - Method in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
Returns the corresponding Java Class of the Type instance.
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() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverKeyValue
 
getKey() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator.ValidatedEntry
Return the key in the resolver mapping.
getKey() - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyValue
 
getKey() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
getKey() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortKey
 
getKey() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
getKey() - Method in interface com.apple.foundationdb.record.util.pair.Pair
Alias of Pair.getLeft().
getKey(KeySelector) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getKey(KeySelector) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getKey(Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
Given a Key.Evaluated returned 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
 
getKeyChecker() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Get the key checker to hook operations' keys.
getKeyChecker() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
Get the key checker to hook operations' keys.
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
 
getKeyExpression() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithOneOfComparison
 
getKeyFields(KeyExpression) - Static method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
Return the key fields for an expression.
getKeyFromCursorResult(RecordCursorResult<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexScrubbingToolsDangling
 
getKeyFromCursorResult(RecordCursorResult<FDBStoredRecord<Message>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexScrubbingToolsMissing
 
getKeyFromCursorResult(RecordCursorResult<T>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScrubbingTools
Return a key for a given result.
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 for KeyValueLogMessage.
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
 
getKeyValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
getKeyword() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.KeywordToken
 
getKind() - Method in enum com.apple.foundationdb.record.PlanHashable.PlanHashMode
Get the plan hash kind associated with this mode.
getLabel() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.AbstractEdge
 
getLastFieldAccessor() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
getLastFieldName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
getLastFieldName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
getLastFieldOrdinal() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
getLastFieldType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
getLastModifiedVersion() - Method in class com.apple.foundationdb.record.metadata.Index
Get the version at which the index was changed.
getLastModifiedVersion() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate.UsedIndex
 
getLastStep() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
During the deferred operation, each step should record its action.
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() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanRange
 
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() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanRange
 
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
 
getLeafReferences() - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal
 
getLeaseLengthMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
 
getLeft() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordType.Join
 
getLeft() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder.Join
 
getLeft() - Method in class com.apple.foundationdb.record.util.pair.ComparablePair
 
getLeft() - Method in class com.apple.foundationdb.record.util.pair.ImmutablePair
 
getLeft() - Method in class com.apple.foundationdb.record.util.pair.NonnullPair
 
getLeft() - Method in interface com.apple.foundationdb.record.util.pair.Pair
Get the left element of the pair.
getLeftArgType() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
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.IndexingBase
 
getLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingThrottle
 
getLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
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 class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Get the maximum number of records to process in one transaction.
getLimit() - Method in interface com.apple.foundationdb.record.RecordScanLimiter
Get the record scan limit.
getLimitManager() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
getList() - Method in class com.apple.foundationdb.record.query.plan.cascades.TempTable
Returns the underlying buffer, note that this method is not synchronized.
getListener() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
 
getLiteralValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
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.
getLocalityProvider() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
getLocalValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.Derivations
 
getLocalVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Retrieves the part of the version that is set within a single FDBRecordContext.
getLocation() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.AbstractEventWithState
 
getLocation() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Event
Getter.
getLocation() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
getLocation() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TranslateCorrelationsEvent
 
getLocationCountMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Stats
 
getLogicalKeyValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.ScanWithFetchMatchCandidate.IndexEntryToLogicalRecord
 
getLogicalOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
getLogicalOperator() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.Resolved
 
getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedIndexKeyspace
 
getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedKeyField
 
getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedPath
 
getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRecordStoreKeyspace
 
getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRecordTypeKeyspace
 
getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRoot
 
getLogicalValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
Returns the logical value (prior to resolving) for this path element.
getLogicalValueValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.ScanWithFetchMatchCandidate.IndexEntryToLogicalRecord
 
getLogInfo() - Method in exception com.apple.foundationdb.record.LoggableTimeoutException
 
getLogName() - Method in enum com.apple.foundationdb.record.IndexState
 
getLogWarningsLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy
 
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
How the lower boundary key of the range is to be interpreted by the scan.
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.
getMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap
 
getMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.MaxMatchMap
 
getMap() - Method in class com.apple.foundationdb.record.sorting.MemoryScratchpad
 
getMappedRange(KeySelector, KeySelector, byte[], int, boolean, StreamingMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getMappedRange(KeySelector, KeySelector, byte[], int, boolean, StreamingMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getMappingKey() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
getMappingKind() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
getMappingKind() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.MappingKey
 
getMappingOptional(QueryPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMap
 
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 a CompletableFuture that will contain the Subspace where this resolver stores the mappings from key Strings to value Long.
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
 
getMapSorter() - Method in class com.apple.foundationdb.record.sorting.FileSorter
 
getMatchCandidate() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
getMatchCandidate() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getMatchCandidate() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithMatchCandidate
 
getMatchCandidateMaybe() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
getMatchCandidateMaybe() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
getMatchCandidateMaybe() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
getMatchCandidateMaybe() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithMatchCandidate
 
getMatchCandidateMaybe() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
getMatchCandidateMaybe() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
 
getMatchCandidates() - Method in class com.apple.foundationdb.record.query.plan.cascades.MetaDataPlanContext
 
getMatchCandidates() - Method in interface com.apple.foundationdb.record.query.plan.cascades.PlanContext
 
getMatchCandidates() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Return all match candidates that partially match this reference.
getMatchedOrderingParts() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedBuilder
 
getMatchedOrderingParts() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedMatchInfo
 
getMatchedOrderingParts() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchInfo
 
getMatchedOrderingParts() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
getMatchedQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.Compensation.ForMatch
 
getMatchedQuantifiers() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
 
getMatchedQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getMatchedQuantifiers(PartialMatch) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
getMatchedQuantifiers(PartialMatch) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionWithChildren
 
getMatcher() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRule
 
getMatcher() - Method in interface com.apple.foundationdb.record.query.plan.cascades.PlannerRule
 
getMatcher() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRule
 
getMatchInfo() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getMatchPartitionRules() - Method in class com.apple.foundationdb.record.query.plan.cascades.PlannerRuleSet
 
getMatchPartitionRules(Predicate<CascadesRule<? extends MatchPartition>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PlannerRuleSet
 
getMatchResult() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BoundMatch
 
getMatchResultOptional() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BoundMatch
 
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.
getMaxArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression
 
getMaxArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
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.OnlineIndexOperationBaseBuilder
Get the maximum number of transaction retry attempts.
getMaxAttempts() - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
 
getMaxCardinality() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty.Cardinalities
 
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.OnlineIndexOperationBaseBuilder
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.
getMaxFileCount() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
getMaxFileCount() - Method in interface com.apple.foundationdb.record.sorting.FileSortAdapter
Get the maximum number of files to keep before merging.
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.
getMaxLength(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
getMaxLength(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
getMaxLengths() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
getMaxLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Get the maximum number of records to process in one transaction.
getMaxLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
Get the maximum number of records to process in one transaction.
getMaxMatchMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedBuilder
 
getMaxMatchMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedMatchInfo
 
getMaxMatchMap() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchInfo
 
getMaxMatchMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
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.
getMaxNumMatchesPerRuleCall() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Get the maximum number of matches that are permitted per rule call within the Cascades planner.
getMaxNumReplansForInToJoin() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
The number of times the RecordQueryPlanner will attempt to replan during IN-to-JOIN planning.
getMaxNumReplansForInUnion() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
The number of times the RecordQueryPlanner will attempt to replan during IN-to-union planning.
getMaxRecordCountInMemory() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
getMaxRecordCountInMemory() - Method in interface com.apple.foundationdb.record.sorting.MemorySortAdapter
Get the maximum allowed size of the in-memory map.
getMaxRetries() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Get the maximum number of times to retry a single range rebuild.
getMaxRetries() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Get the maximum number of times to retry a single range rebuild.
getMaxRetries() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
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.
getMaxSize() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
Returns the maximum length of the plan string, not counting a potential trailing ellipsis.
getMaxTaskQueueSize() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Return the size limit of the cascades planner task queue.
getMaxTotalTaskCount() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Return the limit on the number of tasks that can be executed as part of the cascades planner planning.
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.OnlineIndexOperationBaseBuilder
Get the approximate maximum transaction write size.
getMaxWriteLimitBytes() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
Stop scanning if the write size (bytes) becomes bigger that this value.
getMaybe(Class<? extends T>) - Method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
Retrieve the wrapped result by attempting it to cast it to the given class.
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.OnlineIndexOperationBaseBuilder
Get the logging context used during the online index operation.
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 class com.apple.foundationdb.record.query.plan.cascades.Reference
 
getMergeRequiredIndexes() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Return a set of indexes that need a deferred index merge operation.
getMergesFound() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Report the number of merges found.
getMergesLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Limit the number of merges that may be attempted in a single transaction.
getMergesTried() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Report the number of merges attempted in a single transaction.
getMessage() - Method in exception com.apple.foundationdb.record.logging.CompletionExceptionLogHelper.IgnoredSuppressedExceptionCount
 
getMessage() - Method in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
getMessage() - Method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
 
getMessageDescriptor(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Gets the protobuf message descriptor for the given message type.
getMessageDescriptor(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Gets the protobuf message descriptor for the given message type.
getMessageMaybe() - Method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
 
getMessageTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Returns the message types registered with the schema.
getMessageWithKeys() - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
 
getMetadata() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.PathValue
If the PathValue was returned by the DirectoryLayerDirectory or some other directory type that involves a LocatableResolver, this will return any metadata that is associated with the key in by LocatableResolver.
getMetadata() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverResult
 
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 the FDBMetaDataStore to use as the source of meta-data.
getMetaDataStore() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
 
getMetaDataVersion() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
getMetaDataVersion() - Method in interface com.apple.foundationdb.record.sorting.FileSortAdapter
Get the version of the meta-data used to save the file.
getMetaDataVersionStamp(IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
getMetaDataVersionStampAsync(IsolationLevel) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Get the database's meta-data version-stamp.
getMetrics(QueryPredicate) - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer
 
getMinArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
 
getMinArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
Get the minimum number of arguments supported by this function.
getMinArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression
 
getMinArguments() - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
getMinCardinality() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty.Cardinalities
 
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
 
getMinFileRecordCount() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
getMinFileRecordCount() - Method in interface com.apple.foundationdb.record.sorting.FileSortAdapter
Get the mimimum number of records needed to write a file.
getMinLength(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
getMinLength(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
getMinLengths() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
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
 
getMode() - Method in class com.apple.foundationdb.record.PlanSerializationContext
 
getMode() - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer
Get the mode of this normalizer.
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
The Indexes 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.TextCollatorRegistry
Get the name of this collator registry.
getName() - Method in class com.apple.foundationdb.record.provider.common.text.TextCollatorRegistryJRE
 
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.keyspace.KeySpaceDirectory
Returns the name of this directory.
getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.Resolved
 
getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedIndexKeyspace
 
getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedKeyField
 
getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedPath
 
getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRecordStoreKeyspace
 
getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRecordTypeKeyspace
 
getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRoot
 
getName() - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
The name for each property needs to be unique and in a reverse FQDN format according to the package it is located.
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.QueryKeyExpressionWithOneOfComparison
 
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.cascades.AggregateIndexMatchCandidate
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.AbstractNode
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceHeadNode
 
getName() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
Returns the name of the match candidate.
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate.UsedIndex
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum.EnumValue
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.Accessor
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RankValue
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
getName() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
getName() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo.QueryPlanInfoKey
 
getName() - Method in class com.apple.foundationdb.record.RecordFunction
 
getName() - Method in class com.apple.foundationdb.record.util.ProtoUtils.DynamicEnum
 
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 from KeySpaceDirectory.toString() allows the directory implementation to ornament the name in any fashion it sees fit.
getNestedClusterProvider() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter.Cluster
 
getNestingAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.PullUp
 
getNestingExpression() - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordType.NestedConstituent
Expression that can generate instances of this constituent when evaluated on an instance of its parent.
getNestingExpression() - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordTypeBuilder.NestedConstituent
 
getNetwork() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph
 
getNetwork() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.PlannerGraphBuilder
 
getNetwork() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter.ExporterContext
 
getNetworkExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
getNewExpressions() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
getNewPartialMatches() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
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.cursors.RangeCursor
 
getNext() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase
 
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.
getNextDelayMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.runners.ExponentialDelay
 
getNextMinimumKey() - Method in class com.apple.foundationdb.record.sorting.MemoryScratchpad.LoadResult
 
getNextResult(List<KeyedMergeCursorState<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ComparatorCursor
 
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.
getNextResult(List<KeyedMergeCursorState<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnionCursor
Get the result from the list of chosen states.
getNlevels() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
 
getNLevels() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboard
 
getNodeForIdentity(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph
 
getNodeInfo() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.NodeWithInfo
 
getNodeInfos() - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
getNodeLabel(Attribute, Attribute, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.DotExporter
 
getNodes() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter.Cluster
 
getNodeSubspace(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
 
getNoNextReason() - Method in class com.apple.foundationdb.record.RecordCursorIterator
Get the reason that the cursor has reached the end and returned false for RecordCursorIterator.hasNext().
getNoNextReason() - Method in class com.apple.foundationdb.record.RecordCursorResult
Return the no-next-reason of this result.
getNonSynchronizedRunner() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
getNormalFormFullSize() - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer.PredicateMetrics
 
getNormalFormMaximumNumMinors() - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer.PredicateMetrics
 
getNormalFormSize() - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer.PredicateMetrics
 
getNotCommittedConflictingKeys() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Get key ranges that encountered conflicts when trying to FDBRecordContext.commit() failed due to NOT_COMMITTED.
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
 
getNumber() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum.EnumValue
 
getNumber() - Method in class com.apple.foundationdb.record.util.ProtoUtils.DynamicEnum
 
getNumBoundParameterPrefix() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getNumericCode() - Method in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
getNumericVersion() - Method in enum com.apple.foundationdb.record.PlanHashable.PlanHashMode
Returns a numeric version.
getNumIndexFilters() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
getNumNonSargables() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
getNumResiduals() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
getNumSkippedMappings() - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor.Result
 
getNumSkippedMappings() - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor.State
 
getObject() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.ToStringToken
 
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
 
getOnEmptyResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
getOnEmptyResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
getOnEmptyResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
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.IndexComparison.SimpleComparison
 
getOperand() - Method in class com.apple.foundationdb.record.metadata.IndexRecordFunction
 
getOption(String) - Method in class com.apple.foundationdb.record.metadata.Index
 
getOptionalFieldNames() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
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 to setTraceFormat().
getOrCreateCommitCheck(String, Function<String, FDBRecordContext.CommitCheckAsync>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Fetches a pre-commit check, creating a new one if it does not already exist.
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.
getOrDefault(Object, Equivalence.Wrapper<V>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
getOrDefaultUnwrapped(Object, V) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
getOrdering() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
getOrderingAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
getOrderingAliases() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
Returns the parameter names for the resulting order for parameters that can be bound during matching (sargable and residual).
getOrderingAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
getOrderingAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getOrderingAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
getOrderingParts() - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
 
getOrderingSet() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
getOrderPreservingKind() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Ordering.DirectOrderPreservingValue
 
getOrderPreservingKind() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Ordering.InverseOrderPreservingValue
 
getOrderPreservingKind() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Ordering.OrderPreservingValue
 
getOrderPreservingKind() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
getOrderPreservingKind() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
getOrderPreservingKindExclusive() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Ordering.DirectOrderPreservingValue
 
getOrderPreservingKindExclusive() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Ordering.InverseOrderPreservingValue
 
getOrdinal() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.Accessor
 
getOrdinal() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
getOrdinalPath() - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.FieldData
 
getOrdinalWithParent() - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor.State
 
getOriginalQueryPredicate() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
getOriginalQueryPredicate() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.MappingKey
 
getOrRegisterSingleton(Object) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
getOrToUnionMaxNumConjuncts() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Returns the maximum number of conjuncts whose combinations are enumerated when PredicateToLogicalUnionRule is applied.
getOtherAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
 
getOtherAliasToElementMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
 
getOtherDependsOnMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
 
getOtherElementToAliasFn() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
 
getOtherFields(KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.planning.TextScanPlanner
 
getOuterQuantifier() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
getOwnTimeInNs() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Stats
 
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 interface com.apple.foundationdb.record.query.expressions.Comparisons.ComparisonWithParameter
 
getParameter() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
getParameter1() - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph.Relationship
 
getParameter2() - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph.Relationship
 
getParameterAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
getParameterAlias() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.WithAlias
Returns the alias.
getParameterAliasOptional() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
getParameterBindingMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
getParameterId() - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedOrderingPart
 
getParameterName() - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
getParameterRelationshipGraph() - Method in class com.apple.foundationdb.record.query.BoundRecordQuery
 
getParameters() - Method in class com.apple.foundationdb.record.query.BoundRecordQuery
 
getParameterTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
 
getParameterTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfFunction
 
getParent() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
 
getParent() - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordType.NestedConstituent
The immediate parent of this constituent.
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.KeySpaceTreeResolver.Resolved
 
getParent() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
Returns the parent path element.
getParentConstituent() - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordType
Get the constituent of this type which represents the base FDBStoredRecord.
getParentExpressions(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal
Return all expressions (as RelationalExpressions) that refer to this expression reference.
getParentName() - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordType.NestedConstituent
Get the name of this constituent's parent.
getParentName() - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordTypeBuilder.NestedConstituent
 
getParentPullUp() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.PullUp
 
getParentRefPaths(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal
Return all expressions (as Traversal.ReferencePaths) that refer to this expression reference.
getParentRefs(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal
Return all expression references that contain a path.
getPartialMatch() - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.MatchIntermediateRule.PartialMatchWithQuantifier
 
getPartialMatches() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchPartition
 
getPartialMatchesForCandidate(MatchCandidate) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Return all partial matches for the MatchCandidate passed in.
getPartialMatchesForExpression(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Return all partial matches that match a given expression.
getPartialMatchMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
getPartialMatchRules() - Method in class com.apple.foundationdb.record.query.plan.cascades.PlannerRuleSet
 
getPartialMatchRules(Predicate<CascadesRule<? extends PartialMatch>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PlannerRuleSet
 
getPartialOrder() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet.EligibleSet
 
getPartialToFinalFunction() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
 
getPartialToFinalFunction() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
getPartialToPartialFunction() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
 
getPartialToPartialFunction() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
getPartitioningValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
getPath() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.Resolved
 
getPermutedSize(Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.PermutedMinMaxIndexMaintainer
 
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.
getPipelineOperation() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getPipelineOperation() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan
 
getPipelineOperation() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
 
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 the object to 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
 
getPlaceholderAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
getPlaceholders() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
getPlaceholders() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Sealed
 
getPlan() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanResult
 
getPlan() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
Make callers get the plan in a more readable way.
getPlanComparison(QueryRecordFunctionWithComparison) - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons
 
getPlanContext() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.CandidateScan
 
getPlanInfo() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanResult
 
getPlannerAttributeForAllPlans(PlanProperty<P>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PropertiesMap
Returns a map from RecordQueryPlan to a computed specific property value for a PlanProperty passed in.
getPlannerAttributeForMembers(PlanProperty<A>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
getPlannerConfiguration() - Method in class com.apple.foundationdb.record.query.plan.cascades.MetaDataPlanContext
 
getPlannerConfiguration() - Method in interface com.apple.foundationdb.record.query.plan.cascades.PlanContext
 
getPlannerConstraint(PlannerConstraint<T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
getPlannerGraphDetails(ImmutableList.Builder<String>, ImmutableMap.Builder<String, Attribute>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
getPlannerGraphDetails(ImmutableList.Builder<String>, ImmutableMap.Builder<String, Attribute>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScanParameters
Get details for graph visualization, including the scan type.
getPlannerGraphDetails(ImmutableList.Builder<String>, ImmutableMap.Builder<String, Attribute>) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons
 
getPlannerGraphDetails(ImmutableList.Builder<String>, ImmutableMap.Builder<String, Attribute>) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
getPlannerRuleClassStatsMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.StatsMaps
 
getPlanOrderingKey() - Method in interface com.apple.foundationdb.record.query.plan.PlanWithOrderingKey
 
getPlanPartitions() - Method in class com.apple.foundationdb.record.query.plan.cascades.PropertiesMap
 
getPlanPartitions() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
getPlans() - Method in class com.apple.foundationdb.record.query.plan.cascades.PlanPartition
 
getPlanSerializationRegistry() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
 
getPlanSerializationRegistry() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Method to return the PlanSerializationRegistry in use.
getPoolSize(K) - Method in class com.apple.foundationdb.record.provider.common.MappedPool
Pool size for the key.
getPossibleTypes(Index) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
 
getPostCommit(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Fetches a previously installed post-commit hook.
getPrecedence() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
getPrecedence() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence
 
getPrecedenceOrdinal() - Method in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
getPredicate() - Method in class com.apple.foundationdb.record.metadata.Index
Returns the predicate associated with the index in case of a filtered (sparse) index.
getPredicate() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcherWithPredicate
 
getPredicate() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
getPredicateCompensation() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
getPredicateCompensationMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.Compensation.ForMatch
 
getPredicateCompensationMap() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
 
getPredicateMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
getPredicates() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
getPredicates() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionWithPredicates
 
getPredicates() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
getPredicates() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
getPredicates() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Sealed
 
getPredicates() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
getPrefixAndDimensionsKeyExpression() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
getPrefixLength() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
getPrefixRange() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds
 
getPrefixScanComparisons() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
getPrefixSize() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
getPrefixSize() - Method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
 
getPrefixSubKey() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
getPreWriteChecks() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverCreateHooks
 
getPrimaryDatacenter(FDBDatabaseRunner) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBSystemOperations
Get the primary datacenter of the underlying cluster.
getPrimaryDatacenterAsync(FDBDatabaseRunner) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBSystemOperations
Get the primary datacenter of the underlying cluster.
getPrimaryIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
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 class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
getPrimaryKey() - Method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
 
getPrimaryKey() - Method in exception com.apple.foundationdb.record.RecordIndexUniquenessViolation
Get the primary key of this uniqueness violation.
getPrimaryKeyBoundaries(TupleRange) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
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.
getPrimaryKeyFieldMap(RecordType, Index, KeyExpression, int, List<KeyExpression>, ImmutableMap<String, ImmutableIntArray>, IndexKeyValueToPartialRecord.Builder) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields
 
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
 
getPrimaryKeyValuesMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
getPrimaryKeyValuesMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getPrimaryKeyValuesMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
getPrimaryKeyValuesMaybe() - Method in interface com.apple.foundationdb.record.query.plan.cascades.WithPrimaryKeyMatchCandidate
 
getPrintWriter() - Method in class com.apple.foundationdb.record.query.plan.cascades.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
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.OnlineIndexOperationBaseBuilder
Get the priority of transactions used for this index build.
getProgressLogIntervalMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Get the minimum time between successful progress logs when building across transactions.
getProgressLogIntervalMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Get the minimum time between successful progress logs when building across transactions.
getProgressLogIntervalMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
Get the minimum time between successful progress logs when building across transactions.
getProjectedValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
getPropertiesForPlan(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.PropertiesMap
Returns the properties currently stored in the properties map for the given plan.
getPropertyMap() - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyStorage
 
getPropertyOrElse(PlannerConstraint<T>, T) - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
Method to return an optional constraint given an attribute key passed in or an alternative default constraint.
getPropertyOrThrow(PlannerConstraint<T>, Supplier<? extends X>) - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
Method to return a constraint given an attribute key passed in or to throw an exception.
getPropertyStorage() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Get the properties configured by adopter for this FDBRecordContext.
getPropertyStorage() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
Get the properties for this context configured by adopter.
getPropertyValue(RecordLayerPropertyKey<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyStorage
 
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.
getProtoMessageClass() - Method in interface com.apple.foundationdb.record.PlanDeserializer
Returns M.class.
getProtoMessageClass() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.ConditionalUponPathPredicate.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.TruePredicate.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MaxEverValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MinEverValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Avg.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.BitmapConstructAgg.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Max.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Min.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Sum.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.ArrayCoercionBiFunction.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.PrimitiveCoercionBiFunction.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RankValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.BinaryRelOpValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.UnaryRelOpValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldWithValueCopier.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.MessageCopier.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan.Deserializer
 
getProtoMessageClass() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan.Deserializer
 
getProtoType() - Method in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
Returns the corresponding protobuf DescriptorProtos.FieldDescriptorProto.Type of the Type instance.
getProtoTypeName(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Returns the protobuf type name of the given Type.
getPulledUpPredicateMappings(Predicate<QueryPredicate>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getPulledUpPredicateMappings(Set<QueryPredicate>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getPullThroughValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.PullUp
 
getPushValueFunction() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
getQuantifier() - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.MatchIntermediateRule.PartialMatchWithQuantifier
 
getQuantifier() - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal.ReferencePath
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUnionExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUniqueExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
getQuantifiers() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Return an iterator of references to the children of this planner expression.
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Sealed
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
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 class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
getQuantifiers() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithNoChildren
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
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.plans.TempTableInsertPlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
getQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
getQueriedRecord() - Method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
Retrieve the wrapped result by attempting it to cast it to the giving class.
getQueriedRecordMaybe() - Method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
Retrieve the wrapped result by attempting it to cast it to the giving class.
getQueriedRecordType() - Method in class com.apple.foundationdb.record.query.plan.cascades.ScanWithFetchMatchCandidate.IndexEntryToLogicalRecord
 
getQueriedRecordTypeNames() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
getQueriedRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
getQueriedRecordTypes() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
getQueriedRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
getQueriedRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getQueriedRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
getQueryableRecordType(String) - Method in class com.apple.foundationdb.record.RecordMetaData
Get a record type or synthetic record type by name as used in a query.
getQueryExpression() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getQueryPlanChildren() - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
Returns the (zero or more) child QueryPlans of this plan.
getQueryPlanChildren() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
 
getQueryPlanConstraint() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.MaxMatchMap
 
getQueryRef() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getQueryValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.MaxMatchMap
 
getRange(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRange(byte[], byte[], int) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(byte[], byte[], int) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRange(byte[], byte[], int, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(byte[], byte[], int, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRange(byte[], byte[], int, boolean, StreamingMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(byte[], byte[], int, boolean, StreamingMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRange(KeySelector, KeySelector) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(KeySelector, KeySelector) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRange(KeySelector, KeySelector, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(KeySelector, KeySelector, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRange(KeySelector, KeySelector, int, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(KeySelector, KeySelector, int, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRange(KeySelector, KeySelector, int, boolean, StreamingMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(KeySelector, KeySelector, int, boolean, StreamingMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRange(Range) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(Range) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRange(Range, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(Range, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRange(Range, int, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(Range, int, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRange(Range, int, boolean, StreamingMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRange(Range, int, boolean, StreamingMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRangedOverAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.MaxMatchMap
 
getRangedOverAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.PullUp
 
getRanges() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
getRanges() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
getRangesOver() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Existential
 
getRangesOver() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach
 
getRangesOver() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Return the reference that the quantifier ranges over.
getRangesOver() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
getRangesOverPlan() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
getRangeSplitPoints(byte[], byte[], long) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRangeSplitPoints(byte[], byte[], long) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRangeSplitPoints(Range, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getRangeSplitPoints(Range, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
getRangeType() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
getRank() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer.TimeWindowRankAndEntry
 
getRanks() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
 
getRankTypes() - Method in class com.apple.foundationdb.record.query.plan.PlannableIndexTypes
 
getRawRecord() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRawRecord
 
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() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
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 the FDBRecordContext within which this store operates.
getRecordContextProperties() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Get the properties' wrapper to be used by this context to pass in the parameters configured by adopter.
getRecordCountForRebuildIndexes(boolean, boolean, Map<Index, List<RecordType>>, RecordType) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Get count of records to pass to a FDBRecordStoreBase.UserVersionChecker to decide whether to build right away.
getRecordCountInMemoryLimitMode() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
getRecordCountInMemoryLimitMode() - Method in interface com.apple.foundationdb.record.sorting.MemorySortAdapter
Get action to perform when in-memory map is full.
getRecordCountKey() - Method in class com.apple.foundationdb.record.RecordMetaData
 
getRecordCountKey() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
Deprecated.
use COUNT type indexes instead
getRecordCountPerSection() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
getRecordCountPerSection() - Method in interface com.apple.foundationdb.record.sorting.FileSortAdapter
Get the maximum number of files in a section.
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.FDBMetaDataStore
 
getRecordMetaData() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Get the RecordMetaData used by this store.
getRecordMetaData() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
getRecordMetaData() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRecordStoreKeyspace
 
getRecordMetaData() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
 
getRecordMetaData() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
 
getRecordMetaData() - Method in interface com.apple.foundationdb.record.query.plan.QueryPlanner
Get the RecordMetaData for this planner.
getRecordMetaData() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
Get the RecordMetaData for this planner.
getRecordMetaData() - Method in class com.apple.foundationdb.record.RecordMetaData
Get this RecordMetaData instance.
getRecordMetaData() - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
 
getRecordMetaData() - Method in interface com.apple.foundationdb.record.RecordMetaDataProvider
Provide an instance of RecordMetaData.
getRecordMetaDataAsync(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
 
getRecordPosition() - Method in class com.apple.foundationdb.record.sorting.SortedFileReader
 
getRecordQuery() - Method in class com.apple.foundationdb.record.query.BoundRecordQuery
 
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
 
getRecordSectionPosition() - Method in class com.apple.foundationdb.record.sorting.SortedFileReader
 
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.OnlineIndexOperationBaseBuilder
Get the maximum number of records to process in a single second.
getRecordsPerSecond() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Get the maximum number of records to process in a single second.
getRecordsPerSecond() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
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.IndexingCommon
 
getRecordStoreBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
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.keyspace.KeySpaceTreeResolver.ResolvedRecordStoreKeyspace
 
getRecordStoreMetaData(KeySpaceTreeResolver.Resolved, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver
getRecordStoreState() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Get the RecordStoreState for this store.
getRecordStoreState() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Get the RecordStoreState for this store.
getRecordStoreState() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
getRecordStoreState() - Method in class com.apple.foundationdb.record.provider.foundationdb.storestate.FDBRecordStoreStateCacheEntry
Get the RecordStoreState contained within this entry.
getRecordStoreState() - Method in class com.apple.foundationdb.record.query.BoundRecordQuery
 
getRecordStoreState() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
 
getRecordStoreState() - Method in interface com.apple.foundationdb.record.query.plan.QueryPlanner
Get the RecordStoreState for this planner.
getRecordStoreState() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
Get the RecordStoreState for 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.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.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRecordTypeKeyspace
 
getRecordType() - Method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
 
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 the Tuple element value that will be used by RecordTypeKeyExpression for this record type.
getRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
 
getRecordTypeKey() - Method in interface com.apple.foundationdb.record.metadata.RecordTypeOrBuilder
Gets the Tuple element value that will be used by RecordTypeKeyExpression for this record type.
getRecordTypeKeyTuple() - Method in class com.apple.foundationdb.record.metadata.RecordType
Get a Tuple containing only the record type key.
getRecordTypeNames() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
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.cascades.expressions.FullUnorderedScanExpression
 
getRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
getRecordTypes() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
getRecordTypes() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.TypeFilterExpression
 
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.RecordQuery.Builder
 
getRecordTypes() - Method in class com.apple.foundationdb.record.query.RecordQuery
 
getRecordTypes() - Method in class com.apple.foundationdb.record.RecordMetaData
 
getRecursiveStateQuantifier() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
getRecursiveUnionTempTable() - Method in interface com.apple.foundationdb.record.cursors.RecursiveUnionCursor.RecursiveStateManager
Retrieve the TempTable that is owned by the RecordQueryRecursiveUnionPlan.
getReference() - Method in interface com.apple.foundationdb.record.query.plan.cascades.explain.Attribute
Return the underlying object this attribute refers to.
getReference() - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal.ReferencePath
 
getReferencedFieldValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.ReferencedFieldsConstraint.ReferencedFields
 
getReferencePlanIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ComparatorCursor
 
getReferenceState(List<KeyedMergeCursorState<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ComparatorCursor
 
getReferencesWithPushedRequirements() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
getRefreshTimeMillis() - Method in class com.apple.foundationdb.record.AsyncLoadingCache
Get the amount of time between cache refreshes in milliseconds.
getRefreshTimeSeconds() - Method in class com.apple.foundationdb.record.AsyncLoadingCache
Get the amount of time between cache refreshes in seconds.
getRefs() - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal
 
getRefsContaining(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal
Returns all references containing the expression passed in.
getRegistry() - Method in class com.apple.foundationdb.record.PlanSerializationContext
 
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
 
getRegularMatchInfo() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedMatchInfo
 
getRegularMatchInfo() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchInfo
 
getRegularMatchInfo() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
getRegularMatchInfo() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getRelatedParameters(String, ParameterRelationshipGraph.RelationshipType) - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUnionExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUniqueExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
getRelationalChildCount() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionWithChildren
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
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.RecordQueryRecursiveUnionPlan
 
getRelationalChildCount() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
 
getRelationshipKind() - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph.Relationship
 
getRemainder() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
getRemainder() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
Deprecated.
getRemainder() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedAndRemainder
The suffix of a Tuple representing unmatched fields from the KeySpace.
getRemainder() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
If this path was created via KeySpace.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.
getRepartitionDocumentCount() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Max number of documents to move during repartitioning (per partition).
getRepeatedFieldName() - Static method in class com.apple.foundationdb.record.query.plan.cascades.NullableArrayTypeUtils
Get the fieldName of the repeated field.
getReplacedByIndexNames() - Method in class com.apple.foundationdb.record.metadata.Index
Get a list of index names that are replacing this index.
getRequestedOrdering() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
Returns the ordering requirements of the underlying scan for the group by to work.
getRequiredFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan
 
getRequiredFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
getRequiredFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan
 
getRequiredFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
getRequiredFields() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan
 
getRequiredFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan
 
getRequiredFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
getRequiredFields() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
 
getRequiredResults() - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
 
getRequiredResults() - Method in class com.apple.foundationdb.record.query.RecordQuery
 
getRequiredValues(CorrelationIdentifier, Type) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
getRequiredValues(CorrelationIdentifier, Type) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
getRequiredValues(CorrelationIdentifier, Type) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan
Method that returns a list of values that are required to be evaluable by this set-based plan operator.
getRequiredValues(CorrelationIdentifier, Type) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
getResidualComparisons() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange.MergeResult
 
getResolved() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedAndRemainder
A KeySpaceTreeResolver.Resolved key space path, etc.
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.keyspace.KeySpaceTreeResolver.Resolved
 
getResolvedPath() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.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.keyspace.KeySpaceTreeResolver.Resolved
 
getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedIndexKeyspace
 
getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedKeyField
 
getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedPath
 
getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRecordStoreKeyspace
 
getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRecordTypeKeyspace
 
getResolvedValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.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
 
getResult(QueryPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateComputationRuleCall
 
getResult(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRuleCall
 
getResultColumns() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
getResultColumns() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Sealed
 
getResultCompensationFunction() - Method in class com.apple.foundationdb.record.query.plan.cascades.Compensation.ForMatch
 
getResultCompensationFunction() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
 
getResults() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
getResultType() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Method that resolves the result type by looking and unifying the result types from all the members.
getResultType() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Typed
Returns the Type of the result set.
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
getResultType() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.BooleanValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RankValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfValue
 
getResultType() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Returns the Type of the scalar value output.
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
getResultType() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
getResultType() - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
getResultTypeCode() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
getResultTypeCode() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
 
getResultTypeCode() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUnionExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUniqueExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
getResultValue() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
getResultValue() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
getResultValueFunction() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
getResultValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
getResultValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Sealed
 
getResultValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.Derivations
 
getReturnedRowLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
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.Builder
 
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.
getReusedExpressionReferences() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
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
 
getReverseValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator.ValidatedEntry
The key found in the reverse directory associated with the value found in the forward mapping.
getRight() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordType.Join
 
getRight() - Method in class com.apple.foundationdb.record.metadata.JoinedRecordTypeBuilder.Join
 
getRight() - Method in class com.apple.foundationdb.record.util.pair.ComparablePair
 
getRight() - Method in class com.apple.foundationdb.record.util.pair.ImmutablePair
 
getRight() - Method in class com.apple.foundationdb.record.util.pair.NonnullPair
 
getRight() - Method in interface com.apple.foundationdb.record.util.pair.Pair
Get the right element of the pair.
getRightArgType() - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
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.cascades.CascadesRuleCall
 
getRoot() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph
 
getRoot() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.PlannerGraphBuilder
 
getRoot() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
getRootClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AllOfMatcher
 
getRootClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AnyOfMatcher
 
getRootClass() - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
Get a class that this matcher can match.
getRootClass() - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.CollectionMatcher
 
getRootClass() - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.ContainerMatcher
 
getRootClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.InstanceMatcher
 
getRootClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.NotMatcher
 
getRootClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.OptionalIfPresentMatcher
 
getRootClass() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcher
 
getRootExpression() - Method in class com.apple.foundationdb.record.metadata.Index
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRule
Returns the class of the operator at the root of the binding expression, if this rule uses a non-trivial binding.
getRootOperator() - Method in interface com.apple.foundationdb.record.query.plan.cascades.PlannerRule
Returns the class of the operator at the root of the binding expression, if this rule uses a non-trivial binding.
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AbsorptionRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AnnulmentAndRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AnnulmentOrRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DeMorgansTheoremRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.IdentityAndRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.IdentityOrRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.NormalFormRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.NotOverComparisonRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.MatchIntermediateRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.MatchLeafRule
Note: Transformation rules for expressions are partitioned by the class of the root matcher.
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRule
Returns the class of the operator at the root of the binding expression, if this rule uses a non-trivial binding.
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.CompensateToOrderedBytesValueRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.DefaultOrderingPartRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExpandRecordRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.FoldConstantRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchConstantValueRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchFieldValueOverFieldValueRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchSimpleFieldValueRule
 
getRootOperator() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchValueRule
 
getRootPullUp() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.PullUp
 
getRootReference() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.AbstractEventWithState
 
getRootReference() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.EventWithState
Getter.
getRootReference() - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal
 
getRule() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.EventWithRule
Return the rule.
getRule() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformEvent
 
getRule() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformRuleCallEvent
 
getRule() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
getRuleCall() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformRuleCallEvent
 
getRunner() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
getRunner() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
getRunner() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Get the runner that will be used to call into the database.
getSargableAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
getSargableAliases() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
Returns a list of parameter names for sargable parameters that can to be bound during matching.
getSargableAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
getSargableAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getSargableAliases() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
getSargedInBindings() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
getSavedStamp() - Method in exception com.apple.foundationdb.record.provider.foundationdb.IndexingBase.PartlyBuiltException
 
getSavedStampString() - Method in exception com.apple.foundationdb.record.provider.foundationdb.IndexingBase.PartlyBuiltException
 
getScanComparisons() - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons.RankComparison
 
getScanComparisons() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
getScanComparisons() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
getScanComparisons() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithComparisons
 
getScanComparisons() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
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.
getScanParameters() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
getScanRange() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanRange
 
getScanType() - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScanBounds
Get the type of index scan to be performed.
getScanType() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
getScanType() - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScanParameters
Get the type of index scan to be performed.
getScanType() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanRange
 
getScanType() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds
 
getScanType() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
getScanType() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
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
 
getScheduledExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
Get an executor service that can be used for scheduling tasks.
getScheduledExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Get a scheduled executor.
getScheduledExecutor() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
Get the scheduled executor to use to schedule return delays.
getScheduledExecutor() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
Get the scheduled executor to use when scheduling delayed tasks in the context of this transaction.
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.
getSecureRandom() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
getSecureRandom() - Method in interface com.apple.foundationdb.record.sorting.FileSortAdapter
Get source of randomness for encryption.
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
 
getSet() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
getShape() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Node
 
getShape() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceHeadNode
 
getShape() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceMemberNode
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.AdjustMatchEvent
 
getShorthand() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Event
Getter.
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExecutingTaskEvent
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreExpressionEvent
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreGroupEvent
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeGroupEvent
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeInputsEvent
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformEvent
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformRuleCallEvent
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TranslateCorrelationsEvent
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Existential
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach
 
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Return a shorthand string for the quantifier.
getShorthand() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
getShouldCheckContinuationAccess() - Static method in class com.apple.foundationdb.record.cursors.IllegalContinuationAccessChecker
 
getSimplificationDependsOn() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRuleSet.TransformedRules
 
getSimplificationRules() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRuleSet.TransformedRules
 
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.
getSize(StoreTimer.SizeEvent) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
Get the total size for a given event.
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.
getSizeLimit() - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer
Get the limit on the size of the normalized form that this normalizer will produce.
getSizeQuotaBytes() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
If bigger than 0, define a size quota for agility context (i.e.
getSkip() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
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 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, IndexQueryabilityFilter) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
getSnapshotRecordCount(KeyExpression, Key.Evaluated, IndexQueryabilityFilter) - 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, IndexQueryabilityFilter) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
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, IndexQueryabilityFilter) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
getSnapshotRecordCountForRecordType(String, IndexQueryabilityFilter) - 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, IndexQueryabilityFilter) - 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
 
getSnapshotRecordUpdateCount(KeyExpression, Key.Evaluated, IndexQueryabilityFilter) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
 
getSort() - Method in class com.apple.foundationdb.record.query.RecordQuery.Builder
 
getSort() - Method in class com.apple.foundationdb.record.query.RecordQuery
 
getSortConfiguration() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Get configuration for planning sorting, including whether the planner is allowed to use an in-memory sort plan.
getSortKey(KeyExpression, boolean) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryPlannerSortConfiguration
Get the sort key for the given key expression and direction.
getSortOrder() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Binding
 
getSortOrder() - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart
 
getSortParameterIds() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
getSource() - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.FieldData
 
getSource(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Get the source for a target passed in.
getSourceContinuation() - Method in class com.apple.foundationdb.record.sorting.FileSorter.LoadResult
 
getSourceContinuation() - Method in class com.apple.foundationdb.record.sorting.MemoryScratchpad.LoadResult
 
getSourceIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
If active, get the source index.
getSourceIndexSubspaceKey() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
 
getSourceNoNextReason() - Method in class com.apple.foundationdb.record.sorting.FileSorter.LoadResult
 
getSourceNoNextReason() - Method in class com.apple.foundationdb.record.sorting.MemoryScratchpad.LoadResult
 
getSourceOrDefault(CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Get the source for a target passed in or a default in case there is no mapping for the target alias.
getSourceOrThrow(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Get the source for a target passed in or throw an exception in case there is no mapping for the target alias.
getSpatialPredicate() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds
 
getSpecs() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
 
getSplitPoint() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
 
getSplitPointForValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
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.
getStateCacheabilityOnOpen() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
 
getStateCacheabilityOnOpen() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Determines what happens to the store state cacheability flag when the store is opened.
getStateCacheabilityOnOpen() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
Get how the store state cacheability should be modified during store opening.
getStateCacheabilityOnOpen() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
 
getStateDesiredAction(IndexState) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
Get the appropriate desired action for a given index state.
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>>, Supplier<CompletableFuture<Long>>, Supplier<CompletableFuture<Long>>, 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
 
getStatsMaps() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
getStoppedReason() - Method in class com.apple.foundationdb.record.cursors.CursorLimitManager
Report a single reason associated with a limit that has been exceeded.
getStoredFields(List<KeyExpression>, List<KeyExpression>, List<KeyExpression>) - Method in interface com.apple.foundationdb.record.query.plan.PlanWithStoredFields
Adjust the set of fields available from an index entry scanned by this plan.
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
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.
getStreamingMode() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
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.cascades.explain.PlannerGraph.DataNodeWithInfo
 
getStyle() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Edge
 
getStyle() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.LogicalOperatorNode
 
getStyle() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.LogicalOperatorNodeWithInfo
 
getStyle() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationOperatorNodeWithInfo
 
getStyle() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Node
 
getStyle() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.PartialMatchEdge
 
getStyle() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.PhysicalQuantifierEdge
 
getStyle() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceHeadNode
 
getStyle() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceInternalEdge
 
getStyle() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceMemberNode
 
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
 
getSubFilter() - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
 
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 based on the column indexes into the expression.
getSubKey(KeyExpression, int, int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
 
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.DimensionsKeyExpression
 
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 with FDBRecordContext.
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 a Tuple-encodable version of the subspace key formerly occupied by the index.
getSubspaceTupleKey() - Method in class com.apple.foundationdb.record.metadata.Index
Get a Tuple-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.
getSuffixRange() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds
 
getSuffixScanComparisons() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
getSuffixSize() - Method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
 
getSymbolForAlias(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.DefaultExplainSymbolMap
 
getSymbolForAlias(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainSelfContainedSymbolMap
 
getSymbolForAlias(CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainSymbolMap
 
getSymbolForAliasMaybe(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.DefaultExplainFormatter
 
getSymbolForAliasMaybe(CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
getSynchronizedSessionRunner() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
getSyntheticRecord() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
Get the synthetic record if this is a synthetic record type..
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
 
getTags() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Get tags used for throttling.
getTags() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
Get tags used for throttling.
getTarget(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Get the target for a source passed in.
getTargetIndexContexts() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
getTargetIndexes() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
getTargetIndexesNames() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
getTargetOrDefault(CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Get the target for a source passed in or a default in case there is no mapping for the source alias.
getTargetOrThrow(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Get the target for a source passed in or throw an exception in case there is no mapping for the source alias.
getTargetRecordType() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getTargetType() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
getTargetType() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getTask() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExecutingTaskEvent
 
getTaskStack() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.AbstractEventWithState
 
getTaskStack() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.EventWithState
Getter.
getTempTable() - Method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor.Continuation
 
getTempTableFactory() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Returns a transaction-bound factory of TempTables.
getTempTableInsertAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
getTempTableInsertAlias() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
getTempTableReferenceValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
getTempTableReferenceValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
 
getTempTableReferenceValue() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
getTempTableReferenceValue() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
getTempTableScanAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
getTempTableScanAlias() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
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
 
getThenSubKey(ThenKeyExpression, int, int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
 
getThis() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.FieldAccessTrieNode
 
getThis() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.FieldAccessTrieNodeBuilder
 
getThis() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
getThis() - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Method to get a T-typed this.
getThis() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.CoercionTrieNode
 
getThis() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.TransformationTrieNode
 
getThis() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
getThis() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
getThis() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredMatch
 
getThis() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
 
getThreadsPerClientVersion() - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Deprecated.
Call directly on FDBDatabaseFactoryImpl. This will be removed in a future release.
getThreadsPerClientVersion() - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
getTimeLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
getTimeLimit() - Method in class com.apple.foundationdb.record.ExecuteProperties
Get the time limit for query execution.
getTimeLimitMilliseconds() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Exit with exception if this limit is exceeded (checked after each non-final transaction).
getTimeLimitMilliseconds() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
Exit with exception if this limit is exceeded (checked after each non-final transaction).
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.
getTimeQuotaMillis() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
If bigger than 0, define a time quota for agility context (i.e.
getTimer() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
Get the FDBStoreTimer used 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.OnlineIndexOperationBaseBuilder
Get the timer used during the online index operation.
getTimerEvent() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBLatencySource
Get the event used to track this latency source by FDBStoreTimers.
getTimerForEvent(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
 
getTimerForEvent(StoreTimer.Event) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
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 the DefaultTextTokenizer singleton.
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
 
getTokenKind() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
getTokens() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
getTokenSize(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
getTokenSize(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
getTokenSizes() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
getTopAlias() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.PullUp
 
getTopReferenceMatcher() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ReferenceMatchers
 
getToRecord() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
getToRecord() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
getTotalMerges() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Return to the total number of merges attempted, yet hadn't failed.
getTotalRecordsScanned() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
getTotalRecordsScannedSuccessfully() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
getTotalRecordsScannedSuccessfully() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingThrottle
 
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.
getTotalTimeInNs() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Stats
 
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.
getTransaction() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
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
 
getTransactionIsTracedSupplier() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
getTransactionListener() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
getTransactionListener() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
Return the listener to be notified of transaction events.
getTransactionTimeLimitMilliseconds() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Get the time quota for a single transaction.
getTransactionTimeLimitMilliseconds() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
Get the time quota for a single transaction.
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.
getTransformationsTrie() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
getTransitiveClosure() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
getTranslatedQueryPredicate() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
getTraversal() - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
getTraversal() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
getTraversal() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
Returns the traversal object for this candidate.
getTraversal() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
getTraversal() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
getTraversal() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
getTupleDirection() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
 
getTupleDirection() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
 
getTupleDirection() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
 
getTupleDirection() - Method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
Get the corresponding tuple ordering direction.
getType() - Method in class com.apple.foundationdb.record.metadata.Index
Returns the type of the 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 class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
 
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.InvertedFunctionComparison
 
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.OpaqueEqualityComparison
 
getType() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
getType() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
getType() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
getType() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
getType() - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
getType() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
getType() - Method in class com.apple.foundationdb.record.query.QueryToKeyMatcher.Match
 
getType(Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.indexes.PermutedMinMaxIndexMaintainer
 
getTypeByName(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
getTypeCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
Returns the Type.TypeCode of the Type instance.
getTypeCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
Returns the Type.TypeCode of the Type instance.
getTypeCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
Returns the Type.TypeCode of the Type instance.
getTypeCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
getTypeCode() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Returns the Type.TypeCode of the Type instance.
getTypeCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
getTypeCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
getTypeCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive
 
getTypeCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Returns the Type.TypeCode of the Type instance.
getTypeCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
Returns the Type.TypeCode of the Type instance.
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
 
getTypeName(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
getTypeRepository() - Method in class com.apple.foundationdb.record.EvaluationContext
 
getTypeUrlPrefix() - Method in class com.apple.foundationdb.record.query.plan.serialization.DefaultPlanSerializationRegistry
 
getTypeUrlPrefix() - Method in interface com.apple.foundationdb.record.query.plan.serialization.PlanSerializationRegistry
 
getUnbuiltRange() - Method in exception com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.IndexNotBuiltException
Get the unbuilt range associated with this exception.
getUncommittedComparisonRanges() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
getUnderlying() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedMatchInfo
 
getUnexpectedReadableIfApplicable(Throwable) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
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
 
getUnmatchedForEachQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.Compensation.ForMatch
 
getUnmatchedForEachQuantifiers() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
 
getUnmatchedQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.Compensation.ForMatch
 
getUnmatchedQuantifiers() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
 
getUnmatchedQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
getUnsatisfiedFilter() - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
Construct a QueryComponent that is equal to the original QueryComponent but 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.
getUnstoredNonPrimaryKeyTypes() - Method in class com.apple.foundationdb.record.query.plan.PlannableIndexTypes
 
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.
getUnwrapped(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
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 class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
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.RecordQueryAggregateIndexPlan
 
getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
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.RecordQueryRangePlan
 
getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
 
getUsedIndexes() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
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 the function to be used to check the meta-data version of the record store.
getUserVersionChecker() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
 
getUuid() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
getValidationResult() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator.ValidatedEntry
 
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.metadata.IndexPredicate.ConstantPredicate
 
getValue() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.NotPredicate
 
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 to KeySpacePath.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.ResolverKeyValue
 
getValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverResult
 
getValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator.ValidatedEntry
The value for the key in the mapping.
getValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyValue
 
getValue() - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
getValue() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
getValue() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
getValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.Column
 
getValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart
 
getValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
getValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
getValue() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
getValue() - Method in interface com.apple.foundationdb.record.query.plan.cascades.WithValue
 
getValue() - Method in interface com.apple.foundationdb.record.util.pair.Pair
Alias of Pair.getRight().
getValue() - Method in class com.apple.foundationdb.record.util.Result
The value returned by the operation, if successful.
getValue() - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNode
 
getValue() - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNodeBuilder
 
getValue() - Method in interface com.apple.foundationdb.record.util.TrieNode
 
getValue(Key.Evaluated) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
Given a Key.Evaluated returned 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.
getValueEquivalence() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.MaxMatchMap
 
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.
getValueRequestedSortOrderMap() - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
Returns a map from Value to OrderingPart.RequestedSortOrder.
getValueRules(BASE) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleSet
 
getValueRules(BASE, Predicate<AbstractRule<RESULT, CALL, BASE, ? extends BASE>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleSet
 
getValues() - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
 
getValues() - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
getValues() - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
getValues(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
getValues(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
getValues(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
getValues(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
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.RecordQueryInValuesJoinPlan
 
getValues(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource
 
getValues(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
getValues(MessageOrBuilder) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
 
getValuesContexts(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
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
 
getValuesLimit() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
getValuesSize(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
getValuesWithRealEquals() - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
getValuesWithThrowable(Throwable) - Method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
 
getValueTypes() - Method in class com.apple.foundationdb.record.query.plan.PlannableIndexTypes
 
getValueValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
getVariadicSuffixType() - Method in class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
 
getVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
 
getVersion() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecord
Get the FDBRecordVersion associated with this record (or null).
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 this LocatableResolver.
getVersionNumber() - Method in enum com.apple.foundationdb.record.provider.foundationdb.APIVersion
Get the API version number.
getVersionstamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
getVersionstamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
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.cascades.explain.GraphExporter
 
getVertexID(N) - Method in class com.apple.foundationdb.record.query.plan.cascades.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.cascades.explain.GraphExporter
 
getVertexIds() - Method in class com.apple.foundationdb.record.query.plan.cascades.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 the FDBDatabase.WeakReadSemantics from this configuration.
getWeakReadSemantics() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
Get the FDBDatabase.WeakReadSemantics configuration used when creating the transaction.
getWeakReadSemantics() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Get the acceptable staleness bounds for transactions used by this build.
getWholeKey() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
getWholeKey() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
 
getWriteLimitBytes() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Stop scanning if the write size (bytes) becomes bigger that this value.
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 by FDBRecordVersion.
gml(Object) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.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.cascades.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.cascades.explain.GmlExporter
Constructs a new GmlExporter object with the given ID, label, attribute, and graph ID providers.
GraphExpansion - Class in com.apple.foundationdb.record.query.plan.cascades
Class to abstract behavior when query expansion is applied to query components or key expressions.
GraphExpansion.Builder - Class in com.apple.foundationdb.record.query.plan.cascades
Builder for GraphExpansion.
GraphExpansion.Sealed - Class in com.apple.foundationdb.record.query.plan.cascades
A sealed version of GraphExpansion that has already reconciled duplicate placeholders.
GraphExporter<N,E> - Class in com.apple.foundationdb.record.query.plan.cascades.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>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter
Constructs a new GraphExporter object with the given ID, label, attribute, and graph ID providers.
GraphExporter.Cluster<N,E> - Class in com.apple.foundationdb.record.query.plan.cascades.explain
This class represents a cluster with the additional ability to further subdivide the cluster into sub-clusters.
GraphExporter.ClusterProvider<N,E> - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Shorthand-type for the extended functional interface.
GraphExporter.ComponentAttributeProvider<T> - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Shorthand-type for the extended functional interface.
GraphExporter.ComponentIdProvider<T> - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Shorthand-type for the extended functional interface.
GraphExporter.ExporterContext - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Context class used while serializing the graph.
GREATER_THAN - Enum constant in enum com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison.ComparisonType
 
GREATER_THAN - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
GREATER_THAN_OR_EQUALS - Enum constant in enum com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison.ComparisonType
 
GREATER_THAN_OR_EQUALS - Enum constant in enum 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.QueryKeyExpression.OneOfThem
 
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.QueryKeyExpression.OneOfThem
 
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.
GREATEST - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.ComparisonFunction
 
GREATEST_BOOLEAN - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
GREATEST_DOUBLE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
GREATEST_FLOAT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
GREATEST_INT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
GREATEST_LONG - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
GREATEST_STRING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
GreatestFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.GreatestFn
 
GREEN - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
group(int) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
 
groupBy(KeyExpression, KeyExpression...) - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
 
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.FunctionKeyExpression
 
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
 
groupByExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
groupByExpression(BindingMatcher<? extends RecordConstructorValue>, CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
GroupByExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A logical group by expression that represents grouping incoming tuples and aggregating each group.
GroupByExpression(Value, AggregateValue, BiFunction<Value, Value, Value>, Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
Creates a new instance of GroupByExpression.
groupedComparisons(QueryComponent) - Static method in interface com.apple.foundationdb.record.query.expressions.BooleanComponent
Starting from an arbitrary query component collect all ComponentWithComparisons within the sub tree spanned by the queryComponent handed in and group each of these components with all comparisons referring to them.
groupedComparisonsMap(Stream<ComponentWithComparison>) - Static method in interface com.apple.foundationdb.record.query.expressions.BooleanComponent
 
GROUPING_KEY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
groupingKeyExpression - Variable in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexExpansionVisitor
 
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
 
groupings(BindingMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
groupKey(KeyExpression) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
 
groupOrderedScoreIndexKeys(Iterable<IndexEntry>, TimeWindowLeaderboardDirectory, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
Group the given indexKeys by group of size groupPrefixSize, ordering within each group by score, taking highScoreFirst into account from the directory or any sub-directory (if includesGroup is true).
GteFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.GteFn
 
GtFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.GtFn
 

H

handleNextCursorResult(RecordCursorResult<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
 
handleOneItem(FDBRecordStore, RecordCursorResult<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexScrubbingToolsDangling
 
handleOneItem(FDBRecordStore, RecordCursorResult<FDBStoredRecord<Message>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexScrubbingToolsMissing
 
handleOneItem(FDBRecordStore, RecordCursorResult<T>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScrubbingTools
Check the validity of a given a specific cursor item.
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.RecordQueryFilterPlanBase
 
hasAsyncFilter() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
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.
hasComparisonRanges() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
hasComparisonRanges() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
hasComparisonRanges() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithComparisons
 
hasComparisons() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithComparisons
 
hasData(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
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.
hasEdgeConnecting(EndpointPair<N>) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
hasEdgeConnecting(N, N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
hasExplicitRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.RecordType
Get whether this record type sets an explicit value for RecordType.getRecordTypeKey().
hasExplicitSubspaceKey() - Method in class com.apple.foundationdb.record.metadata.Index
Checks whether the subspace key was set using Index.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.RecordQueryAggregateIndexPlan
 
hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
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.RecordQueryRangePlan
 
hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
 
hasFullRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
HASH - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
HASH_FUNCTION - Enum constant in enum 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.locking.LockIdentifier
 
hashCode() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
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.IndexAggregateFunctionCall
 
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.ObjectPlanHash
 
hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRawRecord
 
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.IndexScanComparisons
 
hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
 
hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedAndRemainder
 
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.ResolverKeyValue
 
hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverResult
 
hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator.ValidatedEntry
 
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.TimeWindowLeaderboardIndexMaintainer.TimeWindowRankAndEntry
 
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.leaderboard.TimeWindowScanComparisons
 
hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
hashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
 
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.BoundRecordQuery
 
hashCode() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
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.InvertedFunctionComparison
 
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.OpaqueEqualityComparison
 
hashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
hashCode() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
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.Comparisons.ValueComparison
 
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.QueryKeyExpressionWithOneOfComparison
 
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.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
hashCode() - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph
 
hashCode() - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph.Relationship
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Define equality based on the equality of the backing bimap.
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.Column
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.Correlated.BoundEquivalence
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.CorrelationIdentifier
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.AbstractNode
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUnionExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUniqueExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.IndexAccessHint
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentityMap
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Binding
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedOrderingPart
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.MappingKey
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndOrPredicate
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate.UsedIndex
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum.EnumValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.Accessor
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.ArrayCoercionBiFunction
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.PrimitiveCoercionBiFunction
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldWithValueCopier
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.MessageCopier
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
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.RecordQueryFirstOrDefaultPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
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.RecordQueryInUnionPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
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.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
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.plans.RelativeProbabilityPlanSelector
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo.QueryPlanInfoKey
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortKey
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
hashCode() - Method in class com.apple.foundationdb.record.query.plan.TextScan
 
hashCode() - Method in class com.apple.foundationdb.record.query.RecordQuery
 
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.util.pair.ComparablePair
 
hashCode() - Method in class com.apple.foundationdb.record.util.pair.ImmutablePair
 
hashCode() - Method in class com.apple.foundationdb.record.util.pair.NonnullPair
 
hashCode() - Method in class com.apple.foundationdb.record.util.ProtoUtils.DynamicEnum
 
hashCode() - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNode
 
hashCode() - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNodeBuilder
 
hashCode() - Method in class com.apple.foundationdb.record.ValueRange
 
hashCodeSupplier - Variable in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUnionExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUniqueExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
hashCodeWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
 
hashCodeWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.TypeFilterExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AbstractQueryPredicate
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
hashCodeWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.BinaryRelOpValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.UnaryRelOpValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfValue
 
hashCodeWithoutChildren() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Method to compute the hash code of this value without considering the children of this TreeLike.
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
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.RecordQueryFirstOrDefaultPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
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.RecordQueryInsertPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
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.RecordQuerySelectorPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
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.plans.RecordQueryUpdatePlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
hashCodeWithoutChildren() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
hasHookForAsyncToSync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
 
HashUtils - Class in com.apple.foundationdb.record.util
Utility class for hash functions.
hasIncompatibleBoundQuantifiers(AliasMap, Collection<? extends Quantifier>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
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.
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.RecordQueryAggregateIndexPlan
 
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.RecordQueryExplodePlan
 
hasIndexScan(String) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
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.RecordQueryRangePlan
 
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
 
hasIndexScan(String) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
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.RecordQueryAggregateIndexPlan
 
hasLoadBykeys() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
hasLoadBykeys() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
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.RecordQueryRangePlan
 
hasLoadBykeys() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
hasLoadBykeys() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
 
hasLoadBykeys() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
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
 
hasLosslessNormalization() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
hasLosslessNormalization() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
 
hasLosslessNormalization() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
Method that indicates to the caller if this key expression can be normalized and re-composed in a way that yields an expression equivalent to the original.
hasLosslessNormalization() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
 
hasLosslessNormalization() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
 
hasLosslessNormalization() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
 
hasLosslessNormalization() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
 
hasLosslessNormalization() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
 
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
 
hasMultipleFixedBindings(Collection<Ordering.Binding>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
hasNeverBeenExplored() - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
This method indicates whether a reference containing this map has not been explored yet.
hasNeverBeenExplored() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
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.
hasPredicate() - Method in class com.apple.foundationdb.record.metadata.Index
Checks whether a predicate is defined on the index.
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.RecordQueryAggregateIndexPlan
 
hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
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.RecordQueryRangePlan
 
hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
 
hasRecordScan() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
hasRecordTypeKey() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
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.
hasScanComparisons() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
hasScanComparisons() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithComparisons
 
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
Returns true if 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 calling getStoredRecord().
hasStoredValue() - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
hasStoredValue() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
Deprecated.
hasUnboundQuantifiers(AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
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
 
hasVariadicSuffix() - Method in class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
 
hasVersion() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRecord
 
hasVersion() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecord
Get whether a FDBRecordVersion has been set for this StoredRecord.
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
 
height() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AbstractQueryPredicate
 
height() - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
returns the height of the tree.
height() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractValue
 
height() - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNode
 
HIGH_BYTES - Enum constant in enum 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
 
Hypercube(List<TupleRange>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.Hypercube
 

I

id() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
 
identifier(String) - Method in enum com.apple.foundationdb.record.Bindings.Internal
 
IDENTIFIER - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
identifierFromMatcher() - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
 
IdentifierToken(int, String) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.IdentifierToken
 
identitiesFor(Set<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap.Builder
Method to update the builder to contain entries a -> a, b -> b, ... for each alias contained in the set of CorrelationIdentifiers passed in.
identitiesFor(Set<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Factory method to create an alias map that contains entries a -> a, b -> b, ... for each alias contained in the set of CorrelationIdentifiers passed in.
identity() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.Extractor
 
identityAndRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
IdentityAndRule - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A rule that matches a AndPredicate (with the argument values).
IdentityAndRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.IdentityAndRule
 
IdentityBiMap<K,V> - Class in com.apple.foundationdb.record.query.plan.cascades
BiMap based on identities of types K and V.
identityMappingMap(Set<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.CorrelationIdentifier
Return a mapping between a -> a for all a in the given set as a view on the original set.
identityOrRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
IdentityOrRule - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A rule that matches a OrPredicate (with the argument values).
IdentityOrRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.IdentityOrRule
 
IF_OVERLAPPING_CHANGED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.Rebuild
 
IF_PRESENT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.VersionstampSaveBehavior
Save a record with a version if and only if a non-null version is passed to FDBRecordStoreBase.saveRecord(Message, FDBRecordVersion, VersionstampSaveBehavior).
ifDisabled - Variable in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
 
ifMismatchPrevious - Variable in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
 
ifReadable - Variable in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
 
ifWriteOnly - Variable in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexStatePrecondition
 
IGNORE_COMPLETE_EXCEPTION_BLOCKING - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
When asyncToSync() is called in an asynchronous context and the future it is passed would block, an exception will be thrown.
IGNORE_COMPLETE_WARN_BLOCKING - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
When asyncToSync() 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 into asyncToSync() was completed.
ignoreIndexTypeCheck() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy.Builder
Deprecated, for removal: This API element is subject to removal in a future version.
because this option is associated with legacy code only (see OnlineIndexScrubber.ScrubbingPolicy.Builder.useLegacyScrubber(boolean)).
IllegalContinuationAccessChecker - Class in com.apple.foundationdb.record.cursors
Check that RecordCursorIterator.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
 
ImmutablePair<L,R> - Class in com.apple.foundationdb.record.util.pair
Immutable implementation of the Pair interface.
ImplementDeleteRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a DeleteExpression by creating a RecordQueryDeletePlan.
ImplementDeleteRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementDeleteRule
 
ImplementDistinctRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a distinct expression by adding a RecordQueryUnorderedPrimaryKeyDistinctPlan if necessary.
ImplementDistinctRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementDistinctRule
 
ImplementDistinctUnionRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a distinct union of its (already implemented) children.
ImplementDistinctUnionRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementDistinctUnionRule
 
ImplementExplodeRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements an explode expression as a RecordQueryExplodePlan.
ImplementExplodeRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementExplodeRule
 
ImplementFilterRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a logical filter around a RecordQueryPlan as a RecordQueryFilterPlan.
ImplementFilterRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementFilterRule
 
ImplementInJoinRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a SELECT over a VALUES and a correlated subexpression as a RecordQueryInUnionPlan.
ImplementInJoinRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementInJoinRule
 
ImplementInsertRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements an InsertExpression by creating a RecordQueryInsertPlan.
ImplementInsertRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementInsertRule
 
ImplementIntersectionRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements an intersection of its (already implemented) children.
ImplementIntersectionRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementIntersectionRule
 
ImplementInUnionRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a SELECT over a VALUES and a correlated subexpression as a RecordQueryInUnionPlan.
ImplementInUnionRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementInUnionRule
 
ImplementNestedLoopJoinRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements an existential nested loop join of its (already implemented) children.
ImplementNestedLoopJoinRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementNestedLoopJoinRule
 
ImplementPhysicalScanRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that converts a logical index scan expression to a RecordQueryScanPlan.
ImplementPhysicalScanRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementPhysicalScanRule
 
ImplementRecursiveUnionRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a RecursiveUnionExpression.
ImplementRecursiveUnionRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementRecursiveUnionRule
 
ImplementSimpleSelectRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a select expression without predicates over a single partition as a RecordQueryMapPlan.
ImplementSimpleSelectRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementSimpleSelectRule
 
ImplementStreamingAggregationRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
Rule for implementing logical GROUP BY into a physical streaming aggregate operator RecordQueryStreamingAggregationPlan.
ImplementStreamingAggregationRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementStreamingAggregationRule
 
ImplementTempTableInsertRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a TempTableInsertExpression producing a TempTableInsertPlan operator.
ImplementTempTableInsertRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementTempTableInsertRule
 
ImplementTempTableScanRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a TempTableScanExpression producing a TempTableScanPlan operator.
ImplementTempTableScanRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementTempTableScanRule
 
ImplementTypeFilterRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a logical type filter on an (already implemented) RecordQueryPlan as a RecordQueryTypeFilterPlan.
ImplementTypeFilterRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementTypeFilterRule
 
ImplementUniqueRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
This rule implements LogicalUniqueExpression by absorbing it if the inner reference is already distinct.
ImplementUniqueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementUniqueRule
 
ImplementUnorderedUnionRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements an unordered union of its (already implemented) children.
ImplementUnorderedUnionRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementUnorderedUnionRule
 
ImplementUpdateRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements an UpdateExpression by creating a RecordQueryUpdatePlan.
ImplementUpdateRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementUpdateRule
 
impliesCandidatePredicateMaybe(ValueEquivalence, QueryPredicate, QueryPredicate, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
impliesCandidatePredicateMaybe(ValueEquivalence, QueryPredicate, QueryPredicate, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
Checks for implication with a match candidate predicate by constructing a disjunction set of compile-time ranges of the this and the candidate predicate and, if the construction is possible, matches them.
impliesCandidatePredicateMaybe(ValueEquivalence, QueryPredicate, QueryPredicate, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
Checks whether this predicate implies a candidatePredicate, if so, we return a PredicateMultiMap.PredicateMapping reflecting the implication itself in addition to a context needed to effectively implement the mapping (i.e.
impliesCandidatePredicateMaybe(ValueEquivalence, QueryPredicate, QueryPredicate, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
Determines if this predicate implies some other predicate.
IMPOSSIBLE_COMPENSATION - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
Identity element for the intersection monoid defined by Compensation.intersect(Compensation).
IMPOSSIBLE_COMPENSATION - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateCompensationFunction
 
IMPOSSIBLE_COMPENSATION - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.ResultCompensationFunction
 
impossibleCompensation() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
Returns a compensation which represents the impossible compensation, i.e.
impossibleCompensation() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateCompensationFunction
 
impossibleCompensation() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.ResultCompensationFunction
 
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 - Enum constant in enum com.apple.foundationdb.record.Bindings.Internal
 
IN - Enum constant in enum 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.cascades.explain.NodeIcon
 
IN_UNION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
incidentEdges(N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
incidentNodes(E) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
inComparandJoin(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inComparandJoinPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inComparandJoinPlan(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
InComparandSource - Class in com.apple.foundationdb.record.query.plan.plans
Source of values for an "IN" query where the values are derived from the comparand of a Comparison object.
InComparandSource(PlanSerializationContext, PInComparandSource) - Constructor for class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
InComparandSource(String, Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
InComparandSource.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
InComparisonToExplodeRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that traverses a predicate in a SelectExpression and attempts to extract IN-comparisons into separate ExplodeExpressions, e.g.
InComparisonToExplodeRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.InComparisonToExplodeRule
 
INCOMPATIBLE_TYPE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
incomplete(int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Create a FDBRecordVersion that is incomplete and has the given local version.
incompleteMatch() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PartialMatchMatchers
Matches any PartialMatch that is not yet complete.
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) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
increment(StoreTimer.Count, int) - Method in class com.apple.foundationdb.record.provider.common.StoreSubTimer
 
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(StoreTimer.Count, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
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.
inDegree(N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
INDENTATION - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
index - Variable in class com.apple.foundationdb.record.metadata.IndexValidator
 
index - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon.IndexContext
 
index - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
 
index - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.Builder
 
index - Variable in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexExpansionVisitor
 
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(Index, IndexPredicate) - 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, KeyExpression, String, Map<String, String>, IndexPredicate) - 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 - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
INDEX - Enum constant in enum com.apple.foundationdb.record.provider.common.text.TextTokenizer.TokenizerMode
Tokenize a String as if it were about to be indexed.
INDEX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
 
INDEX_ASYNC_FILTER - Static variable in class com.apple.foundationdb.record.PipelineOperation
 
INDEX_BUILD_SPACE - Enum constant in enum 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.cascades.explain.NodeIcon
 
INDEX_DATA - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
INDEX_DEFERRED_ACTION_STEP - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_KEY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
INDEX_MERGE_LOCK - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_MERGES_CONTEXT_TIME_QUOTA - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_MERGES_LAST_FOUND - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_MERGES_LAST_LIMIT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_MERGES_LAST_TRIED - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_MERGES_NUM_COMPLETED - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_NAME - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_OPERATION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_OPTION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_RANGE_SPACE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
 
INDEX_RANGE_SPACE_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
INDEX_REPARTITION_DOCUMENT_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
INDEX_SCRUBBER_DANGLING_ENTRIES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of dangling index entries detected by online scrubber.
INDEX_SCRUBBER_MISSING_ENTRIES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
IndexingMutuallyByRecords counter: had conflicts while indexing an 'ANY' fragment, jump ahead.
INDEX_SECONDARY_SPACE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
 
INDEX_SECONDARY_SPACE_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
INDEX_STATE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_STATE_PRECONDITION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_STATE_SPACE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
 
INDEX_STATE_SPACE_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
INDEX_SUBSPACE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_TO_RECORD - Static variable in class com.apple.foundationdb.record.PipelineOperation
 
INDEX_TYPE - Enum constant in enum 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
 
INDEX_VALUE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEX_VERSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
IndexableAggregateValue - Interface in com.apple.foundationdb.record.query.plan.cascades.values
Tag interface for AggregateValue that are backed by an aggregate index.
IndexAccessHint - Class in com.apple.foundationdb.record.query.plan.cascades
Represents an index hint.
IndexAccessHint(String) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.IndexAccessHint
 
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
 
IndexAggregateFunctionCall - Class in com.apple.foundationdb.record.metadata
Class to represent a construct AGG by Set.of(col1, col2, ...).
IndexAggregateFunctionCall(String, GroupingKeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
Overloaded constructor using a GroupingKeyExpression that represents both the grouping expressions and the grouped expression.
IndexAggregateFunctionCall(String, GroupingKeyExpression, Iterable<KeyExpression>, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
 
IndexAggregateGroupKeys - Class in com.apple.foundationdb.record.provider.foundationdb
Helper class for extracting grouping keys from an IndexAggregateFunction given 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
 
indexBuildLockSubspace(FDBRecordStoreBase<?>, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
indexBuildScannedRecordsSubspace(FDBRecordStoreBase<?>, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
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.
indexBuildTypeSubspace(FDBRecordStoreBase<?>, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
indexBuildTypeSubspace(FDBRecordStoreBase<?>, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
 
IndexComparison - Class in com.apple.foundationdb.record.metadata
This is a simple PoJo hierarchy representing SerDe operations on a predicate comparison of a sparse Index.
IndexComparison() - Constructor for class com.apple.foundationdb.record.metadata.IndexComparison
 
IndexComparison.NullComparison - Class in com.apple.foundationdb.record.metadata
A POJO equivalent for Comparisons.NullComparison.
IndexComparison.SimpleComparison - Class in com.apple.foundationdb.record.metadata
A POJO equivalent for Comparisons.SimpleComparison.
IndexComparison.SimpleComparison.ComparisonType - Enum in com.apple.foundationdb.record.metadata
The type of the comparison, this is a subset of Comparisons.Type.
IndexDeferredMaintenanceControl - Class in com.apple.foundationdb.record.provider.foundationdb
Some store's indexes may need merging on some occasions.
IndexDeferredMaintenanceControl() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
 
IndexDeferredMaintenanceControl.LastStep - Enum in com.apple.foundationdb.record.provider.foundationdb
During the deferred operation, each step should record its action.
indexDetails(RecordQueryIndexPlan) - Static method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
indexed(FDBIndexedRecord<M>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
 
IndexedValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value representing the source of a value derivation.
IndexedValue() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
IndexedValue(Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
IndexedValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
indexEntriesForRecord(FDBRecordStore, FDBStoredRecord<Message>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexScrubbingToolsMissing
 
IndexEntry - Class in com.apple.foundationdb.record
An IndexEntry carries 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
 
IndexEntry(Index, Tuple, 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.
IndexEntryObjectValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
Represents a value that references into an index entry in the bindings of EvaluationContext by means of an ordinal path (dewey id).
IndexEntryObjectValue(CorrelationIdentifier, IndexKeyValueToPartialRecord.TupleSource, ImmutableIntArray, Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
IndexEntryObjectValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
IndexEntryToLogicalRecord(RecordType, IndexKeyValueToPartialRecord, List<Value>, List<Value>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ScanWithFetchMatchCandidate.IndexEntryToLogicalRecord
 
indexEntryToQueriedRecord(FDBRecordStoreBase<M>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
INDEXER_CURR_RETRY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEXER_DELAY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent delayed during index builds.
INDEXER_ID - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEXER_MAX_RETRIES - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEXER_SESSION_ID - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
indexes - Variable in class com.apple.foundationdb.record.metadata.RecordTypeIndexesBuilder
 
INDEXES_NEED_REBUILDING - Enum constant in enum 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.
IndexFetchMethod - Enum in com.apple.foundationdb.record
An indicator for the index fetch method to use for a query or an index scan.
IndexFunctionHelper - Class in com.apple.foundationdb.record.provider.foundationdb
Helper class for finding appropriate indexes for IndexRecordFunction and IndexAggregateFunction.
INDEXING_ATTEMPTS_RECURSION_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
 
INDEXING_FRAGMENTATION_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEXING_FRAGMENTATION_CURRENT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEXING_FRAGMENTATION_FIRST - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEXING_FRAGMENTATION_STEP - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEXING_FRAGMENTATION_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEXING_METHOD - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEXING_POLICY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INDEXING_POLICY_DESIRED_ACTION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
IndexingBase - Class in com.apple.foundationdb.record.provider.foundationdb
A base class for different types of online indexing process.
IndexingBase.PartlyBuiltException - Exception in com.apple.foundationdb.record.provider.foundationdb
thrown when partly built by another method.
IndexingBase.TimeLimitException - Exception in com.apple.foundationdb.record.provider.foundationdb
Thrown when the indexing process exceeds the time limit.
IndexingBase.UnexpectedReadableException - Exception in com.apple.foundationdb.record.provider.foundationdb
thrown if some or all of the indexes to build became readable (maybe by another process).
IndexingBase.ValidationException - Exception in com.apple.foundationdb.record.provider.foundationdb
Thrown when the indexing process fails to meet a precondition.
IndexingByIndex - Class in com.apple.foundationdb.record.provider.foundationdb
This indexer scans records by a source index.
IndexingByRecords - Class in com.apple.foundationdb.record.provider.foundationdb
This indexer scans all records in the record store.
IndexingCommon - Class in com.apple.foundationdb.record.provider.foundationdb
Shared data structure to be used (only) by the Indexing* modules.
IndexingCommon.IndexContext - Class in com.apple.foundationdb.record.provider.foundationdb
Index and record types for indexing.
IndexingMerger - Class in com.apple.foundationdb.record.provider.foundationdb
Implement an index merge.
IndexingMerger(Index, IndexingCommon, long) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexingMerger
 
IndexingMultiTargetByRecords - Class in com.apple.foundationdb.record.provider.foundationdb
This indexer scans records to build multiple indexes.
IndexingMutuallyByRecords - Class in com.apple.foundationdb.record.provider.foundationdb
This indexer supports mutual concurrent multi-target indexing by multiple processes or hosts.
IndexingMutuallyByRecords(IndexingCommon, OnlineIndexer.IndexingPolicy, List<Tuple>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexingMutuallyByRecords
 
IndexingRangeSet - Class in com.apple.foundationdb.record.provider.foundationdb.indexing
Wrapper around a RangeSet class that binds the class with a specific transaction.
IndexingScrubDangling - Class in com.apple.foundationdb.record.provider.foundationdb
Manifesto: Scrub a readable index to validate its consistency.
IndexingScrubDangling(IndexingCommon, OnlineIndexer.IndexingPolicy, OnlineIndexScrubber.ScrubbingPolicy, AtomicLong) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexingScrubDangling
 
IndexingScrubMissing - Class in com.apple.foundationdb.record.provider.foundationdb
Manifesto: Scrub a readable index to validate its consistency.
IndexingScrubMissing(IndexingCommon, OnlineIndexer.IndexingPolicy, OnlineIndexScrubber.ScrubbingPolicy, AtomicLong) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexingScrubMissing
 
IndexingThrottle - Class in com.apple.foundationdb.record.provider.foundationdb
This class provides build/commit/retry with throttling to the OnlineIndexer.
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
IndexKeyValueToPartialRecord.Copier - Interface in com.apple.foundationdb.record.query.plan
Copy from an index entry into part of a record.
IndexKeyValueToPartialRecord.FieldCopier - Class in com.apple.foundationdb.record.query.plan
Copier for basic fields.
IndexKeyValueToPartialRecord.FieldCopier.Deserializer - Class in com.apple.foundationdb.record.query.plan
Deserializer.
IndexKeyValueToPartialRecord.FieldWithValueCopier - Class in com.apple.foundationdb.record.query.plan
Copier for fields that is based on some give Value to do its work.
IndexKeyValueToPartialRecord.FieldWithValueCopier.Deserializer - Class in com.apple.foundationdb.record.query.plan
Deserializer.
IndexKeyValueToPartialRecord.MessageCopier - Class in com.apple.foundationdb.record.query.plan
Copier for nested messages.
IndexKeyValueToPartialRecord.MessageCopier.Deserializer - Class in com.apple.foundationdb.record.query.plan
Deserializer.
IndexKeyValueToPartialRecord.TupleSource - Enum in com.apple.foundationdb.record.query.plan
Which side of the IndexEntry to take a field from.
indexLogMessageKeyValues() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
indexLogMessageKeyValues(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
indexLogMessageKeyValues(String, List<Object>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
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 for IndexMaintainer.
indexMaintainerForAggregateFunction(FDBRecordStore, IndexAggregateFunction, List<String>, IndexQueryabilityFilter) - 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 of IndexMaintainers.
IndexMaintainerRegistryImpl - Class in com.apple.foundationdb.record.provider.foundationdb
A singleton IndexMaintainerRegistry that finds IndexMaintainerFactory classes 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 an IndexMaintainer.
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
 
indexName(String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
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.
IndexOnlyAggregateValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
Represents a compile-time aggregation value that must be backed by an aggregation index, and can not be evaluated at runtime by a streaming aggregation operator.
IndexOnlyAggregateValue(PlanSerializationContext, PIndexOnlyAggregateValue) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
IndexOnlyAggregateValue(IndexOnlyAggregateValue.PhysicalOperator, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
Creates a new instance of IndexOnlyAggregateValue.
IndexOnlyAggregateValue.MaxEverFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The max_ever function.
IndexOnlyAggregateValue.MaxEverValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
Class to represent MAX_EVER(field) where field which can only be provided by a suitable index.
IndexOnlyAggregateValue.MaxEverValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
IndexOnlyAggregateValue.MinEverFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The min_ever function.
IndexOnlyAggregateValue.MinEverValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
Class to represent MIN_EVER(field) where field which can only be provided by a suitable index.
IndexOnlyAggregateValue.MinEverValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
IndexOnlyAggregateValue.PhysicalOperator - Enum in com.apple.foundationdb.record.query.plan.cascades.values
 
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 an IndexOperation.
IndexOperationResult() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexOperationResult
 
IndexOptions - Class in com.apple.foundationdb.record.metadata
The standard options for use with Index.
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.
indexPlan() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
indexPlanOf(BindingMatcher<? extends RecordQueryPlanWithIndex>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
IndexPredicate - Class in com.apple.foundationdb.record.metadata
This is a Plain old Java object (POJO) hierarchy representing SerDe operations on a predicate on an Index.
IndexPredicate() - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate
 
IndexPredicate.AndPredicate - Class in com.apple.foundationdb.record.metadata
A POJO equivalent for AndPredicate.
IndexPredicate.ConstantPredicate - Class in com.apple.foundationdb.record.metadata
a POJO equivalent for ConstantPredicate.
IndexPredicate.ConstantPredicate.ConstantValue - Enum in com.apple.foundationdb.record.metadata
The constant to use.
IndexPredicate.NotPredicate - Class in com.apple.foundationdb.record.metadata
A POJO equivalent of NotPredicate.
IndexPredicate.OrPredicate - Class in com.apple.foundationdb.record.metadata
A POJO equivalent for OrPredicate.
IndexPredicate.ValuePredicate - Class in com.apple.foundationdb.record.metadata
A POJO equivalent of ValuePredicate.
IndexPredicateExpansion - Class in com.apple.foundationdb.record.query.plan.cascades
Trait that plugs index predicate expansion utility methods into the consumer.
IndexPredicateExpansion() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.IndexPredicateExpansion
 
IndexPrefetchRangeKeyValueCursor - Class in com.apple.foundationdb.record.provider.foundationdb
A KeyValueCursor that scans an index using the IndexPrefetch operation.
IndexPrefetchRangeKeyValueCursor.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
A Builder for the cursor.
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 a RangeSet.
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
 
IndexScanBounds - Interface in com.apple.foundationdb.record.provider.foundationdb
The bounds for an index scan.
IndexScanComparisons - Class in com.apple.foundationdb.record.provider.foundationdb
ScanComparisons for use in an index scan.
IndexScanComparisons(IndexScanType, ScanComparisons) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
IndexScanComparisons(PlanSerializationContext, PIndexScanComparisons) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
IndexScanComparisons.Deserializer - Class in com.apple.foundationdb.record.provider.foundationdb
Deserializer.
indexScanParameters(BindingMatcher<? extends IndexScanParameters>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
IndexScanParameters - Interface in com.apple.foundationdb.record.provider.foundationdb
The parameterized form of index scan bounds.
IndexScanRange - Class in com.apple.foundationdb.record.provider.foundationdb
TupleRange for an index scan.
IndexScanRange(IndexScanType, TupleRange) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexScanRange
 
indexScanToGroupKeys(String, int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexAggregateGroupKeys
 
indexScanType(IndexScanType) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
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
 
IndexScrubbing - Class in com.apple.foundationdb.record.provider.foundationdb
Scrub a readable index to validate its consistency.
IndexScrubbing(IndexingCommon, OnlineIndexer.IndexingPolicy, OnlineIndexScrubber.ScrubbingPolicy, AtomicLong, IndexScrubbingTools.ScrubbingType) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexScrubbing
 
IndexScrubbingTools<T> - Interface in com.apple.foundationdb.record.provider.foundationdb
Index Scrubbing Toolbox for a specific index maintainer.
IndexScrubbingTools.Issue - Class in com.apple.foundationdb.record.provider.foundationdb
IndexScrubbingTools.ScrubbingType - Enum in com.apple.foundationdb.record.provider.foundationdb
The specific type of scrubbing.
indexScrubIndexRangeSubspace(FDBRecordStoreBase<?>, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
indexScrubRecordsRangeSubspace(FDBRecordStoreBase<?>, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
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.keyspace.KeySpaceTreeResolver
 
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 of IndexValidators.
inEdges(N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
INEQUALITY - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.ComparisonRange.Type
 
INEQUALITY - Enum constant in enum com.apple.foundationdb.record.query.plan.ScanComparisons.ComparisonType
 
INEQUALITY - Enum constant in enum 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
Extract IN predicates 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(InExtractor) - Constructor for class com.apple.foundationdb.record.query.plan.planning.InExtractor
 
InFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue.InFn
 
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.FDBDatabaseFactoryImpl
 
INITIAL_INDEX_STATE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
INITIAL_PREFIX - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
initialize(Function<Class<?>, Iterable<?>>) - Static method in class com.apple.foundationdb.record.util.ServiceLoaderProvider
Replaces the default service loader.
initRegistry() - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerRegistryImpl
 
inject(Value, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
INJECTED_COMMIT_LATENCY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time injected into committing transactions.
INJECTED_GET_READ_VERSION_LATENCY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time injected by the client prior to getting a read version.
inJoin(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inJoinPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inJoinPlan(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
InJoinVisitor - Class in com.apple.foundationdb.record.query.plan.visitor
A substitution visitor that pushes a RecordQueryInJoinPlan below a RecordQueryFetchFromPartialRecordPlan.
InJoinVisitor(RecordMetaData, PlannableIndexTypes, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.visitor.InJoinVisitor
 
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
 
inner - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
InOpValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value that checks if the left child is in the list of values.
InOpValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
InOpValue.InFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The in function.
inParameter(BindingMatcher<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inParameterJoin(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inParameterJoinPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inParameterJoinPlan(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
InParameterSource - Class in com.apple.foundationdb.record.query.plan.plans
Helper class which represents a specialized InSource whose input is an outer binding (a parameter).
InParameterSource(PlanSerializationContext, PInParameterSource) - Constructor for class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
InParameterSource(String, String) - Constructor for class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
InParameterSource.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
insert(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Inserts a new expression into this reference.
INSERT - Static variable in class com.apple.foundationdb.record.PipelineOperation
 
INSERT_INTO_MEMO - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
 
insertExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
InsertExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A logical version of RecordQueryInsertPlan.
InsertExpression(Quantifier.ForEach, String, Type.Record) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
insertFrom(RelationalExpression, Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Inserts a new expression into this reference.
InsertionOrderComparator(Comparator<K>, K) - Constructor for class com.apple.foundationdb.record.sorting.MemorySortAdapter.InsertionOrderComparator
 
insertPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
insertPlan(Quantifier.Physical, Value, boolean) - Static method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
Factory method to create a TempTableInsertPlan.
insertPlan(Quantifier.Physical, String, Type.Record, Value) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan
Factory method to create a RecordQueryInsertPlan.
insertRangeAsync(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Insert a range into the range set.
insertRangeAsync(byte[], byte[], boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Insert a range into the range set.
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.
insertUnchecked(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Inserts a new expression into this reference.
insertUnchecked(RelationalExpression, Map<PlanProperty<?>, ?>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Inserts a new expression into this reference.
inSource - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
InSource - Class in com.apple.foundationdb.record.query.plan.plans
Helper class to describe an IN-list for physical RecordQueryInJoinPlans and RecordQueryInUnionPlans.
InSource(PlanSerializationContext, PInSource.Super) - Constructor for class com.apple.foundationdb.record.query.plan.plans.InSource
 
InSource(String) - Constructor for class com.apple.foundationdb.record.query.plan.plans.InSource
 
install() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
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
Returns the default implementation of FDBDatabaseFactory (specifically an instance of FDBDatabaseFactoryImpl.instance().
instance() - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
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 method in exception com.apple.foundationdb.record.query.expressions.Comparisons.EvaluationContextRequiredException
 
instance() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
Create a unique instance that can be used to manually set a binding in a PlannerBindings.
instance() - Static method in class com.apple.foundationdb.record.query.plan.cascades.TempTable.Factory
 
instance() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.DefaultValueSimplificationRuleSet
 
instance() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MaxMatchMapSimplificationRuleSet
 
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
 
INSTANCE - Static variable in class com.apple.foundationdb.record.query.plan.serialization.DefaultPlanSerializationRegistry
 
InstanceMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A binding matcher that matches the same object as another BindingMatcher.
InstanceMatcher(BindingMatcher<T>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.structure.InstanceMatcher
 
instanceOfMajorClass(QueryPredicate) - Method in enum com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer.Mode
 
instanceOfMinorClass(QueryPredicate) - Method in enum com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer.Mode
 
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.common.StoreTimer
Add timing instrumentation to an asynchronous operation.
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>, 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 around Transaction that instruments certain calls to expose their behavior with FDBStoreTimer metrics.
InstrumentedTransaction(StoreTimer, StoreTimer, FDBDatabase, TransactionListener, Transaction, boolean) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
INT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
INT - Enum constant in enum com.apple.foundationdb.record.query.plan.planning.BindingFunction
 
INT64_ZERO - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
intAverageState() - Static method in class com.apple.foundationdb.record.cursors.aggregate.AverageAccumulatorState
 
integerPropertyKey(String, int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
 
IntegerState - Class in com.apple.foundationdb.record.cursors.aggregate
Accumulator state for Integer types.
IntegerState(PrimitiveAccumulatorOperation) - Constructor for class com.apple.foundationdb.record.cursors.aggregate.IntegerState
 
intern(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
 
internal - Variable in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
internal - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
The use of this field is to distinguish old-planner use of this plan object versus cascades planner use.
internal - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
InternalPlannerGraphBuilder(AbstractPlannerGraph<PlannerGraph.Node, PlannerGraph.Edge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.InternalPlannerGraphBuilder
 
InternalPlannerGraphBuilder(PlannerGraph.Node) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.InternalPlannerGraphBuilder
 
InternalPlannerGraphRewritable - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Interface to allow RelationalExpressions to rewrite their own internal graph representation.
INTERNING_LAYER_CREATE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent adding a new entry to a ScopedInterningLayer.
INTERNING_LAYER_READ - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent reading an entry from a ScopedInterningLayer.
intersect(Compensation) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
Intersect this compensation with another one passed in.
intersect(Compensation) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
Specific implementation of intersecting two compensations both of type Compensation.WithSelectCompensation.
intersect(RangeConstraints.CompilableRange) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.CompilableRange
 
intersection(List<AvailableFields>) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields
 
intersection(List<Quantifier.Physical>, List<OrderingPart.ProvidedOrderingPart>, boolean) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
Intersection(SetMultimap<Value, Ordering.Binding>, PartiallyOrderedSet<Value>, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Ordering.Intersection
 
INTERSECTION - Static variable in class com.apple.foundationdb.record.query.plan.cascades.Ordering
Intersection merge operator to be used to obtain the resulting order of a distinct intersection operation.
INTERSECTION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.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.
intersectionOnExpressionPlan(BindingMatcher<? extends RecordQueryPlan>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
intersectionOnValuesPlan(BindingMatcher<? extends RecordQueryPlan>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
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
 
inUnion(Quantifier.Physical, List<? extends InSource>, List<OrderingPart.ProvidedOrderingPart>, boolean, int, Bindings.Internal) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
inUnionBindingName(String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inUnionComparisonKey(KeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inUnionComparisonKey(BindingMatcher<KeyExpression>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inUnionComparisonValues(CollectionMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inUnionInParameter(BindingMatcher<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inUnionInValues(BindingMatcher<? extends Collection<?>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inUnionOnExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inUnionOnExpressionPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inUnionOnValues(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inUnionOnValuesPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inUnionValuesSources(CollectionMatcher<? extends InSource>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
InUnionVisitor - Class in com.apple.foundationdb.record.query.plan.visitor
A substitution visitor that pushes a RecordQueryInJoinPlan below a RecordQueryFetchFromPartialRecordPlan.
InUnionVisitor(RecordMetaData, PlannableIndexTypes, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.visitor.InUnionVisitor
 
INVALID_ENUM_VALUE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
INVALID_KEY_LENGTH - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of record keys with an incorrect length found by FDBRecordStore.repairRecordKeys(byte[], com.apple.foundationdb.record.ScanProperties).
INVALID_SPLIT_SUFFIX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of record keys with an invalid split suffix found by FDBRecordStore.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.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
 
inValuesJoin(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inValuesJoinPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inValuesJoinPlan(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
inValuesList(BindingMatcher<? extends Collection<?>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
InValuesSource - Class in com.apple.foundationdb.record.query.plan.plans
Helper class which represents a specialized InSource whose input is a list of literal values.
InValuesSource(PlanSerializationContext, PInValuesSource) - Constructor for class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
InValuesSource(String, List<Object>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
InValuesSource.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
inverse() - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Returns the inverse of this AliasMap.
inverse() - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
INVERSE_ORDER_PRESERVING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.Ordering.OrderPreservingKind
 
inverseMaybe() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence
Method that returns the inverse of this value equivalence.
invertComparisonType(Comparisons.Type) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons
 
InvertibleFunctionKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
Key expression representing an invertible function.
InvertibleFunctionKeyExpression(String, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.expressions.InvertibleFunctionKeyExpression
 
invisible(Object) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.explain.Attribute
Static factory method to create an attribute based on a reference to some object.
IS_NULL - Enum constant in enum com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison.ComparisonType
 
IS_NULL - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
IS_SPLIT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
IS_VERSIONED_INLINE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
isAccessCompatibleWithCurrentType(CompatibleTypeEvolutionPredicate.FieldAccessTrieNode, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
isAdjusted() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedMatchInfo
 
isAdjusted() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchInfo
 
isAdjusted() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
isAllTime() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate
 
isAny() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Checks whether a Type is any type.
isAnyAscending() - Method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
 
isAnyDescending() - Method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
 
isAPIVersionAtLeast(APIVersion) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
Determine whether the API version of this transaction is at least as new as the provided API version.
isArray() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Checks whether a Type is Type.Array.
isArrayWrapper(NestingKeyExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.NullableArrayTypeUtils
Check whether a nesting keyExpression is a wrapped array field.
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
 
isAtLeast(APIVersion) - Method in enum com.apple.foundationdb.record.provider.foundationdb.APIVersion
Whether this API version is at least as new as another API version.
isAtomic() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AbstractQueryPredicate
 
isAtomic() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
isAutoGenerated(String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
 
isBetterThanOther(RecordQueryPlanner.PlanContext, RecordQueryPlanner.ScoredPlan, Index, RecordQueryPlanner.ScoredPlan, Index) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
 
isByIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
Check if active.
isCacheable() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.StateCacheabilityOnOpen
Whether the store state should be marked as cacheable.
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.cursors.aggregate.AggregateCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.AsyncLockCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.AutoContinuingCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.ChainedCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.ConcatCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.EmptyCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.FallbackCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.FilterCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.FlatMapPipelinedCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.FutureCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.AsyncIteratorCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.LazyCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.ListCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.MapCursor
Deprecated.
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.MapResultCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.MapWhileCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.OrElseCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.RangeCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.RowLimitedCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.SkipCursor
 
isClosed() - Method in class com.apple.foundationdb.record.cursors.TempTableInsertCursor
 
isClosed() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
 
isClosed() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorState
 
isClosed() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.SizeStatisticsCollectorCursor
 
isClosed() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
 
isClosed() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
 
isClosed() - Method in interface com.apple.foundationdb.record.RecordCursor
 
isClosed() - Method in class com.apple.foundationdb.record.sorting.FileSortCursor
 
isClosed() - Method in class com.apple.foundationdb.record.sorting.MemorySortCursor
 
isCompatible(Bindings) - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph
 
isCompatible(FDBRecordStore, Bindings) - Method in class com.apple.foundationdb.record.query.BoundRecordQuery
Check if a given RecordQueryPlan for the given store and a set of bindings is compatible to this bound query.
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.
isCompatible(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Determine if two AliasMaps are compatible.
isCompatibleWithRequestedSortOrder(OrderingPart.RequestedSortOrder) - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
 
isCompatiblyAndCompletelyBound(AliasMap, List<? extends Quantifier>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
isCompileTime() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
isCompileTimeEvaluable() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
Checks whether the range can be determined at compile-time or not.
isComplete() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Whether this version has all of its relevant data set.
isCompressed() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
isCompressed() - Method in interface com.apple.foundationdb.record.sorting.FileSortAdapter
Get whether files should be compressed.
isConstant() - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Checks whether this Value is compile-time constant.
isConstraining() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
isConstraining() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
isContradiction() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
isContradiction() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
isCorrelatedTo(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
isCorrelatedTo(CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Correlated
Test if the current correlated object is correlated to a CorrelationIdentifier passed in.
isCorrelation() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
isCounterflowNulls() - Method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
 
isDefaultValue() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBTraceFormat
Get whether this is the default trace format.
isDefinedEqual(CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.AliasMapBackedValueEquivalence
 
isDefinedEqual(CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ConstantValueEquivalence
 
isDefinedEqual(CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence
 
isDefinedEqual(CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ThenEquivalence
 
isDefinedEqual(CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ValueMap
 
isDefinedEqual(ConstantObjectValue, LiteralValue<?>) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ConstantValueEquivalence
 
isDefinedEqual(Value, Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.AliasMapBackedValueEquivalence
 
isDefinedEqual(Value, Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ConstantValueEquivalence
 
isDefinedEqual(Value, Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence
 
isDefinedEqual(Value, Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ThenEquivalence
 
isDefinedEqual(Value, Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ValueMap
 
isDelayedUntilCommit() - Method in interface com.apple.foundationdb.record.provider.common.StoreTimer.Event
Whether a metric should not be recorded until its associated transaction has committed.
isDelayedUntilCommit() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
 
isDirected() - Method in class com.google.common.graph.StableStandardMutableNetwork
 
isDirectional() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
 
isDirectional() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
 
isDirectional() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
 
isDirectional() - Method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
All sort orders should represent some notion of ascending and descending.
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.
isDistinct() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
isDistinct() - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
 
isDone() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
Return whether the max-size of the string has already been hit.
isDryRun() - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
isDryRun() - Method in class com.apple.foundationdb.record.ExecuteProperties
 
isDynamic() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
isDynamic() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan
Returns whether the set operation is dynamic if it only has exactly one leg, i.e., the leg of the plan can be executed many times side-by-side as if the set operation were created over many legs.
isEmpty() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet.EligibleSet
 
isEmpty() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
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.cascades.AliasMap
 
isEmpty() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
isEmpty() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
isEmpty() - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
isEmpty() - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
isEmpty() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
isEmpty() - Method in class com.apple.foundationdb.record.query.plan.cascades.TempTable
 
isEmpty() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
isEmpty() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
isEmpty() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo
Return TRUE if the info set is empty.
isEmpty() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
isEmpty(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
checks whether the range is known to be empty at compile-time or not.
isEmptyAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Returns whether the set is empty.
isEnd() - Method in class com.apple.foundationdb.record.ByteArrayContinuation
 
isEnd() - Method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor.Continuation
 
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.
isEnum() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Checks whether a Type is Type.Enum.
isEqualities() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
isEquality() - Method in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
isEquality() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
isEquality() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
isEquals() - Method in class com.apple.foundationdb.record.TupleRange
 
isErased() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
 
isErased() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
Checks whether the array type is erased or not.
isErased() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type.Erasable
 
isErased() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Checks whether the Type.Record type instance is erased or not.
isErased() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
Checks whether the stream type is erased or not.
isExhaustive() - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
Method to return if we are interested in all plans satisfying this requested ordering (iff true) or what would just be preemptively considered the best plan per given requirement.
isExplored() - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
Method to establish whether this map is explored.
isExploredForAttributes(Set<PlannerConstraint<?>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
This method indicates whether the reference containing this map is currently being explored because of a change to a property as defined by a set of attributes passed in.
isExploredForAttributes(Set<PlannerConstraint<?>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
isExploring() - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
This method indicates whether the reference containing this map is currently being explored.
isExploring() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
isFailOnScanLimitReached() - Method in class com.apple.foundationdb.record.ExecuteProperties
Get whether reaching the scan limit throws an exception.
isFalse() - Method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
Returns iff this boolean is considered to be false.
isFinalNeeded() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
Method that indicates if this compensation needs to be applied if it is the top compensation in the chain of compensations.
isFinalNeeded() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
 
isFixed() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Binding
 
isForbidRecordScan() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
If another indexing method is not possible, indicate if a fallback to records scan is forbidden.
isForExplain() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
isFull() - Method in class com.apple.foundationdb.record.sorting.MemoryScratchpad.LoadResult
 
isFullyExploring() - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
This method indicates whether the reference containing this map is currently being explored for the first time (a full exploration).
isFullyExploring() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
isFunctionallyDependentOn(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
isFunctionallyDependentOn(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
isFunctionallyDependentOn(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
isFunctionallyDependentOn(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
isFunctionallyDependentOn(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
isFunctionallyDependentOn(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
isFunctionallyDependentOn(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
isFunctionallyDependentOn(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
isFunctionallyDependentOn(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
isFunctionallyDependentOn(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
isFunctionallyDependentOn(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
isFunctionallyDependentOn(Value) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Method to derive if this value is functionally dependent on another value.
isGroupingPermutable() - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
 
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
 
isImpossible() - Method in class com.apple.foundationdb.record.query.plan.cascades.Compensation.ForMatch
 
isImpossible() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
Returns if this compensation can be applied in a way to yield the correct result.
isImpossible() - Method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateCompensationFunction
 
isImpossible() - Method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.ResultCompensationFunction
 
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.
isIndexReadableUniquePending(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Determine if the index is readable-unique-pending for this record store.
isIndexReadableUniquePending(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Determine if the index with the given name is readable-unique-pending for this record store.
isIndexScannable(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Determine if the index with the given name is scannable - i.e.
isIndexScannable(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Determine if the index with the given name is scannable - i.e.
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.cascades.ComparisonRange
 
isInheritOuterRecordProperties() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
isInitialState() - Method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor.Continuation
 
isInitialState() - Method in interface com.apple.foundationdb.record.cursors.RecursiveUnionCursor.RecursiveStateManager
Checks whether the execution is still in the initial phase or not.
isInjective() - Method in class com.apple.foundationdb.record.metadata.expressions.InvertibleFunctionKeyExpression
Whether the function key expression is injective.
isInjective() - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
isInMemory() - Method in class com.apple.foundationdb.record.sorting.FileSorter.LoadResult
 
isInternal(String) - Static method in enum com.apple.foundationdb.record.Bindings.Internal
 
isInternalExpansion() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
isIsomorphic(AliasMap, Set<CorrelationIdentifier>, Set<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
Helper to determine whether this set is equals to otherSet after translation using the given AliasMap.
isKey() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
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.
isLoadComplete() - Method in class com.apple.foundationdb.record.sorting.FileSorter.LoadResult
 
isLockReleased() - Method in class com.apple.foundationdb.record.locking.AsyncLock
Checks if the lock is released.
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.
isMemoizedExpression(RelationalExpression, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
isMemoryOnly() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
isMutual() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
In this mode, assume concurrently indexing with other entities.
isNeeded() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
Returns if this compensation object needs to be applied in order to correct the result of a match.
isNeeded() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
 
isNeeded() - Method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateCompensationFunction
 
isNeeded() - Method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.ResultCompensationFunction
 
isNeededForFiltering() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
Returns if this compensation object needs to be applied in order to filter to the correct records.
isNeededForFiltering() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
 
isNotReverse() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
isNull() - Method in class com.apple.foundationdb.record.metadata.IndexComparison.NullComparison
 
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 to null.
isNull() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression.OneOfThem
 
isNullable() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
Checks whether a Type is nullable.
isNullable() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
Checks whether a Type is nullable.
isNullable() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
Checks whether a Type is nullable.
isNullable() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
isNullable() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Checks whether a Type is nullable.
isNullable() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
isNullable() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
isNullable() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive
 
isNullable() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Checks whether a Type is nullable.
isNullable() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
Checks whether a Type is nullable.
IsNullFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.IsNullFn
 
isNullOnEmpty() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach
 
isNullsFirst() - Method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
 
isNullsLast() - Method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
 
isNumeric() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Checks whether a Type is numeric.
isNumeric() - Method in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
Checks whether a Type is numeric.
isOfType(String) - Method in enum com.apple.foundationdb.record.Bindings.Internal
 
isolationLevel - Variable in class com.apple.foundationdb.record.ExecuteProperties
 
IsolationLevel - Enum in com.apple.foundationdb.record
The isolation level for reads from the database.
isOpen() - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.BracketLikeToken
 
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.
isParent() - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordType.NestedConstituent
Whether this is the parent of the record type.
isParent() - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordTypeBuilder.NestedConstituent
 
isPermittedToPullFrom(SelectExpression, Quantifier.ForEach, RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PullUpNullOnEmptyRule
 
isPermuted() - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexExpansionVisitor
 
isPermuted() - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
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.
isPrefixOf(FieldValue.FieldPath) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
isPreserve() - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
When expressing a requirement (see also RequestedOrderingConstraint), the requirement may be to preserve the order of records that are being encountered.
isPrimaryKeyOrdered() - Method in class com.apple.foundationdb.record.query.plan.PlanOrderingKey
Return true if only primary key fields follow the prefix.
isPrimitive() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Checks whether a Type is primitive or structured.
isPrimitive() - Method in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
Checks whether a Type is primitive or structured.
isPromotable(Type, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
isPromotionNeeded(Type, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
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.
isReadableUniquePending(String) - Method in class com.apple.foundationdb.record.RecordStoreState
Determines whether the index of the given name is in readable-unique-pending.
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
 
isRecord() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Checks whether a Type is Type.Record.
isRecordStoreLeaf(KeySpaceTreeResolver.Resolved, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver
Determine whether this leaf of the KeySpaceDirectory tree is the root of a FDBRecordStore.
isRegular() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchInfo
 
isRelation() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Checks whether a Type is Type.Relation.
isRenderingEnabled(int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
isReportConflictingKeys() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Get whether to report conflicting key ranges on commit conflict.
isReportConflictingKeys() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
Get whether to report conflicting key ranges on commit conflict.
isResultOnEmpty() - Method in class com.apple.foundationdb.record.cursors.aggregate.StreamGrouping
 
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.provider.foundationdb.KeyValueCursorBase.Builder
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
isReverse() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
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.RecordQueryAbstractDataModificationPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
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.RecordQueryInUnionPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
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.RecordQueryStreamingAggregationPlan
 
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.plans.SortedInComparandSource
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.CandidateScan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortKey
 
isReverse() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
isReverse() - Method in class com.apple.foundationdb.record.ScanProperties
Get direction of scans.
isReversed(List<Quantifier.Physical>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
 
isReverseScanOrder() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
Get caller's request to scan records in reverse order while indexing.
isRoot() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
isRoot() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.PullUp
 
isRuleEnabled(CascadesRule<?>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Method to return if a particular rule is enabled per this configuration.
isRunLoopProfilingEnabled() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Get whether additional run-loop profiling has been been enabled.
isRunLoopProfilingEnabled() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
isSane() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
isSargable() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
isSargable() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
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.
isScannable() - Method in enum com.apple.foundationdb.record.IndexState
 
isScannable(String) - Method in class com.apple.foundationdb.record.RecordStoreState
Determines whether the index of the given name is in scannable.
isSelectStar() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
isSerializedOrderReversed() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
isSerializedOrderReversed() - Method in interface com.apple.foundationdb.record.sorting.MemorySortAdapter
Get whether the unsigned byte comparison order of values returned by MemorySortAdapter.serializeKey(K) is the same as Comparator.compare(T, T)'s order or its reverse.
isServerRequestTracing() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Get whether FDB server request tracing is enabled for this transaction.
isServerRequestTracing() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
Get whether FDB server request tracing is enabled.
isSingleFieldComparison(QueryComponent) - Static method in class com.apple.foundationdb.record.query.expressions.Query
 
isSingularBinding(Collection<Ordering.Binding>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
isSingularDirectionalBinding(Collection<Ordering.Binding>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
isSingularFixedValue(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
isSingularNonFixedBinding(Collection<Ordering.Binding>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
isSingularNonFixedValue(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
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
 
isSize() - Method in enum com.apple.foundationdb.record.sorting.SortEvents.Counts
 
isSnapshot() - Method in enum com.apple.foundationdb.record.IsolationLevel
 
isSnapshot() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
isSnapshot() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
isSorted() - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
isSorted() - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
isSorted() - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
isSorted() - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
isSorted() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource
 
isSorted() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
isSorted() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource
 
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 which RecordCursorResult.getContinuation() would return null.
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.
isStrictlySorted() - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
Indicates whether the ordering of records from this plan is fully accounted for by its requested sort.
isStrictlySorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
isStrictlySorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
isStrictlySorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
isStrictlySorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
isStrictlySorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
isStrictlySorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
isStrictlySorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
isStrictlySorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
isStrictlySorted() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
 
isStrictlySorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
isStrictlySorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
isStrictlySorted() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
 
isSuccess() - Method in class com.apple.foundationdb.record.util.Result
Whether the underlying result was successful or not.
Issue(KeyValueLogMessage, FDBStoreTimer.Counts, FDBStoredRecord<Message>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.IndexScrubbingTools.Issue
 
isSupported(Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.metadata.IndexComparison
Checks whether a Comparisons.Comparison can be represented by this POJO hierarchy.
isSupported(QueryPredicate) - Static method in class com.apple.foundationdb.record.metadata.IndexPredicate
Checks whether a QueryPredicate is supported for SerDe operations using this POJO hierarchy.
isSynthetic - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon.IndexContext
 
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
 
isTautology() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
isTautology() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
isTautology() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
Method that indicates whether this predicate is filtering at all.
isTimedOut - Variable in class com.apple.foundationdb.record.TimeScanLimiter
 
isTimeLimitException(Throwable) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
isTopExpression() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
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 associated FDBDatabase.
isTrackOpen() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig
Get whether open context is tracked in the associated FDBDatabase.
isTrackProgress() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
isTrackProgress() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
 
isTrivialSelect() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
isTrue() - Method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
Returns iff this boolean is considered to be true.
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
 
isUnbound() - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph
 
isUnclosedWarning() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
isUncommitedComparisonRangesEqualities() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
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.
isUnique() - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
isUnique() - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
isUnique() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
isUnique() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
isUnique() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
isUnique(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
isUnique(Index) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScanParameters
Get whether this scan is fully restricted, so that it can only output one or zero entries.
isUnique(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
isUnknown() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty.Cardinality
 
isUnresolved() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
isUnresolved() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
isUnresolved() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
isUpdateExistingStores() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.StateCacheabilityOnOpen
Whether to update existing stores.
isUseLegacy() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy
 
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.
isValid(boolean) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Builder
 
isValidationException(Throwable) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
isValidId(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.DotExporter
Test if the ID candidate is a valid ID.
isValidId(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GmlExporter
Test if the ID candidate is a valid ID.
isValidId(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter
 
isVersionChanged() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Returns true if the RecordMetadata version is changed in the RecordStore.
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.cascades.explain.Attribute.CommonAttribute
 
isVisible(GraphExporter.ExporterContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.explain.Attribute.DotAttribute
 
isVisible(GraphExporter.ExporterContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.explain.Attribute.GmlAttribute
 
isVisible(GraphExporter.ExporterContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.explain.Attribute.InvisibleAttribute
 
isVisible(GraphExporter.ExporterContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.explain.Attribute
Returns whether this method is visible in the given context.
isWriteOnly() - Method in enum com.apple.foundationdb.record.IndexState
 
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.
IterableHelpers - Class in com.apple.foundationdb.record.query.plan.cascades
Helper methods for Iterables.
iterablePlanHash(PlanHashable.PlanHashKind, Iterable<?>) - Static method in interface com.apple.foundationdb.record.PlanHashable
Deprecated, for removal: This API element is subject to removal in a future version.
iterablePlanHash(PlanHashable.PlanHashMode, Iterable<?>) - Static method in interface com.apple.foundationdb.record.PlanHashable
 
iterateAllRanges(List<Object>, BiFunction<FDBRecordStore, AtomicLong, CompletableFuture<Boolean>>, SubspaceProvider, Subspace) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
iterateAllRanges(List<Object>, BiFunction<FDBRecordStore, AtomicLong, CompletableFuture<Boolean>>, SubspaceProvider, Subspace, Function<FDBException, Optional<Boolean>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
iterateRangeOnly(FDBRecordStore, RecordCursor<T>, BiFunction<FDBRecordStore, RecordCursorResult<T>, CompletableFuture<FDBStoredRecord<Message>>>, AtomicReference<RecordCursorResult<T>>, AtomicBoolean, AtomicLong, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
iterate cursor's items and index them.
ITERATION - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
iterator - Variable in class com.apple.foundationdb.record.cursors.AsyncIteratorCursor
 
iterator() - Method in class com.apple.foundationdb.record.query.combinatorics.EnumeratingIterable.EmptyIterable
 
iterator() - Method in interface com.apple.foundationdb.record.query.combinatorics.EnumeratingIterable
 
iterator() - Method in class com.apple.foundationdb.record.query.combinatorics.EnumeratingIterable.SingleIterable
 
iterator() - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
ITERATOR - Enum constant in enum 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.CipherPool
 

J

JavaCallFunction - Class in com.apple.foundationdb.record.query.plan.cascades.values
Represents a Java user-defined function.
JavaCallFunction() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.JavaCallFunction
 
JDK - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetHashFunctions
 
JNI_CALLS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
JNI Calls.
join(CompletableFuture<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
Join a future, following the same logic that asyncToSync() 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 that asyncToSync() 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 for JoinedRecordType.
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 existing SynchronizedSession.
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 existing SynchronizedSession.
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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBTraceFormat
Format the trace logs as JSON.
jumpMap - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
jumpMap - Static variable in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 

K

key() - Method in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
 
Key - Class in com.apple.foundationdb.record.metadata
Namespace for classes related to KeyExpression construction and evaluation.
KEY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
KEY - Enum constant in enum com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.TupleSource
 
KEY_COMPARATOR - Static variable in class com.apple.foundationdb.record.provider.foundationdb.cursors.KeyComparisons
 
KEY_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
KEY_EVALUATED - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
KEY_EXPRESSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
KEY_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
KEY_SIZE_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
KEY_SPACE_PATH - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
KEY_TO_RECORD - Static variable in class com.apple.foundationdb.record.PipelineOperation
 
KEY_TUPLE - Enum constant in enum 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.
keyChecker - Variable in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
KeyChecker - Interface in com.apple.foundationdb.record.provider.foundationdb
Hook for checking keys passed to a Transaction.
KeyCheckingReadTransaction<T extends ReadTransaction> - Class in com.apple.foundationdb.record.provider.foundationdb
Wrapper around Transaction that performs checks on keys passed to various operations.
KeyCheckingReadTransaction(T, KeyChecker) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
KeyCheckingTransaction - Class in com.apple.foundationdb.record.provider.foundationdb
Wrapper around Transaction that performs checks on keys passed to various operations.
KeyCheckingTransaction(Transaction, KeyChecker) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
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 a Key.Evaluated.NullStandin.NULL_UNIQUE value.
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 - Variable in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
 
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.
KeyExpressionExpansionVisitor - Class in com.apple.foundationdb.record.query.plan.cascades
Expansion visitor that implements the shared logic between primary scan data access and value index access.
KeyExpressionExpansionVisitor() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
 
KeyExpressionExpansionVisitor.VisitorState - Class in com.apple.foundationdb.record.query.plan.cascades
Class that holds the state necessary to expand both primary data access as well as value indexes.
KeyExpressionVisitor<S extends KeyExpressionVisitor.State,R> - Interface in com.apple.foundationdb.record.query.plan.cascades
An interface to provide a state-based visitor pattern that can traverse a tree of KeyExpressions.
KeyExpressionVisitor.State - Interface in com.apple.foundationdb.record.query.plan.cascades
Tag interface to capture state within this visitor.
KeyExpressionWithChild - Interface in com.apple.foundationdb.record.metadata.expressions
A KeyExpression with exactly one child expression.
KeyExpressionWithChildren - Interface in com.apple.foundationdb.record.metadata.expressions
A KeyExpression with child expressions.
KeyExpressionWithoutChildren - Interface in com.apple.foundationdb.record.metadata.expressions
A KeyExpression with no children.
KeyExpressionWithValue - Interface in com.apple.foundationdb.record.metadata.expressions
A key expression that can be represented as a single Value because it meets both of the following criteria: It's a single value rather than a complex tuple. It does not produce multiple values because of fan-out. This is completely unrelated to the (disturbingly) similarly named KeyWithValueExpression.
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.
keySet() - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
keySet() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap
 
keySet() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo
Return the Key Set for info map.
KeySpace - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
A KeySpace defines 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
 
KeySpaceDirectory - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
Defines a directory within a KeySpace.
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
A KeySpacePath represents a discrete path through a directory tree defined by a KeySpace.
KeySpacePathWrapper - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
Helper class to make it easy to create KeySpacePath wrapper implementations for use in KeySpaceDirectory(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
 
KeySpaceTreeResolver - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
Resolve trees of key space paths and record store descendants.
KeySpaceTreeResolver() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver
 
KeySpaceTreeResolver.Resolved - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
The resolved interpretation of the node value.
KeySpaceTreeResolver.ResolvedAndRemainder - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
Result of resolving a Tuple into a KeySpaceTreeResolver.Resolved key space path or other resolved element in the tree.
KeySpaceTreeResolver.ResolvedIndexKeyspace - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
A resolved index keyspace.
KeySpaceTreeResolver.ResolvedKeyField - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
A resolved field of a record primary key or index key.
KeySpaceTreeResolver.ResolvedPath - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
KeySpaceTreeResolver.ResolvedPrefixRoot - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
KeySpaceTreeResolver.ResolvedRoot with a prefix object.
KeySpaceTreeResolver.ResolvedRecordStoreKeyspace - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
A resolved record store keyspace, such as records or indexes.
KeySpaceTreeResolver.ResolvedRecordTypeKeyspace - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
A resolved record type key prefix keyspace.
KeySpaceTreeResolver.ResolvedRoot - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
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 for KeyValueCursor.
KeyValueCursorBase<K extends KeyValue> - Class in com.apple.foundationdb.record.provider.foundationdb
The base class for cursors scanning ranges of the FDB database.
KeyValueCursorBase(FDBRecordContext, AsyncIterator<K>, int, CursorLimitManager, int) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase
 
KeyValueCursorBase.Builder<T extends KeyValueCursorBase.Builder<T>> - Class in com.apple.foundationdb.record.provider.foundationdb
A builder for KeyValueCursorBase.
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
A keyWithValue expression is a top level expression that takes as input an expression that produces more than one column, and indicates that all columns before the specified splitPoint should be used in the key of an index and all of the values starting at the splitPoint are to be used as the value of the index.
KeyWithValueExpression - Class in com.apple.foundationdb.record.metadata.expressions
A KeyWithValue expression is a top level expression that takes as input an expression that produces more than one column, and indicates that all columns before the specified splitPoint should be used in the key of a covering index and all of the values starting at the splitPoint are 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
 
KEYWORD - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
KeywordToken(int, String) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.KeywordToken
 
KNOWN_LAST_KEY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 

L

LARGE - Enum constant in enum com.apple.foundationdb.record.CursorStreamingMode
Advanced.
lastInDBVersion(long) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Returns the last FDBRecordVersion that could have been written at the given database version.
lastInGlobalVersion(byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Return the last FDBRecordVersion that could be written at the given global version.
lastReset - Variable in class com.apple.foundationdb.record.provider.common.StoreTimer
 
LATEST_ENTRY_TIMESTAMP - Enum constant in enum 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.
leaderboardTimestampString() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
 
leaderboardTypeString() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
 
LeafQueryPredicate - Interface in com.apple.foundationdb.record.query.plan.cascades.predicates
Class to model the concept of a predicate.
LeafValue - Interface in com.apple.foundationdb.record.query.plan.cascades.values
A scalar value type that has children.
LEAST - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.ComparisonFunction
 
LEAST_BOOLEAN - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
LEAST_DOUBLE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
LEAST_FLOAT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
LEAST_INT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
LEAST_LONG - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
LEAST_STRING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
LeastFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.LeastFn
 
LEGACY - Enum constant in enum com.apple.foundationdb.record.PlanHashable.PlanHashKind
 
length - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.TransformState
 
LESS_THAN - Enum constant in enum com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison.ComparisonType
 
LESS_THAN - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
LESS_THAN_OR_EQUALS - Enum constant in enum com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison.ComparisonType
 
LESS_THAN_OR_EQUALS - Enum constant in enum 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.QueryKeyExpression.OneOfThem
 
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.QueryKeyExpression.OneOfThem
 
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.
LiftConstructorRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that lifts the fields of a nested record constructor into the current record constructor.
LiftConstructorRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.LiftConstructorRule
 
LIKE - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
LikeFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue.LikeFn
 
likeOperation(String, String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
LikeOperatorValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value that applies a like operator on its child expressions.
LikeOperatorValue(Value, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
Constructs a new instance of LikeOperatorValue.
LikeOperatorValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
LikeOperatorValue.LikeFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The like operator.
LIMIT - Enum constant in enum 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.
LINE_BREAK_OR_SPACE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
LineBreakOrSpaceToken(int) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.LineBreakOrSpaceToken
 
LinkedIdentityMap<K,V> - Class in com.apple.foundationdb.record.query.plan.cascades
A map of items that uses reference equality to determine equivalence for the purposes of set membership, rather than the LinkedIdentityMap.equals(Object) method used by the Java Set interface.
LinkedIdentityMap() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentityMap
 
LinkedIdentitySet<T> - Class in com.apple.foundationdb.record.query.plan.cascades
A set of items that uses reference equality to determine equivalence for the purposes of set membership, rather than the LinkedIdentitySet.equals(Object) method used by the Java Set interface.
LinkedIdentitySet() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
LinkedIdentitySet(Collection<? extends T>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
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
list(FDBRecordContext, String) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
list(FDBRecordContext, String, ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
list(FDBRecordContext, String, ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
list(FDBRecordContext, String, ValueRange<?>, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
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 - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
listAsync(FDBRecordContext, String, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
listAsync(FDBRecordContext, String, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
listAsync(FDBRecordContext, String, ValueRange<?>, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
listAsync(FDBRecordContext, String, ValueRange<?>, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
Deprecated.
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.
listener - Variable in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
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
 
ListMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A collection matcher that binds a sub collection of the collection it is being matched by pairing up the items in the collection (in iteration order) with a list of downstream matchers.
listMissingRangesAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Get all missing ranges.
listMissingRangesAsync(byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexing.IndexingRangeSet
Get all missing ranges within the given boundaries.
listSubdirectory(FDBRecordContext, String) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
Synchronous/blocking version of listSubdirectoryAsync.
listSubdirectory(FDBRecordContext, String, ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
Synchronous/blocking version of listSubdirectoryAsync.
listSubdirectory(FDBRecordContext, String, ValueRange<?>, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
Synchronous/blocking version of listSubdirectoryAsync.
listSubdirectory(FDBRecordContext, String, ValueRange<?>, ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
Synchronous/blocking version of listSubdirectoryAsync.
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
 
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
 
LiteralValue<T> - Class in com.apple.foundationdb.record.query.plan.cascades.values
A wrapper around a literal of the given type.
LiteralValue(Type, T) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
LiteralValue(T) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
LiteralValue.Deserializer<T> - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
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(RecordCursor<V>) - Method in class com.apple.foundationdb.record.sorting.FileSorter
 
load(RecordCursor<V>, K) - Method in class com.apple.foundationdb.record.sorting.MemoryScratchpad
Load and sort records from a cursor.
load(Class<T>) - Static method in class com.apple.foundationdb.record.util.ServiceLoaderProvider
Creates an Iterable of services instances for the given service.
LOAD_BOUNDARY_KEYS - Enum constant in enum 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.cascades.explain.NodeInfo
 
LOAD_INDEX_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of index key-value pairs loaded.
LOAD_INDEX_KEY_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of keys for index key-value pairs loaded.
LOAD_INDEX_VALUE_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of values for index key-value pairs loaded.
LOAD_KEY_VALUE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of key-value pairs loaded by a range scan.
LOAD_META_DATA - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken loading meta-data from a FDBMetaDataStore.
LOAD_RECORD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken loading records.
LOAD_RECORD_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of record key-value pairs loaded.
LOAD_RECORD_KEY_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of keys for record key-value pairs loaded.
LOAD_RECORD_STORE_INDEX_META_DATA - Enum constant in enum 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken loading a record store's DataStoreInfo header.
LOAD_RECORD_STORE_STATE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken loading a record store's RecordStoreState listing store-specific information.
LOAD_RECORD_VALUE_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of values for record key-value pairs loaded.
LOAD_RECORDS_VIA_GETS - Static variable in class com.apple.foundationdb.record.FDBRecordStoreProperties
Whether loading a record should use multiple single-key gets instead of a single scan.
LOAD_SCAN_ENTRY - Enum constant in enum 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of index state key-value pairs loaded.
LOAD_STORE_STATE_KEY_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of keys for index state key-value pairs loaded.
LOAD_STORE_STATE_VALUE_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of values for index state key-value pairs loaded.
LOAD_TEXT_ENTRY - Enum constant in enum 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 for getRecordMetaData.
loadBoundaryKeys(FDBTransactionContext, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
 
loadByPrimaryKeyAsync(FDBRecordStore, Tuple) - Method in class com.apple.foundationdb.record.metadata.JoinedRecordType
 
loadByPrimaryKeyAsync(FDBRecordStore, Tuple) - Method in class com.apple.foundationdb.record.metadata.SyntheticRecordType
 
loadByPrimaryKeyAsync(FDBRecordStore, Tuple) - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordType
 
loadConfig() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
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.
loadIndexingTypeStampAsync(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Load the indexing type stamp for an index.
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 of FDBRecordStore.loadRecordVersion(Tuple) that supports snapshot reads.
loadRecordVersionAsync(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
loadRecordVersionAsync(Tuple, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
loadResolverState(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
 
LoadResult(boolean, boolean, RecordCursorContinuation, RecordCursor.NoNextReason) - Constructor for class com.apple.foundationdb.record.sorting.FileSorter.LoadResult
 
LoadResult(boolean, K, RecordCursorContinuation, RecordCursor.NoNextReason) - Constructor for class com.apple.foundationdb.record.sorting.MemoryScratchpad.LoadResult
 
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 a synthetic record by loading its stored constituent records and synthesizing it from them.
loadSyntheticRecord(Tuple) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Load a synthetic record by loading its stored constituent records and synthesizing it from them.
loadSyntheticRecord(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
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 - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
LocatableResolver - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
LocatableResolver represents 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
 
locationCountMap - Variable in class com.apple.foundationdb.record.query.plan.cascades.debug.Stats
 
LockIdentifier - Class in com.apple.foundationdb.record.locking
Tuple-based identifier used to locate a resource in the LockRegistry.
LockIdentifier(Subspace) - Constructor for class com.apple.foundationdb.record.locking.LockIdentifier
 
LockRegistry - Class in com.apple.foundationdb.record.locking
The LockRegistry keeps track of locking over resources in the context of a single transaction.
LockRegistry(StoreTimer) - Constructor for class com.apple.foundationdb.record.locking.LockRegistry
 
LOCKS_ACQUIRED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
Time spent in waiting for the lock to be acquired.
LOCKS_ATTEMPTED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Count of the locks created.
LOCKS_REGISTERED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
Time taken to register a lock in the registry.
LOCKS_RELEASED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Count of the locks released.
LOG_KEY_SUFFIX_CACHE - Static variable in interface com.apple.foundationdb.record.provider.common.StoreTimer.Event
 
loggable(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
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 interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
 
LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
LOGGER - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
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.RecordQueryIndexPlan
 
LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan
 
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.RecordQuerySelectorPlan
 
LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
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
 
LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
 
LOGGER - Static variable in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
logicalDistinctExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
logicalDistinctExpression(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
LogicalDistinctExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A relational planner expression representing a stream of distinct records.
LogicalDistinctExpression(Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
LogicalDistinctExpression(Reference) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
logicalFilterExpression(BindingMatcher<? extends QueryPredicate>, BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
logicalFilterExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
logicalFilterExpression(CollectionMatcher<? extends QueryPredicate>, CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
logicalFilterExpression(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
LogicalFilterExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A relational planner expression that represents an unimplemented filter on the records produced by its inner relational planner expression.
LogicalFilterExpression(Iterable<? extends QueryPredicate>, Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
logicalIntersectionExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
logicalIntersectionExpression(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
LogicalIntersectionExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A query plan that executes by taking the union of records from two or more compatibly-sorted child plans.
LogicalOperatorNode(RelationalExpression, String, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.LogicalOperatorNode
 
LogicalOperatorNodeWithInfo(RelationalExpression, NodeInfo, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.LogicalOperatorNodeWithInfo
 
logicalProjectionExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
logicalProjectionExpression(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
LogicalProjectionExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A relational planner expression that projects its input values.
LogicalProjectionExpression(List<? extends Value>, Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
logicalSortExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
logicalSortExpression(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
LogicalSortExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A relational planner expression that represents an unimplemented sort on the records produced by its inner relational planner expression.
LogicalSortExpression(RequestedOrdering, Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
LogicalSortExpression(List<Value>, boolean, Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
Deprecated.
logicalTypeFilterExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
logicalTypeFilterExpression(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
LogicalTypeFilterExpression - Class in com.apple.foundationdb.record.query.plan.cascades.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, Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
logicalUnionExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
logicalUnionExpression(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
LogicalUnionExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A relational planner expression that represents an unimplemented union of its children.
LogicalUnionExpression(List<? extends Quantifier>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUnionExpression
 
logicalUniqueExpression(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
LogicalUniqueExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A relational planner expression representing a stream of unique records.
LogicalUniqueExpression(Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUniqueExpression
 
LogicalUniqueExpression(Reference) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUniqueExpression
 
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.MultiDimensionalIndexHelper.Events
 
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
 
logKey() - Method in enum com.apple.foundationdb.record.sorting.SortEvents.Counts
 
logKey() - Method in enum com.apple.foundationdb.record.sorting.SortEvents.Events
 
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
Common KeyValueLogMessage keys logged by the Record Layer core.
logMessageKeyValues() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingThrottle
 
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 appropriate StoreTimer counter 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.RecordQueryAbstractDataModificationPlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
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.RecordQueryDefaultOnEmptyPlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
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.RecordQueryFilterPlanBase
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
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.RecordQueryInUnionPlan
 
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.RecordQueryMapPlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
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.RecordQuerySelectorPlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
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
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
logPlanStructure(StoreTimer) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
logTransaction() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Write the details of this transaction to the FoundationDB client logs.
LONG - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
 
LONG - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
LONG - Enum constant in enum com.apple.foundationdb.record.query.plan.planning.BindingFunction
 
LongArithmethicFunctionKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
Function key expression representing evaluating arithmetic functions on longs.
LongArithmethicFunctionKeyExpression.Builder - Class in com.apple.foundationdb.record.metadata.expressions
LongArithmethicFunctionKeyExpression.LongArithmethicFunctionKeyExpressionFactory - Class in com.apple.foundationdb.record.metadata.expressions
Factory for constructing built-in arithmetic functions that operate on longs.
LongArithmethicFunctionKeyExpressionFactory() - Constructor for class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression.LongArithmethicFunctionKeyExpressionFactory
 
longAverageState() - Static method in class com.apple.foundationdb.record.cursors.aggregate.AverageAccumulatorState
 
longPropertyKey(String, long) - Static method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
 
LongState - Class in com.apple.foundationdb.record.cursors.aggregate
Accumulator state for Long types.
LongState(PrimitiveAccumulatorOperation) - Constructor for class com.apple.foundationdb.record.cursors.aggregate.LongState
 
lookUpFromProto(Class<M>) - Method in class com.apple.foundationdb.record.query.plan.serialization.DefaultPlanSerializationRegistry
 
lookUpFromProto(Class<M>) - Method in interface com.apple.foundationdb.record.query.plan.serialization.PlanSerializationRegistry
 
lookUpMessageClass(String) - Method in class com.apple.foundationdb.record.query.plan.serialization.DefaultPlanSerializationRegistry
 
lookUpMessageClass(String) - Method in interface com.apple.foundationdb.record.query.plan.serialization.PlanSerializationRegistry
 
lookupRecordTypeForReferenceId(int) - Method in class com.apple.foundationdb.record.PlanSerializationContext
 
lookupReferenceIdForRecordType(Type.Record) - Method in class com.apple.foundationdb.record.PlanSerializationContext
 
LOW_BYTES - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
LteFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.LteFn
 
LtFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.LtFn
 

M

MAGENTA - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
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.
majorWithChildren(Collection<? extends QueryPredicate>) - Method in enum com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer.Mode
 
makeComputationValue(Quantifier, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
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 - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
map(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
map(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
map(Iterable<T>, Function<? super T, R>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.IterableHelpers
Maps given function to the given iterable and returns a new iterable.
map(Function<? super T, ? extends U>) - Method in class com.apple.foundationdb.record.RecordCursorResult
Apply a function to the value inside this result, like Optional.map(Function).
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 Protobuf map messages.
MAP_VALUE_FIELD - Static variable in class com.apple.foundationdb.record.metadata.Key.Expressions
The name of the value field in Protobuf map messages.
mapAll(Function<Iterable<? extends T>, Map<T, R>>) - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
mapAll(Map<T, R>) - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
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
 
mapContinuation(Function<byte[], RecordCursor<T>>, RecordCursor.ContinuationConvertor, byte[]) - Static method in interface com.apple.foundationdb.record.RecordCursor
Get a new cursor by applying a transformation to the continuation of each result.
MapCursor<T,V> - Class in com.apple.foundationdb.record.cursors
MapCursor(RecordCursor<T>, Function<T, V>) - Constructor for class com.apple.foundationdb.record.cursors.MapCursor
Deprecated.
 
mapDebugger(Function<Debugger, T>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
Apply the Function on the currently set debugger.
mapDependenciesToOther(AliasMap, CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
Helper to map the dependencies of the given alias to the dependencies of the given other alias if such a mapping is sound, i.e.
mapEach(Function<T, R>) - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
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 a map.
mapKeyValues(String) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
Index key and value from a map.
mapMatches(Function<Field, QueryComponent>, Function<Field, QueryComponent>) - Method in class com.apple.foundationdb.record.query.expressions.Field
Match map field entries.
mapMaybe(BiFunction<T, Iterable<? extends V>, V>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Method that maps the tree-like rooted at this to another tree-like using a fold operation that folds into a TreeLike<V> if the fold exists.
MAPPED_POOL - Static variable in class com.apple.foundationdb.record.provider.common.CipherPool
 
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.
MappingKey(QueryPredicate, QueryPredicate, PredicateMultiMap.PredicateMapping.MappingKind) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.MappingKey
 
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
 
mapPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
mapPlan(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
mapResult(BindingMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
mapResult(Function<RecordCursorResult<T>, RecordCursorResult<V>>) - Method in interface com.apple.foundationdb.record.RecordCursor
Get a new cursor by applying the given function to the results returned by this cursor.
MapResultCursor<T,V> - Class in com.apple.foundationdb.record.cursors
A cursor that applies a function to the elements of another cursor.
MapResultCursor(RecordCursor<T>, Function<RecordCursorResult<T>, RecordCursorResult<V>>) - Constructor for class com.apple.foundationdb.record.cursors.MapResultCursor
Internal constructor.
mapsPlanHash(PlanHashable.PlanHashMode, Map<?, ?>) - Static method in interface com.apple.foundationdb.record.PlanHashable
 
mapToOptional(Function<? super QueryPlanConstraint, ? extends U>) - Method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
Helper method to interface with Optionals.
mapToReverseSortOrder(FO, EnumMap<TupleOrdering.Direction, TO>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
 
mapToSortOrder(FO, EnumMap<TupleOrdering.Direction, TO>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
 
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 a map.
mapValues(String) - Static method in class com.apple.foundationdb.record.metadata.Key.Expressions
Index value from a map.
MapWhileCursor<T,V> - Class in com.apple.foundationdb.record.cursors
A RecordCursor that 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 for RecordCursorResult.getContinuation() after stopping.
MARK_READABLE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.DesiredAction
 
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(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
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.
markIndexReadableOrUniquePending(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Marks an index as readable, but if uniqueness violations are found - mark the index as unique pending instead of throwing a RecordIndexUniquenessViolation exception.
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.IndexingBase
 
markReadableIfBuilt() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Mark the index as readable if it is built.
match() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.ComputingMatcher
match() - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.graph.GenericMatcher
Perform matching.
match(AliasMap, Collection<? extends Quantifier>, Collection<? extends Quantifier>, MatchFunction<Quantifier, M>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
Method to match the given set of quantifiers and the given set of other quantifiers using an alias map and a matchFunction.
match(RelationalExpression, AliasMap, Function<Quantifier, Collection<AliasMap>>, MatchFunction<Quantifier, M>, RelationalExpression.CombineFunction<M, S>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Attempt to match this expression (this graph) with another expression (from another graph called the candidate graph) to produce matches of some kind.
match(RelationalExpression, AliasMap, List<? extends Quantifier>, List<? extends Quantifier>, Function<Quantifier, Collection<AliasMap>>, MatchFunction<Quantifier, M>, RelationalExpression.CombineFunction<M, S>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Attempt to match this expression (this graph) with another expression (from another graph called the candidate graph) to produce matches of some kind.
match(EnumerationFunction<R>, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BaseMatcher
Main method used for matching.
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
 
MATCH_PRE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
 
MatchableSortExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A relational planner expression that represents an unimplemented sort on the records produced by its inner relational planner expression.
MatchableSortExpression(List<CorrelationIdentifier>, boolean, RelationalExpression) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
Overloaded constructor.
MatchableSortExpression(List<CorrelationIdentifier>, boolean, Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
Overloaded constructor.
MatchAccumulator<M,R> - Interface in com.apple.foundationdb.record.query.plan.cascades.matching.graph
Class to used to accumulate the individual match results (the results of applying the MatchFunction) into an object of type R.
matchAndCompensateComparisonMaybe(Value, ValueEquivalence) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Method that attempts to find another value among its descendants, and if it can find them, returns a ComparisonCompensation that can be used to adjust another Comparisons.Comparison.
MatchCandidate - Interface in com.apple.foundationdb.record.query.plan.cascades
Interface to represent a match candidate.
matchConstantValueRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.PullUpValueRuleSet
 
MatchConstantValueRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that matches any Value (with the argument values) that is a constant expression.
MatchConstantValueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchConstantValueRule
 
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(Object) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
Method that attempts to match the current binding matcher against the object passed in and just returns whether the matching process produced any matches at all thus forsaking all actual bindings accrued in the matching process.
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.
matchesExactly(Object) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
Method that attempts to match the current binding matcher against the object passed in and just returns whether the matching process produced one single match thus forsaking all actual bindings accrued in the matching process.
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
 
MATCHEXPCAND - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
 
matchFieldValueAgainstQuantifiedObjectValueRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.PullUpValueRuleSet
 
MatchFieldValueAgainstQuantifiedObjectValueRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that matches a QuantifiedObjectValue (with the argument values).
MatchFieldValueAgainstQuantifiedObjectValueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchFieldValueAgainstQuantifiedObjectValueRule
 
matchFieldValueOverFieldValueRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExtractFromIndexKeyValueRuleSet
 
MatchFieldValueOverFieldValueRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that matches a FieldValue over another FieldValue to simplify into one FieldValue using a concatenated accessor path.
MatchFieldValueOverFieldValueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchFieldValueOverFieldValueRule
 
MatchFunction<T,M> - Interface in com.apple.foundationdb.record.query.plan.cascades.matching.graph
An functional interface for a match function that computes a match result (an Iterable of type M.
MatchInfo - Interface in com.apple.foundationdb.record.query.plan.cascades
This interface represents the result of matching one expression against an expression from a MatchCandidate.
MatchInfo.AdjustedBuilder - Class in com.apple.foundationdb.record.query.plan.cascades
Builder for an adjusted MatchInfo.
MatchInfo.AdjustedMatchInfo - Class in com.apple.foundationdb.record.query.plan.cascades
An adjusted MatchInfo that is based on another underlying MatchInfo.
MatchInfo.RegularMatchInfo - Class in com.apple.foundationdb.record.query.plan.cascades
Implementation of MatchInfo that represents a match between two expressions.
matchInfosFromMap(IdentityBiMap<Quantifier, PartialMatch>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
matchingAllOf(Class<T>, BindingMatcher<?>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AllOfMatcher
 
matchingAllOf(Class<T>, Collection<? extends BindingMatcher<?>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AllOfMatcher
 
matchingAnyOf(Class<T>, Collection<? extends BindingMatcher<?>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.AnyOfMatcher
 
MatchIntermediateRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
Expression-based transformation rule that matches any non-leaf expression (called an intermediate expression) to a candidate expression in a MatchCandidate.
MatchIntermediateRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.MatchIntermediateRule
 
MatchIntermediateRule.PartialMatchWithQuantifier - Class in com.apple.foundationdb.record.query.plan.cascades.rules
Partial match with a quantifier pulled up along with the partial match during matching.
MatchLeafRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
Expression-based transformation rule that matches any leaf expression.
MatchLeafRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.MatchLeafRule
 
matchOrCompensateFieldValueRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.PullUpValueRuleSet
 
MatchOrCompensateFieldValueRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that matches a FieldValue (with the argument values).
MatchOrCompensateFieldValueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchOrCompensateFieldValueRule
 
MatchPartition - Class in com.apple.foundationdb.record.query.plan.cascades
Case class to represent a partition of partial matches.
MatchPartitionMatchers - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Matchers for MatchPartition.
MatchPredicate<T> - Interface in com.apple.foundationdb.record.query.plan.cascades.matching.graph
An predicate that tests for a match between quantifiers also taking into account an equivalence maps between CorrelationIdentifiers.
matchSimpleFieldValueRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExtractFromIndexKeyValueRuleSet
 
MatchSimpleFieldValueRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that matches any simple FieldValue, i.e.
MatchSimpleFieldValueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchSimpleFieldValueRule
 
matchValueAgainstQuantifiedObjectValueRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.PullUpValueRuleSet
 
MatchValueAgainstQuantifiedObjectValueRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that matches a Value against the current QuantifiedObjectValue.
MatchValueAgainstQuantifiedObjectValueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchValueAgainstQuantifiedObjectValueRule
 
matchValueRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.PullUpValueRuleSet
 
MatchValueRule - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule that matches a Value (with the argument values).
MatchValueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchValueRule
 
Max(PlanSerializationContext, PNumericAggregationValue.PMax) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Max
 
Max(NumericAggregationValue.PhysicalOperator, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Max
 
MAX - Enum constant in enum com.apple.foundationdb.record.cursors.aggregate.PrimitiveAccumulatorOperation
 
MAX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.PermutedMinMaxIndexMaintainer.Type
 
MAX - Static variable in class com.apple.foundationdb.record.FunctionNames
 
MAX_ATTEMPTS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
MAX_COMPLEXITY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
MAX_COMPRESSION_VERSION - Static variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
 
MAX_D - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
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.
use IndexTypes.MAX_EVER_LONG for compatibility with existing data or IndexTypes.MAX_EVER_TUPLE for more flexibility
MAX_EVER_LONG - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
 
MAX_EVER_LONG - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.PhysicalOperator
 
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 - Enum constant in enum 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 - Enum constant in enum 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_F - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
MAX_I - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
MAX_KEY_LENGTH - Static variable in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
MAX_L - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
MAX_LIMIT - Enum constant in enum 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 - Enum constant in enum 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_RULE_MATCHES_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
MAX_SUPPORTED_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
MAX_TASK_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
MAX_TASK_QUEUE_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
MAX_TASK_QUEUE_SIZE - Static variable in class com.apple.foundationdb.record.query.plan.QueryPlanInfoKeys
 
MAX_TOKEN_SIZE - Enum constant in enum 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_VALUE_LENGTH - Static variable in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
MAX_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Maximum possible complete FDBRecordVersion value.
maxCardinality() - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan.KeysSource
 
maxCardinality(RecordMetaData) - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
Indicates how many records this plan could possibly return.
maxCardinality(RecordMetaData) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
maxCardinality(RecordMetaData) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
maxCardinality(RecordMetaData) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
maxCardinality(RecordMetaData) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
maxCardinality(RecordMetaData) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
maxCardinality(RecordMetaData) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
maxCardinality(RecordMetaData) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
 
maxCardinality(RecordMetaData) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
MaxEverFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MaxEverFn
 
MaxFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.MaxFn
 
maximumType(Type, Type) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Find the maximum type of two types.
MaxMatchMap - Class in com.apple.foundationdb.record.query.plan.cascades.values.translation
Represents a maximum match between a query result Value and a candidate result Value.
MaxMatchMapSimplificationRuleSet - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A set of rules for use by the maximum map computation logic.
maxNumberOfValuesAllowed - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
MEDIUM - Enum constant in enum com.apple.foundationdb.record.CursorStreamingMode
Advanced.
members() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer.ReferenceBuilder
 
members(CollectionMatcher<E>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ReferenceMatchers
 
memoizeExpression(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
memoizeExpression(RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
memoizeExpressionBuilder(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
memoizeExpressionBuilder(RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
memoizeLeafExpression(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
memoizeLeafExpression(RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
memoizeMemberPlans(Reference, Collection<? extends RecordQueryPlan>) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
memoizeMemberPlans(Reference, Collection<? extends RecordQueryPlan>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
memoizeMemberPlansBuilder(Reference, Collection<? extends RecordQueryPlan>) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
memoizeMemberPlansBuilder(Reference, Collection<? extends RecordQueryPlan>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
memoizePlans(RecordQueryPlan...) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
memoizePlans(RecordQueryPlan...) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
memoizePlans(Collection<? extends RecordQueryPlan>) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
memoizePlans(Collection<? extends RecordQueryPlan>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
memoizePlansBuilder(RecordQueryPlan...) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
memoizePlansBuilder(RecordQueryPlan...) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
memoizePlansBuilder(Collection<? extends RecordQueryPlan>) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
memoizePlansBuilder(Collection<? extends RecordQueryPlan>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
Memoizer - Interface in com.apple.foundationdb.record.query.plan.cascades
A memoization interface.
Memoizer.ReferenceBuilder - Interface in com.apple.foundationdb.record.query.plan.cascades
Builder for references.
memoizeReference(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
memoizeReference(Reference) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
MEMORY_SORT_LOAD_RECORD - Enum constant in enum com.apple.foundationdb.record.sorting.SortEvents.Events
 
MEMORY_SORT_STORE_RECORD - Enum constant in enum com.apple.foundationdb.record.sorting.SortEvents.Events
 
MemoryDam<K,V> - Class in com.apple.foundationdb.record.sorting
Collect keyed values into a LinkedHashMap so that they end up sorted in insertion order.
MemoryDam(MemorySortAdapter<K, V>, StoreTimer) - Constructor for class com.apple.foundationdb.record.sorting.MemoryDam
 
MemoryScratchpad<K,V,M extends Map<K,V>> - Class in com.apple.foundationdb.record.sorting
Collect keyed values into an in-memory data structure.
MemoryScratchpad(MemorySortAdapter<K, V>, M, StoreTimer) - Constructor for class com.apple.foundationdb.record.sorting.MemoryScratchpad
 
MemoryScratchpad.LoadResult<K> - Class in com.apple.foundationdb.record.sorting
MemoryScratchpad.RecordCountInMemoryLimitMode - Enum in com.apple.foundationdb.record.sorting
How the getMaxRecordCountInMemory is interpreted for MemoryScratchpad.load(com.apple.foundationdb.record.RecordCursor<V>, K).
MemorySortAdapter<K,V> - Interface in com.apple.foundationdb.record.sorting
Provide various options for MemorySorter and MemorySortCursor.
MemorySortAdapter.InsertionOrderComparator<K> - Class in com.apple.foundationdb.record.sorting
Stateful comparator supporting insertion order and delegating to a regular Comparator to establish equality between the minimum key and a probe.
MemorySortAdapter.MemorySortComparator<K> - Interface in com.apple.foundationdb.record.sorting
An extended version of a comparator that can be stateful.
MemorySortAdapter.OrderComparator<K> - Class in com.apple.foundationdb.record.sorting
Stateful comparator to support orderings based on regular comparisons delegated to a Comparator.
MemorySortCursor<K,V> - Class in com.apple.foundationdb.record.sorting
Sort records in memory up to a specified limit, then return them in order.
MemorySorter<K,V> - Class in com.apple.foundationdb.record.sorting
Collect keyed values into a TreeMap so that they end up sorted.
MemorySorter(MemorySortAdapter<K, V>, StoreTimer) - Constructor for class com.apple.foundationdb.record.sorting.MemorySorter
 
merge(Comparisons.Comparison) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
Checks whether the comparison is already defined in this ComparisonRange.
merge(ComparisonRange) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
merge(Ordering, Ordering, Ordering.MergeOperator<O>, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
Method to combine a list of Orderings into one O that extends Ordering.SetOperationsOrdering.
merge(ScanComparisons) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
merge(Equivalence.Wrapper<K>, Equivalence.Wrapper<V>, BiFunction<? super Equivalence.Wrapper<V>, ? super Equivalence.Wrapper<V>, ? extends Equivalence.Wrapper<V>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
merge(Iterable<Ordering>, Ordering.MergeOperator<O>, BiPredicate<O, O>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
MERGE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl.LastStep
 
MERGE_INDEX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent merging an index (explicitly or during indexing).
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 of MergeCursors.
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.cascades.matching.structure.PlannerBindings
Combine this set of bindings with the given set of bindings.
MergeFetchIntoCoveringIndexRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that merges a fetch into a covering index scan.
MergeFetchIntoCoveringIndexRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.MergeFetchIntoCoveringIndexRule
 
mergeHadFailed() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Adjust merge stats after a failure.
mergeIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
 
mergeIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
 
mergeIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
If the index is merge'Able, perform an index merge (within a single transaction limit).
mergeIndex() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
If applicable, merge the target indexes as a background maintenance.
mergeIndexAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
If applicable, merge the target indexes as a background maintenance.
mergeIndexes() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
mergeNoNextReason() - Method in class com.apple.foundationdb.record.provider.foundationdb.SplitHelper.KeyValueUnsplitter
 
mergeNoNextReasons() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ComparatorCursor
Calculate and return the reason the cursor returns a no-next result.
mergeNoNextReasons() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.IntersectionMultiCursor
Merges all of the cursors and whether they have stopped and returns the "weakest" reason for the result to stop.
mergeNoNextReasons() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
Merge the RecordCursor.NoNextReasons for child cursors.
mergeNoNextReasons() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.ProbableIntersectionCursor
 
mergeNoNextReasons() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.UnionCursor
Merges all of the cursors and whether they have stopped and returns the "strongest" reason for the result to stop.
MergeProjectionAndFetchRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that removes a LogicalProjectionExpression and a RecordQueryFetchFromPartialRecordPlan if all fields needed by the projection are already available prior to the fetch.
MergeProjectionAndFetchRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.MergeProjectionAndFetchRule
 
mergeRecordTypeAndComponent(String, QueryComponent) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
mergeValues(Iterable<? extends Quantifier>) - Static method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan
Helper method to create a new DerivedValue above all incoming data streams.
mergeWith(FilterSatisfiedMask) - Method in class com.apple.foundationdb.record.query.plan.planning.FilterSatisfiedMask
Merge in another mask over the same filter.
MESSAGE - Enum constant in enum 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
 
MessageHelpers - Class in com.apple.foundationdb.record.query.plan.cascades.values
A utility class for extracting data and meta-data from Protocol Buffer Messages, as used in the Record Layer.
MessageHelpers.CoercionBiFunction - Interface in com.apple.foundationdb.record.query.plan.cascades.values
Coercion (bi)-function which also is plan hashable.
MessageHelpers.CoercionTrieNode - Class in com.apple.foundationdb.record.query.plan.cascades.values
Trie data structure of Type.Record.Fields to conversion functions used to coerce an object of a certain type into an object of another type.
MessageHelpers.TransformationTrieNode - Class in com.apple.foundationdb.record.query.plan.cascades.values
Trie data structure of Type.Record.Fields to Values.
META_DATA_VERSION - Enum constant in enum 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 for FDBMetaDataStore.
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 the MetaDataEvolutionValidator.
MetaDataException - Exception in com.apple.foundationdb.record.metadata
Exception thrown when there is a problem with something in the RecordMetaDataProto.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.cascades
A PlanContext where the underlying meta-data comes from RecordMetaData and RecordStoreState objects, as is generally the case when planning actual queries.
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 for RecordMetaData.
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 the FDBRecordStoreStateCache that 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 creating MetaDataVersionStampStoreStateCaches.
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(PlanSerializationContext, PNumericAggregationValue.PMin) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Min
 
Min(NumericAggregationValue.PhysicalOperator, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Min
 
MIN - Enum constant in enum com.apple.foundationdb.record.cursors.aggregate.PrimitiveAccumulatorOperation
 
MIN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.PermutedMinMaxIndexMaintainer.Type
 
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_D - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
MIN_EVER - Static variable in class com.apple.foundationdb.record.FunctionNames
 
MIN_EVER - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
Deprecated.
use IndexTypes.MIN_EVER_LONG for compatibility with existing data or IndexTypes.MIN_EVER_TUPLE for more flexibility
MIN_EVER_LONG - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
 
MIN_EVER_LONG - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.PhysicalOperator
 
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 - Enum constant in enum 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_F - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
MIN_I - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
MIN_L - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
MIN_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Minimum possible complete FDBRecordVersion value.
MinEverFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MinEverFn
 
MinFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.MinFn
 
MinimumTupleSizeKeyChecker - Class in com.apple.foundationdb.record.provider.foundationdb
Key checker that reports when operations are not limited to a single tuple subspace of a given minimum size.
MinimumTupleSizeKeyChecker(List<MinimumTupleSizeKeyChecker.CheckedSubspace>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.MinimumTupleSizeKeyChecker
Create a new checker.
MinimumTupleSizeKeyChecker.CheckedSubspace - Class in com.apple.foundationdb.record.provider.foundationdb
A key prefix and associated check settings.
minorWithChildren(Collection<? extends QueryPredicate>) - Method in enum com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer.Mode
 
MISSING - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry.Reasons
 
MISSING - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.IndexScrubbingTools.ScrubbingType
 
MISSING_RANGES - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
MissingMetaDataException(String) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore.MissingMetaDataException
 
MOD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
MOD - Static variable in class com.apple.foundationdb.record.FunctionNames
 
MOD_DD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_DF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_DI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_DL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_FD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_FF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_FI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_FL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_ID - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_IF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_II - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_IL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_LD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_LF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_LI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MOD_LL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
ModFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.ModFn
 
MODIFICATION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
ModificationLogicalOperatorNode(RelationalExpression, NodeInfo, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationLogicalOperatorNode
 
ModificationOperatorNodeWithInfo(RecordQueryPlan, NodeInfo) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationOperatorNodeWithInfo
 
ModificationOperatorNodeWithInfo(RecordQueryPlan, NodeInfo, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationOperatorNodeWithInfo
 
ModificationOperatorNodeWithInfo(RecordQueryPlan, NodeInfo, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationOperatorNodeWithInfo
 
ModificationTargetEdge() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationTargetEdge
 
ModificationTargetEdge(String, Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationTargetEdge
 
ModificationTargetEdge(Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ModificationTargetEdge
 
morphFrom(Quantifier.ForEach) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical.PhysicalBuilder
Build a new physical quantifier from a for-each quantifier with the same alias.
MUL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
MUL_DD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_DF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_DI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_DL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_FD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_FF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_FI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_FL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_ID - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_IF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_II - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_IL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_LD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_LF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_LI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MUL_LL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
MulFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.MulFn
 
MULTI_TARGET_TO_SINGLE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.TakeoverTypes
Allow a single target indexing continuation when the index was partly built with other indexes (as multi target).
MultiColumnComparison(Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
multidimensional() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
MULTIDIMENSIONAL - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
An index using multiple numerical dimensions based on a Hilbert R-tree.
MULTIDIMENSIONAL_CHILD_NODE_DISCARDS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
 
MULTIDIMENSIONAL_INTERMEDIATE_NODE_READ_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
 
MULTIDIMENSIONAL_INTERMEDIATE_NODE_READS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
 
MULTIDIMENSIONAL_INTERMEDIATE_NODE_WRITE_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
 
MULTIDIMENSIONAL_INTERMEDIATE_NODE_WRITES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
 
MULTIDIMENSIONAL_LEAF_NODE_READ_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
 
MULTIDIMENSIONAL_LEAF_NODE_READS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
 
MULTIDIMENSIONAL_LEAF_NODE_WRITE_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
 
MULTIDIMENSIONAL_LEAF_NODE_WRITES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
 
MULTIDIMENSIONAL_MODIFICATION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.MultiDimensionalIndexHelper.Events
 
MULTIDIMENSIONAL_SCAN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.MultiDimensionalIndexHelper.Events
 
MULTIDIMENSIONAL_SKIP_SCAN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.MultiDimensionalIndexHelper.Events
 
MultiDimensionalIndexHelper - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
Helper functions for index maintainers that use a RTree.
MultiDimensionalIndexHelper.Events - Enum in com.apple.foundationdb.record.provider.foundationdb.indexes
Instrumentation events specific to R-tree index maintenance.
MultidimensionalIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
An index maintainer for keeping a RTree.
MultidimensionalIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.MultidimensionalIndexMaintainer
 
MultidimensionalIndexMaintainerFactory - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
A factory for MultidimensionalIndexMaintainer indexes.
MultidimensionalIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.MultidimensionalIndexMaintainerFactory
 
MultidimensionalIndexScanBounds - Class in com.apple.foundationdb.record.provider.foundationdb
IndexScanBounds for a multidimensional index scan.
MultidimensionalIndexScanBounds(TupleRange, MultidimensionalIndexScanBounds.SpatialPredicate, TupleRange) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds
 
MultidimensionalIndexScanBounds.And - Class in com.apple.foundationdb.record.provider.foundationdb
Scan bounds that consists of other MultidimensionalIndexScanBounds.SpatialPredicates to form a logical AND.
MultidimensionalIndexScanBounds.Hypercube - Class in com.apple.foundationdb.record.provider.foundationdb
Scan bounds describing an n-dimensional hypercube.
MultidimensionalIndexScanBounds.Or - Class in com.apple.foundationdb.record.provider.foundationdb
Scan bounds that consists of other MultidimensionalIndexScanBounds.SpatialPredicates to form a logical OR.
MultidimensionalIndexScanBounds.SpatialPredicate - Interface in com.apple.foundationdb.record.provider.foundationdb
Spatial predicate.
MultidimensionalIndexScanComparisons - Class in com.apple.foundationdb.record.provider.foundationdb
ScanComparisons for use in a multidimensional index scan.
MultidimensionalIndexScanComparisons(ScanComparisons, List<ScanComparisons>, ScanComparisons) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
MultidimensionalIndexScanComparisons.Deserializer - Class in com.apple.foundationdb.record.provider.foundationdb
Deserializer.
MultiMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A multi matcher is a CollectionMatcher and by extension also a BindingMatcher that binds to a sub collection of objects in the presented collection.
MultiMatcher(BindingMatcher<T>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MultiMatcher
 
MultiMatcher.AllMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A multi matcher that binds to all objects in the collection it is being matched or it does not match anything at all, i.e.
MultiMatcher.SomeMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A multi matcher that binds a sub collection of objects of the collection it is being matched.
MULTIPLICATIVE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
MULTIPLY - Static variable in class com.apple.foundationdb.record.FunctionNames
 
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 for name within 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 for name within 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
 
mutate(MutationType, byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
mutate(MutationType, byte[], byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
MUTATE_INDEX_ENTRY - Enum constant in enum 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.
mutateRecord(FDBRecordStoreBase<M>, EvaluationContext, QueryResult, Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
mutation - Variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutationIndexMaintainer
 
MUTATION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
MUTATIONS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Total number of mutation operations.
MUTUAL_INDEXER_ANY_DONE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
IndexingMutuallyByRecords counter: start indexing an 'ANY' fragment.
MUTUAL_INDEXER_ANY_JUMP - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
IndexingMutuallyByRecords counter: done indexing an 'ANY' fragment.
MUTUAL_INDEXER_ANY_START - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
IndexingMutuallyByRecords counter: done indexing a 'FULL' fragment.
MUTUAL_INDEXER_FULL_DONE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
IndexingMutuallyByRecords counter: start indexing a 'FULL' fragment.
MUTUAL_INDEXER_FULL_START - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of OnlineIndexer range scans terminated after hitting the cursor's range depletion.
MUTUAL_TO_SINGLE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.TakeoverTypes
Allow a single target indexing continuation when the index was partly built as mutual indexing (either single or multi target).

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() - Method in interface com.apple.foundationdb.record.query.plan.cascades.OrderingPart.SortOrder
Name of the sort order; is implemented by the enum implementing this interface.
NAME - Static variable in class com.apple.foundationdb.record.provider.common.text.DefaultTextTokenizer
The name of the default tokenizer.
NamedCluster(String, Set<PlannerGraph.Node>, GraphExporter.ClusterProvider<PlannerGraph.Node, PlannerGraph.Edge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty.NamedCluster
 
nameForObject(Object) - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
narrow(Class<Q>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
narrow(Class<Q>, List<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
 
narrow(Class<Q>, Set<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
 
narrow(Class<V>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
narrow(Object) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo.QueryPlanInfoKey
 
Narrowable<T> - Interface in com.apple.foundationdb.record.query.plan.cascades
Narrow-able trait that can safely downcast to a particular implementation.
narrowArrayMaybe() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Safe-casts this into a Type.Array.
narrowAttribute(Object) - Method in interface com.apple.foundationdb.record.query.plan.cascades.PlanProperty
Method to narrow the type from Object to the declared type of the attribute.
narrowConstraint(Object) - Method in interface com.apple.foundationdb.record.query.plan.cascades.PlannerConstraint
Method to narrow the type from Object, e.g.
narrowEnumMaybe() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Safe-casts this into a Type.Enum.
narrowMaybe(Class<Q>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
narrowMaybe(Class<T1>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Narrowable
Safe-casts the Narrowable instance to another type.
narrowRecordMaybe() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Safe-casts this into a Type.Record.
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.
needRebuildIndex(Index, Supplier<CompletableFuture<Long>>, Supplier<CompletableFuture<Long>>, boolean) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.UserVersionChecker
Determine what to do about an index needing to be rebuilt.
needsCopyingToPartialRecord() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
needsCopyingToPartialRecord() - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
 
needsCopyingToPartialRecord() - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
 
needsCopyingToPartialRecord() - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpression
Method to determine if data in an index represented by this key expression needs to be copied from an index entry to a partial record.
needsCopyingToPartialRecord() - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
 
needsCopyingToPartialRecord() - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
 
needsCopyingToPartialRecord() - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
 
needsCopyingToPartialRecord() - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
 
needsCopyingToPartialRecord() - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
 
needsCopyingToPartialRecord() - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
 
needsCopyingToPartialRecord() - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
 
needsExploration() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
needsRebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.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 for nest(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 - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
NESTED_LOOP_JOIN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
nestedComponents(Stream<QueryComponent>) - Static method in interface com.apple.foundationdb.record.query.expressions.BooleanComponent
 
NestedField - Class in com.apple.foundationdb.record.query.expressions
A QueryComponent that evaluates a nested component against a Message-valued field.
NestedField(String, QueryComponent) - Constructor for class com.apple.foundationdb.record.query.expressions.NestedField
 
NestedInvertableComparisonCompensation(Value.InvertableValue<?>, NonnullPair<ComparisonCompensation, QueryPlanConstraint>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComparisonCompensation.NestedInvertableComparisonCompensation
 
NestedRecordType - Class in com.apple.foundationdb.record.metadata
Extension of record type representing a nested message within a larger record type.
NestedRecordType(RecordMetaData, Descriptors.Descriptor, RecordType, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.NestedRecordType
 
NestedRecordTypeBuilder - Class in com.apple.foundationdb.record.metadata
Builder class for NestedRecordTypes.
NestedRecordTypeBuilder(Descriptors.Descriptor) - Constructor for class com.apple.foundationdb.record.metadata.NestedRecordTypeBuilder
 
nestedResults(Value, Value) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
NestedToken(int, ExplainTokens, ExplainTokens.Token) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.NestedToken
 
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
 
nestPullUp(PullUp, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
networkExecutor - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
NEVER - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardWindowUpdate.Rebuild
 
NEVER_PARENS - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
NEW - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
NEW - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
 
NEW_FIELD_NAME - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
NEW_FIELD_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
NEW_FORMAT_VERSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
NEW_INDEX_NAME - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
NEW_INDEX_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
NEW_KEY_EXPRESSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
NEW_OPTION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
NEW_RECORD_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
NEW_STORE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
NEW_STORE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
 
NEW_VERSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
newAliasResolver() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
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.IndexingPolicy
Create an indexing policy builder.
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.provider.foundationdb.OnlineIndexOperationConfig
 
newBuilder() - Static method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber
 
newBuilder() - Static method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy
Create an scrubbing policy builder.
newBuilder() - Static method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyStorage
 
newBuilder() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings
Return a new builder.
newBuilder() - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
Creates a new instance of RangeConstraints.Builder.
newBuilder() - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Creates a new dynamic schema builder.
newBuilder() - Static method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo
 
newBuilder() - Static method in class com.apple.foundationdb.record.query.RecordQuery
 
newBuilder() - Static method in class com.apple.foundationdb.record.RecordMetaData
Creates an instance of RecordMetaDataBuilder.
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 new TransformedRecordSerializer.Builder instance around the given serializer.
newBuilder(RecordSerializer<M>) - Static method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
Creates a new TransformedRecordSerializerJCE.Builder instance 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(Subspace) - Static method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
 
newBuilder(Subspace, byte[]) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexPrefetchRangeKeyValueCursor.Builder
 
newBuilder(Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
 
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.
newCallsite(List<Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfFunction
 
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
 
newConstituent(String, RecordTypeBuilder) - Method in class com.apple.foundationdb.record.metadata.UnnestedRecordTypeBuilder
 
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 new Executor for use by a specific FDBRecordContext.
newDefaultBuilder() - Static method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
Creates a new TransformedRecordSerializer.Builder instance that is backed by the default serializer for Messages, namely a DynamicMessageRecordSerializer.
newDefaultBuilder() - Static method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE
Creates a new TransformedRecordSerializerJCE.Builder instance that is backed by the default serializer for Messages, namely a DynamicMessageRecordSerializer.
newExp(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
newForCurrentMode() - Static method in class com.apple.foundationdb.record.PlanSerializationContext
 
newForCurrentMode(PlanSerializationRegistry) - Static method in class com.apple.foundationdb.record.PlanSerializationContext
 
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.
newInstanceWithoutRanges(Value, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
newLine(String) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
 
newMessageBuilder(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Creates a new dynamic message builder for the given type.
newMessageBuilder(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Creates a new dynamic message builder for the given message type.
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
 
newParameterAlias() - Static method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
Creates a new parameter alias.
newPlanSerializationContext(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
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 an FDBDatabaseRunner for use against this database.
newRunner() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Get a new FDBDatabaseRunner that will run contexts similar to this one.
newRunner(FDBRecordContextConfig.Builder) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
Create an FDBDatabaseRunner for use against this database.
newRunner(FDBStoreTimer, Map<String, String>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
Create an FDBDatabaseRunner for use against this database.
newRunner(FDBStoreTimer, Map<String, String>, FDBDatabase.WeakReadSemantics) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
Create an FDBDatabaseRunner for use against this database.
next() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Returns an incremented version of the current FDBRecordVersion.
next() - Method in class com.apple.foundationdb.record.RecordCursorIterator
Return the next value.
NEXT_CONTINUATION - Enum constant in enum 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
 
nextMinimumKey() - Method in class com.apple.foundationdb.record.sorting.MemorySortAdapter.InsertionOrderComparator
 
nextMinimumKey() - Method in interface com.apple.foundationdb.record.sorting.MemorySortAdapter.MemorySortComparator
 
nextMinimumKey() - Method in class com.apple.foundationdb.record.sorting.MemorySortAdapter.OrderComparator
 
nextResult - Variable in class com.apple.foundationdb.record.cursors.AsyncIteratorCursor
 
nextResult - Variable in class com.apple.foundationdb.record.cursors.RowLimitedCursor
 
NO_COMPENSATION - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
Named object to indicate that this compensation is in fact no compensation, that is no additional operators need to be injected to compensate for a match.
NO_COMPENSATION - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComparisonCompensation
 
NO_COMPENSATION - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueCompensation
 
NO_COMPENSATION_NEEDED - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateCompensationFunction
 
NO_COMPENSATION_NEEDED - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.ResultCompensationFunction
 
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 - Enum constant in enum com.apple.foundationdb.record.query.QueryToKeyMatcher.MatchType
 
NO_MEMO - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
NO_NEXT_REASON - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
NO_NULLS - Static variable in interface com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter
Do not put null values into the index.
NO_VERSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.VersionstampSaveBehavior
Do not save the record with a version.
noChooseBindingCheck(SetMultimap<Value, Ordering.Binding>, PartiallyOrderedSet<Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
noCompensation() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
Returns a compensation which represents no compensation at all, i.e.
noCompensation() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComparisonCompensation
 
noCompensation() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueCompensation
 
noCompensationNeeded() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateCompensationFunction
 
noCompensationNeeded() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.ResultCompensationFunction
 
Node(Object, String) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Node
 
Node(Object, String, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Node
 
Node(Object, String, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.Node
 
NodeIcon - Class in com.apple.foundationdb.record.query.plan.cascades.explain
NodeIcon Ids.
NodeIcon(String) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.NodeIcon
 
NodeInfo - Class in com.apple.foundationdb.record.query.plan.cascades.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.cascades.explain.NodeInfo
 
nodeOrder() - Method in class com.google.common.graph.StableStandardMutableNetwork
 
nodes() - Method in class com.google.common.graph.StableStandardMutableNetwork
 
NodeWithInfo(Object, NodeInfo) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.NodeWithInfo
 
NodeWithInfo(Object, NodeInfo, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.NodeWithInfo
 
NodeWithInfo(Object, NodeInfo, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.NodeWithInfo
 
noMemo() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer
 
nonBooleanSubComponents() - Method in interface com.apple.foundationdb.record.query.expressions.BooleanComponent
Starting from this boolean component find all sub components that itself are not considered BooleanComponents.
NonbuildableException(String) - Constructor for exception com.apple.foundationdb.record.metadata.RecordTypeBuilder.NonbuildableException
 
None - Enum constant in enum com.apple.foundationdb.record.metadata.expressions.KeyExpression.FanType
Nothing, only allowed with scalar fields.
None() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
NONE - Enum constant in enum com.apple.foundationdb.record.cursors.MapWhileCursor.StopContinuation
Return null.
NONE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.RecordExistenceCheck
No special action.
NONE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.StoreExistenceCheck
No special action.
NONE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl.LastStep
 
NONE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter.IndexValues
 
NONE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
NONE - Enum constant in enum com.apple.foundationdb.record.query.plan.ScanComparisons.ComparisonType
 
NONE - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
noneType() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
NonnullPair<L,R> - Class in com.apple.foundationdb.record.util.pair
A Pair implementation where both elements are not null.
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 for NoOpIndexMaintainer indexes.
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.
NormalFormRule - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A rule that transforms a boolean expression into a normal form.
NormalFormRule(BooleanPredicateNormalizer) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.NormalFormRule
 
normalizationCheck(SetMultimap<Value, Ordering.Binding>, PartiallyOrderedSet<Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
normalizationCheckConsumer() - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
normalize(QueryComponent) - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
Convert the given predicate to disjunctive normal form, if necessary.
normalize(QueryPredicate, boolean) - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer
Convert the given predicate to its respective normal form, if necessary.
normalizeAndSimplify(QueryPredicate, boolean) - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer
Convert the given predicate to its respective normal form, if necessary.
normalizeBindingMap(SetMultimap<Value, Ordering.Binding>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
Helper method to normalize the binding map handed in.
NormalizedResidualPredicateProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
This property collects a QueryPredicate that represents the entirety of all accumulated residual predicates.
NormalizedResidualPredicateProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.NormalizedResidualPredicateProperty
 
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.DimensionsKeyExpression
 
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
 
normalizeOrderingSet(SetMultimap<Value, Ordering.Binding>, PartiallyOrderedSet<Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
Method to normalize a partially-ordered set representing an ordering, that is, it removes all dependencies from or to a particular element contained in the set if that element is also has a binding that is fixed.
NormalizePredicatesRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
Rule to create the conjunctive normal form of the predicates in a SelectExpression.
NormalizePredicatesRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.NormalizePredicatesRule
 
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 a KeySpaceDirectory does 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(BindingMatcher<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.NotMatcher
 
not(QueryPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
NOT - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
NOT_ALLOWED_FOR_QUERY_OPTIONS - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
Options to set to disable IndexOptions.ALLOWED_FOR_QUERY_OPTION.
NOT_CACHEABLE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.StateCacheabilityOnOpen
Update the store state cacheability flag to false during FDBRecordStore.checkVersion(UserVersionChecker, StoreExistenceCheck).
NOT_DISTINCT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering.Distinctness
 
NOT_EQUALS - Enum constant in enum com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison.ComparisonType
 
NOT_EQUALS - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
NOT_EQUALS - Enum constant in enum com.apple.foundationdb.record.query.ParameterRelationshipGraph.RelationshipType
 
NOT_NULL - Enum constant in enum com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison.ComparisonType
 
NOT_NULL - Enum constant in enum com.apple.foundationdb.record.metadata.Key.Evaluated.NullStandin
 
NOT_NULL - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
NOT_ORDER_PRESERVING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.Ordering.OrderPreservingKind
 
notAllRangesExhausted(Tuple, Tuple) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
NotComponent - Class in com.apple.foundationdb.record.query.expressions
A QueryComponent that 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.QueryKeyExpression.OneOfThem
 
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.
NotEqualsFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.NotEqualsFn
 
NotFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NotValue.NotFn
 
notifyCursorIsExhausted() - Method in interface com.apple.foundationdb.record.cursors.RecursiveUnionCursor.RecursiveStateManager
Callback notifying the manager that the current cursor being iterated over by the RecordQueryRecursiveUnionPlan is exhausted.
NotMatcher - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Matcher that matches the current object if its downstream was unable to match and vice versa.
NotMatcher(BindingMatcher<?>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.structure.NotMatcher
 
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 to null.
notNull() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression.OneOfThem
 
notNullable() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
NotNullFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.NotNullFn
 
notOverComparisonRule - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
NotOverComparisonRule - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A rule that matches a NotPredicate (with the argument values) and attempts to push it into a boolean variable underneath (which can be a comparison).
NotOverComparisonRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.NotOverComparisonRule
 
notPredicate(CollectionMatcher<P>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QueryPredicateMatchers
 
NotPredicate - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
A QueryPredicate that is satisfied when its child component is not satisfied.
NotPredicate(IndexPredicate) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.NotPredicate
 
NotPredicate(RecordMetaDataProto.NotPredicate) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.NotPredicate
 
NotPredicate.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Deserializer.
NotValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value that flips the output of its boolean child.
NotValue(Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
Constructs a new NotValue instance.
NotValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
NotValue.NotFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The not function.
Null() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
NULL - Enum constant in enum com.apple.foundationdb.record.metadata.IndexPredicate.ConstantPredicate.ConstantValue
 
NULL - Enum constant in enum com.apple.foundationdb.record.metadata.Key.Evaluated.NullStandin
 
NULL - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
 
NULL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
NULL - Static variable in class com.apple.foundationdb.record.metadata.Key.Evaluated
A key containing just the null element.
NULL - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
NULL - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
NULL_ASSIGNMENT - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
NULL_UNIQUE - Enum constant in enum com.apple.foundationdb.record.metadata.Key.Evaluated.NullStandin
 
nullable() - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
NullableArrayTypeUtils - Class in com.apple.foundationdb.record.query.plan.cascades
A Utils class that holds logic related to nullable arrays.
NullComparison(boolean) - Constructor for class com.apple.foundationdb.record.metadata.IndexComparison.NullComparison
 
NullComparison(Comparisons.NullComparison) - Constructor for class com.apple.foundationdb.record.metadata.IndexComparison.NullComparison
 
NullComparison(Comparisons.Type) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
 
NullComparison(RecordMetaDataProto.NullComparison) - Constructor for class com.apple.foundationdb.record.metadata.IndexComparison.NullComparison
 
nullType() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
NullValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value that evaluates to empty.
NullValue(Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
NullValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
NumericAccumulator(NumericAggregationValue.PhysicalOperator) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.NumericAccumulator
 
NumericAggregationValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
Aggregation over numeric values.
NumericAggregationValue(PlanSerializationContext, PNumericAggregationValue) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
NumericAggregationValue(NumericAggregationValue.PhysicalOperator, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
NumericAggregationValue.Avg - Class in com.apple.foundationdb.record.query.plan.cascades.values
Average aggregation Value.
NumericAggregationValue.Avg.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
NumericAggregationValue.AvgFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The avg function.
NumericAggregationValue.BitmapConstructAgg - Class in com.apple.foundationdb.record.query.plan.cascades.values
Bitmap aggregation Value.
NumericAggregationValue.BitmapConstructAgg.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
NumericAggregationValue.BitmapConstructAggFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The bitmap function.
NumericAggregationValue.Max - Class in com.apple.foundationdb.record.query.plan.cascades.values
Max aggregation Value.
NumericAggregationValue.Max.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
NumericAggregationValue.MaxFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The max function.
NumericAggregationValue.Min - Class in com.apple.foundationdb.record.query.plan.cascades.values
Min aggregation Value.
NumericAggregationValue.Min.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
NumericAggregationValue.MinFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The min function.
NumericAggregationValue.NumericAccumulator - Class in com.apple.foundationdb.record.query.plan.cascades.values
Accumulator for aggregation using a type- and function-specific operator.
NumericAggregationValue.PhysicalOperator - Enum in com.apple.foundationdb.record.query.plan.cascades.values
The function- x type-specific numeric aggregator.
NumericAggregationValue.Sum - Class in com.apple.foundationdb.record.query.plan.cascades.values
Sum aggregation Value.
NumericAggregationValue.Sum.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
NumericAggregationValue.SumFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The sum function.

O

objectPlanHash(PlanHashable.PlanHashKind, Object) - Static method in interface com.apple.foundationdb.record.PlanHashable
Deprecated, for removal: This API element is subject to removal in a future version.
objectPlanHash(PlanHashable.PlanHashMode, Object) - Static method in interface com.apple.foundationdb.record.PlanHashable
 
ObjectPlanHash - Class in com.apple.foundationdb.record
This class implements a planHash for the member classes of the query plan.
ObjectPlanHash(Object) - Constructor for class com.apple.foundationdb.record.ObjectPlanHash
 
objectsPlanHash(PlanHashable.PlanHashKind, Object...) - Static method in interface com.apple.foundationdb.record.PlanHashable
Deprecated, for removal: This API element is subject to removal in a future version.
objectsPlanHash(PlanHashable.PlanHashMode, Object...) - Static method in interface com.apple.foundationdb.record.PlanHashable
 
ObjectValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value representing any object.
ObjectValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
of(KeyExpression, KeyExpression) - Static method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
of(KeyExpression, KeyExpression, KeyExpression) - Static method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
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 a QueryComponent.
of(ComparisonRange) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange.MergeResult
 
of(ComparisonRange, List<Comparisons.Comparison>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange.MergeResult
 
of(ComparisonRange, Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange.MergeResult
 
of(CorrelationIdentifier, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
of(CorrelationIdentifier, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
of(CorrelationIdentifier, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
of(CorrelationIdentifier, Type, List<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor.ScalarVisitorState
 
of(CorrelationIdentifier, Value, ComparisonRange, OrderingPart.MatchedSortOrder) - Static method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedOrderingPart
 
of(CorrelationIdentifier, String, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
Creates a new instance of ConstantObjectValue.
of(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
of(Unapply<T, U>, UnaryOperator<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.Extractor
 
of(UnapplyWithConfiguration<T, U>, UnaryOperator<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.Extractor
 
of(PartialMatch, Quantifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.rules.MatchIntermediateRule.PartialMatchWithQuantifier
 
of(QueryPredicate, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
of(Quantifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
of(Quantifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
of(Quantifier.Physical, Value, AggregateValue, BiFunction<Value, Value, Value>) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
of(Reference, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.MatchPartition
 
of(Type.Record.Field, int) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
of(Type.Record.Field, V) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Column
 
of(Type, Map<FieldValue.ResolvedAccessor, CompatibleTypeEvolutionPredicate.FieldAccessTrieNode>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.FieldAccessTrieNode
 
of(Type, Optional<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
Constructs a new field.
of(Type, Optional<String>, Optional<Integer>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
Constructs a new field.
of(Value, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
of(Value, Value...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue
 
of(ExplainTokens) - Static method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence
 
of(ExplainTokensWithPrecedence.Precedence, ExplainTokens) - Static method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence
 
of(ExpressionToTuplePathVisitor.OrdinalWithParent, int) - Static method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor.State
 
of(Boolean) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.predicates.Proposition
 
of(String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.CorrelationIdentifier
Create a new correlation identifier using the given string.
of(String, int) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
of(String, int, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
of(String, Object...) - Static method in class com.apple.foundationdb.record.logging.KeyValueLogMessage
 
of(Collection<? extends QueryPredicate>, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
of(Function<CorrelationIdentifier, Value>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.ResultCompensationFunction
 
of(Function<CorrelationIdentifier, Set<QueryPredicate>>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateCompensationFunction
 
of(List<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue
 
of(List<Column<? extends Value>>, List<QueryPredicate>, List<Quantifier>, List<Placeholder>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
of(List<Value>, List<Value>, Quantifier.ForEach, List<String>, int, int, boolean, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
of(Optional<String>, V) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Column
 
of(Set<T>, SetMultimap<T, T>) - Static method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
of(Set<T>, Function<T, Set<T>>) - Static method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
of(L, R) - Static method in class com.apple.foundationdb.record.util.pair.ComparablePair
Create a new ComparablePair wrapping two elements.
of(L, R) - Static method in class com.apple.foundationdb.record.util.pair.ImmutablePair
Create a new Pair from two elements.
of(L, R) - Static method in class com.apple.foundationdb.record.util.pair.NonnullPair
Create a new Pair where both elements are not null.
of(L, R) - Static method in interface com.apple.foundationdb.record.util.pair.Pair
Return a new immutable pair from two elements.
of(T...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
of(V, E) - Static method in class com.apple.foundationdb.record.util.Result
Create a new result wrapping a value and an error.
ofAliases(CorrelationIdentifier, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Factory method to create an alias map based on a given binding.
ofAliases(CorrelationIdentifier, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap
 
ofCardinality(long) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty.Cardinality
 
ofColumns(Collection<Column<? extends Value>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
ofColumns(Collection<Column<? extends Value>>, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
ofColumnsAndName(Collection<Column<? extends Value>>, String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
ofComputationRules() - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DefaultQueryPredicateRuleSet
 
ofComputationRules() - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateWithCnfRuleSet
 
ofComputationRules() - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateWithDnfRuleSet
 
ofComputed(Object) - Static method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
Create a new result with the given element.
ofComputed(Object, Tuple) - Static method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
Create a new result with the given element while inheriting other parts from a caller-provided entities.
ofConditional(IndexKeyValueToPartialRecord.TupleSource, ImmutableIntArray, ImmutableIntArray) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields.FieldData
 
ofConstant(CorrelationIdentifier, String, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
Creates a new instance of TempTableScanExpression that scans records from a constant-bound TempTable, i.e.
ofConstant(Quantifier.ForEach, CorrelationIdentifier, String, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
Creates a new instance of TempTableInsertExpression that adds records to a constant-bound TempTable, i.e.
ofConstant(Quantifier.ForEach, CorrelationIdentifier, String, Type, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
Creates a new instance of TempTableInsertExpression that adds records to a constant-bound TempTable, i.e.
ofCorrelated(CorrelationIdentifier, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
Creates a new instance of TempTableScanExpression that scans records from a correlated TempTable, i.e.
ofCorrelated(Quantifier.ForEach, CorrelationIdentifier, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
Creates a new instance of TempTableInsertExpression that adds records to its own correlated TempTable, i.e.
ofCorrelated(Quantifier.ForEach, CorrelationIdentifier, Type, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
Creates a new instance of TempTableInsertExpression that adds records to a correlated TempTable, i.e.
ofExists(Quantifier.Existential) - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
ofExpressionAndMatches(BindingMatcher<R>, BindingMatcher<C>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MatchPartitionMatchers
 
ofExpressionOptionalAndMatches(BindingMatcher<O>, BindingMatcher<C>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MatchPartitionMatchers
 
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.
ofFieldName(Value, String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
ofFieldNameAndFuseIfPossible(Value, String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
ofFieldNames(Value, List<String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
ofFields(Value, FieldValue.FieldPath) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
ofFieldsAndFuseIfPossible(Value, FieldValue.FieldPath) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
ofFlattened(Quantifier.Physical, Value, AggregateValue) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
ofFoldingSimplificationRules() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.FoldingValueSimplificationRuleSet
 
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 given FDBRecordStore.
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 given FDBRecordStore.
ofIndexKeyToPartialRecordValueRules() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExtractFromIndexKeyValueRuleSet
 
ofInverted(Set<T>, SetMultimap<T, T>) - Static method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
ofInverted(Set<T>, Function<T, Set<T>>) - Static method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
ofList(List<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
ofMatches(BindingMatcher<C>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MatchPartitionMatchers
 
ofNested(Quantifier.Physical, Value, AggregateValue) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
ofOrderingSequence(SetMultimap<Value, Ordering.Binding>, List<? extends Value>, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
ofOrderingSet(SetMultimap<Value, Ordering.Binding>, PartiallyOrderedSet<Value>, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
ofOrdinalNumber(Value, int) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
ofOrdinalNumberAndFuseIfPossible(Value, int) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
ofOthers(GraphExpansion, GraphExpansion...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
ofOthers(List<GraphExpansion>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
ofParts(List<OrderingPart.RequestedOrderingPart>, RequestedOrdering.Distinctness, boolean, Set<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
 
ofPlaceholder(Placeholder) - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
ofPlaceholderAndQuantifier(Placeholder, Quantifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
ofPredicate(QueryPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
ofPredicate(QueryPredicate) - Static method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
ofPredicates(Collection<QueryPredicate>) - Static method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
ofPrimitiveParts(List<OrderingPart.RequestedOrderingPart>, RequestedOrdering.Distinctness, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
 
ofPullUpValueRules() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.PullUpValueRuleSet
 
ofQuantifier(Quantifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
ofRanges(Value, Set<RangeConstraints>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
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 given FDBRecordStore.
ofRequestedOrderSimplificationRules() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.RequestedOrderingValueSimplificationRuleSet
 
ofResultColumn(Column<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
ofResultColumnAndPlaceholder(Column<? extends Value>, Placeholder) - Static method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
ofScalar(T) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
ofSingle(FieldValue.ResolvedAccessor) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
ofSingle(String, Type, Integer) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
ofStartingOrdinal(int) - Static method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor.State
 
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 given FDBRecordStore.
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 given Subspace.
ofType(Class<P>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QueryPredicateMatchers
 
ofType(Class<Q>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
ofType(Class<R>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
ofType(Class<R>, BindingMatcher<R>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
ofTypeOwning(Class<R>, BindingMatcher<C>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
ofTypeRangingOver(Class<Q>, BindingMatcher<? extends Collection<? extends RelationalExpression>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
ofTypeRangingOverRef(Class<Q>, BindingMatcher<? extends Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
OfTypeValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
Checks whether a Value's evaluation conforms to its result type.
OfTypeValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
ofTypeWithChildren(Class<P>, BindingMatcher<C>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QueryPredicateMatchers
 
ofTypeWithPredicates(Class<R>, BindingMatcher<C>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
ofTypeWithPredicatesAndOwning(Class<R>, BindingMatcher<C1>, BindingMatcher<C2>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
ofUnconditional(IndexKeyValueToPartialRecord.TupleSource, ImmutableIntArray) - Static method in class com.apple.foundationdb.record.query.plan.AvailableFields.FieldData
 
ofUnnamed(Collection<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
OK - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator.ValidationResult
Entry is valid.
OLD - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
OLD_FIELD_NAME - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
OLD_FIELD_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
OLD_FORMAT_KEY - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
 
OLD_INDEX_NAME - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
OLD_INDEX_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
OLD_KEY_EXPRESSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
OLD_LIMIT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
OLD_OPTION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
OLD_RECORD_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
OLD_VERSION - Enum constant in enum 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
 
onAliasDependencies(AliasMap, Collection<? extends T>, Function<T, CorrelationIdentifier>, Function<T, Set<CorrelationIdentifier>>, Collection<? extends T>, Function<T, CorrelationIdentifier>, Function<T, Set<CorrelationIdentifier>>, MatchFunction<T, M>, Supplier<MatchAccumulator<M, R>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.ComputingMatcher
Static factory method to create a generic matcher using element type T.
onAliasDependencies(AliasMap, Collection<? extends T>, Function<T, CorrelationIdentifier>, Function<T, Set<CorrelationIdentifier>>, Collection<? extends T>, Function<T, CorrelationIdentifier>, Function<T, Set<CorrelationIdentifier>>, MatchPredicate<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.FindingMatcher
Static factory method to create a generic matcher using element type T.
onAliases(AliasMap, Set<CorrelationIdentifier>, Function<CorrelationIdentifier, Set<CorrelationIdentifier>>, Set<CorrelationIdentifier>, Function<CorrelationIdentifier, Set<CorrelationIdentifier>>, MatchPredicate<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.FindingMatcher
Static factory method to create a generic matcher using element type T.
onDone() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
onEmptyIndividualBindings(Stream<PlannerBindings>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MultiMatcher.AllMatcher
 
onEmptyIndividualBindings(Stream<PlannerBindings>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MultiMatcher
 
onEmptyIndividualBindings(Stream<PlannerBindings>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MultiMatcher.SomeMatcher
 
onEmptyResult(BindingMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
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() - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
Add comparisons to one of the values returned by a multi-valued expression.
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
A QueryComponent that evaluates a Comparisons.Comparison against 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
A QueryComponent that 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
 
onError(Throwable) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
onEvent(Debugger.Event) - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
onGetIndex(Class<?>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
onGetOrRegisterSingleton(Object) - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
onHasNext() - Method in class com.apple.foundationdb.record.RecordCursorIterator
Asynchronously check whether there are more records available from the cursor.
onInstall() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
OnKeyExpression(KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression
 
ONLINE_INDEX_BUILDER_RANGES_BY_COUNT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of OnlineIndexer range scans terminated after hitting the scan limit.
ONLINE_INDEX_BUILDER_RANGES_BY_DEPLETION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of OnlineIndexer range scans terminated after hitting the time limit.
ONLINE_INDEX_BUILDER_RANGES_BY_SIZE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of OnlineIndexer range scans terminated after hitting the size limit.
ONLINE_INDEX_BUILDER_RANGES_BY_TIME - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of missing index entries detected by the online scrubber.
ONLINE_INDEX_BUILDER_RECORDS_INDEXED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of records indexed by OnlineIndexer.
ONLINE_INDEX_BUILDER_RECORDS_SCANNED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of records scanned by OnlineIndexer.
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 for OnlineIndexer.
OnlineIndexer.IndexingPolicy - Class in com.apple.foundationdb.record.provider.foundationdb
A builder for the indexing policy.
OnlineIndexer.IndexingPolicy.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
OnlineIndexer.IndexingPolicy.DesiredAction - Enum in com.apple.foundationdb.record.provider.foundationdb
Possible actions when an index is already partially built.
OnlineIndexer.IndexingPolicy.TakeoverTypes - Enum in com.apple.foundationdb.record.provider.foundationdb
Possible conversion from one indexing method to another.
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
This Exception can 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 the OnlineIndexer during an index build.
OnlineIndexOperationBaseBuilder<B extends OnlineIndexOperationBaseBuilder<B>> - Class in com.apple.foundationdb.record.provider.foundationdb
Base class that the OnlineIndexer.Builder and the OnlineIndexScrubber.Builder can both inherit from.
OnlineIndexOperationBaseBuilder() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
 
OnlineIndexOperationConfig - Class in com.apple.foundationdb.record.provider.foundationdb
A holder for the mutable configuration parameters needed to rebuild an online index.
OnlineIndexOperationConfig.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
OnlineIndexScrubber - Class in com.apple.foundationdb.record.provider.foundationdb
Scan indexes for problems and optionally report or repair.
OnlineIndexScrubber.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
Builder for OnlineIndexScrubber.
OnlineIndexScrubber.ScrubbingPolicy - Class in com.apple.foundationdb.record.provider.foundationdb
A builder for the scrubbing policy.
OnlineIndexScrubber.ScrubbingPolicy.Builder - Class in com.apple.foundationdb.record.provider.foundationdb
only(BindingMatcher<? extends T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ListMatcher
 
ONLY_MANUAL_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
ONLY_QUERY_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
onMatch(C) - Method in interface com.apple.foundationdb.record.query.plan.cascades.PlannerRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.AdjustMatchRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.CombineFilterRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.DataAccessRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementDeleteRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementDistinctRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementDistinctUnionRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementExplodeRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementFilterRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementInJoinRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementInsertRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementIntersectionRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementInUnionRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementNestedLoopJoinRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementPhysicalScanRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementRecursiveUnionRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementSimpleSelectRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementStreamingAggregationRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementTempTableInsertRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementTempTableScanRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementTypeFilterRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementUniqueRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementUnorderedUnionRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.ImplementUpdateRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.InComparisonToExplodeRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.MatchIntermediateRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.MatchLeafRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.MergeFetchIntoCoveringIndexRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.MergeProjectionAndFetchRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.NormalizePredicatesRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PartitionBinarySelectRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PartitionSelectRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PredicateToLogicalUnionRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PullUpNullOnEmptyRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushDistinctBelowFilterRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushDistinctThroughFetchRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushFilterThroughFetchRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushInJoinThroughFetchRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushMapThroughFetchRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushReferencedFieldsThroughDistinctRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushReferencedFieldsThroughFilterRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushReferencedFieldsThroughSelectRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushReferencedFieldsThroughUniqueRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughDeleteRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughDistinctRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughGroupByRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughInLikeSelectRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughInsertRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughInsertTempTableRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughRecursiveUnionRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughSelectExistentialRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughSelectRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughSortRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughUnionRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughUniqueRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughUpdateRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushSetOperationThroughFetchRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.PushTypeFilterBelowFilterRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.RemoveProjectionRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.RemoveSortRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.SelectDataAccessRule
 
onMatch(CascadesRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.rules.SplitSelectExtractIndependentQuantifiersRule
 
onMatch(QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AbsorptionRule
 
onMatch(QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AnnulmentAndRule
 
onMatch(QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AnnulmentOrRule
 
onMatch(QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DeMorgansTheoremRule
 
onMatch(QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.IdentityAndRule
 
onMatch(QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.IdentityOrRule
 
onMatch(QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.NormalFormRule
 
onMatch(QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.NotOverComparisonRule
 
onMatch(ValueComputationRuleCall<OrderingPart.OrderingPartCreator<O, P>, P>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComputeToOrderedBytesValueRule
 
onMatch(ValueComputationRuleCall<OrderingPart.OrderingPartCreator<O, P>, P>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.DefaultOrderingPartRule
 
onMatch(ValueComputationRuleCall<Value, Map<Value, ValueCompensation>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.CompensateToOrderedBytesValueRule
 
onMatch(ValueComputationRuleCall<Value, Map<Value, ValueCompensation>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchFieldValueOverFieldValueRule
 
onMatch(ValueComputationRuleCall<Value, Map<Value, ValueCompensation>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchSimpleFieldValueRule
 
onMatch(ValueComputationRuleCall<Iterable<? extends Value>, Map<Value, ValueCompensation>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.CompensateRecordConstructorRule
 
onMatch(ValueComputationRuleCall<Iterable<? extends Value>, Map<Value, ValueCompensation>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchConstantValueRule
 
onMatch(ValueComputationRuleCall<Iterable<? extends Value>, Map<Value, ValueCompensation>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchFieldValueAgainstQuantifiedObjectValueRule
 
onMatch(ValueComputationRuleCall<Iterable<? extends Value>, Map<Value, ValueCompensation>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchOrCompensateFieldValueRule
 
onMatch(ValueComputationRuleCall<Iterable<? extends Value>, Map<Value, ValueCompensation>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchValueAgainstQuantifiedObjectValueRule
 
onMatch(ValueComputationRuleCall<Iterable<? extends Value>, Map<Value, ValueCompensation>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MatchValueRule
 
onMatch(ValueSimplificationRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.CollapseRecordConstructorOverFieldsToStarRule
 
onMatch(ValueSimplificationRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComposeFieldValueOverFieldValueRule
 
onMatch(ValueSimplificationRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComposeFieldValueOverRecordConstructorRule
 
onMatch(ValueSimplificationRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.EliminateArithmeticValueWithConstantRule
 
onMatch(ValueSimplificationRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExpandFusedFieldValueRule
 
onMatch(ValueSimplificationRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExpandRecordRule
 
onMatch(ValueSimplificationRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.FoldConstantRule
 
onMatch(ValueSimplificationRuleCall) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.LiftConstructorRule
 
onNext() - Method in class com.apple.foundationdb.record.cursors.aggregate.AggregateCursor
 
onNext() - Method in class com.apple.foundationdb.record.cursors.AsyncIteratorCursor
 
onNext() - Method in class com.apple.foundationdb.record.cursors.AsyncLockCursor
 
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.FallbackCursor
 
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
Deprecated.
 
onNext() - Method in class com.apple.foundationdb.record.cursors.MapPipelinedCursor
 
onNext() - Method in class com.apple.foundationdb.record.cursors.MapResultCursor
 
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.RangeCursor
 
onNext() - Method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor
Returns the next cursor item of the current recursive state n from the active state cursor, if the cursor is exhausted, it will notify the recursive state manager which will either.
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.cursors.TempTableInsertCursor
 
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.KeyValueCursorBase
 
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.
onNext() - Method in class com.apple.foundationdb.record.sorting.FileSortCursor
 
onNext() - Method in class com.apple.foundationdb.record.sorting.MemorySortCursor
 
onQuery(String, PlanContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
onRegisterExpression(RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
onRegisterQuantifier(Quantifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
onRegisterReference(Reference) - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
onSetup() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
onShow(Reference) - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
onUpdateIndex(Class<?>, IntUnaryOperator) - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
OnValues(CorrelationIdentifier, List<? extends Value>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues
 
OpaqueEqualityComparison() - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison
 
open() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
open(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Return a Database object from the factory.
open(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
OPEN_CONTEXT - Enum constant in enum 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 existing FDBRecordStore instance 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.runners.TransactionalRunner
Open a new context with the config attached to this runner, that will be closed when this runner is closed.
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
 
openRecordStore(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
OPERAND_OF_LIKE_OPERATOR_IS_NOT_STRING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
operator - Variable in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
operator - Variable in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
operator - Variable in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
OperatorNodeWithInfo(RecordQueryPlan, NodeInfo) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.OperatorNodeWithInfo
 
OperatorNodeWithInfo(RecordQueryPlan, NodeInfo, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.OperatorNodeWithInfo
 
OperatorNodeWithInfo(RecordQueryPlan, NodeInfo, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.OperatorNodeWithInfo
 
OPTGROUP - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
 
optimize(QueryPredicate, ARGUMENT, AliasMap, Set<CorrelationIdentifier>, QueryPredicateComputationRuleSet<ARGUMENT, List<QueryPlanConstraint>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.Simplification
Main function that simplifies the given value using the QueryPredicateComputationRuleSet passed in.
OptimizeGroupEvent(Reference, Deque<CascadesPlanner.Task>, Debugger.Location, Reference) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeGroupEvent
 
OptimizeInputsEvent(Reference, Deque<CascadesPlanner.Task>, Debugger.Location, Reference, RelationalExpression) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeInputsEvent
 
OPTINPUTS - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
 
OPTIONAL_WHITESPACE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
OptionalIfPresentMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A matcher that matches an optional if the object is present.
OptionalIfPresentMatcher(BindingMatcher<?>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.structure.OptionalIfPresentMatcher
 
OptionalWhitespaceToken(int) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.OptionalWhitespaceToken
 
options() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
options() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
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(BindingMatcher<? super T>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
Combinator to return a matcher that matches the logical or of this matcher and the matcher passed in.
or(Proposition) - Method in enum com.apple.foundationdb.record.query.plan.cascades.predicates.Proposition
 
or(QueryPredicate, QueryPredicate, QueryPredicate...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
or(Collection<? extends QueryPredicate>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
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.
Or(List<MultidimensionalIndexScanBounds.SpatialPredicate>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.Or
 
OR - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
OR_TERM_IMPLIES_CANDIDATE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.MappingKind
 
OrComponent - Class in com.apple.foundationdb.record.query.expressions
A QueryComponent that is satisfied when any of its child components is satisfied.
OrComponent(List<QueryComponent>) - Constructor for class com.apple.foundationdb.record.query.expressions.OrComponent
 
OrderComparator(Comparator<K>, K) - Constructor for class com.apple.foundationdb.record.sorting.MemorySortAdapter.OrderComparator
 
OrderedBytesHelpers - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value that produces a binary encoding that is comparable according to certain modes gives by TupleOrdering.Direction.
OrderFunctionKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
ORDER_xxx function.
OrderFunctionKeyExpression(TupleOrdering.Direction, String, KeyExpression) - Constructor for class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
OrderFunctionKeyExpressionFactory - Class in com.apple.foundationdb.record.metadata.expressions
Factory for OrderFunctionKeyExpression for each supported direction.
OrderFunctionKeyExpressionFactory() - Constructor for class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpressionFactory
 
Ordering - Class in com.apple.foundationdb.record.query.plan.cascades
This class captures an ordering property.
Ordering(SetMultimap<Value, Ordering.Binding>, PartiallyOrderedSet<Value>, boolean, BiConsumer<SetMultimap<Value, Ordering.Binding>, PartiallyOrderedSet<Value>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Ordering
Primary constructor.
ORDERING - Static variable in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty
 
ORDERING_IS_OF_INCOMPATIBLE_TYPE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
Ordering.Binding - Class in com.apple.foundationdb.record.query.plan.cascades
A helper class used inside an Ordering to indicate if a value is considered to be ascending, descending, or fixed to a comparison/a set of comparisons (which have to be of type ComparisonRange.Type.EQUALITY).
Ordering.DirectOrderPreservingValue - Interface in com.apple.foundationdb.record.query.plan.cascades
Interface that declares that all instances of the implementing class are directly order-preserving.
Ordering.Intersection - Class in com.apple.foundationdb.record.query.plan.cascades
TODO.
Ordering.InverseOrderPreservingValue - Interface in com.apple.foundationdb.record.query.plan.cascades
Interface that declares that all instances of the implementing class are inverse order-preserving.
Ordering.MergeOperator<O extends Ordering.SetOperationsOrdering> - Interface in com.apple.foundationdb.record.query.plan.cascades
Merge operator for orderings.
Ordering.OrderPreservingKind - Enum in com.apple.foundationdb.record.query.plan.cascades
Enum to differentiate the different kinds of preserving order.
Ordering.OrderPreservingValue - Interface in com.apple.foundationdb.record.query.plan.cascades
Interface that declares that this Value preserves the order of the input value in some way.
Ordering.SetOperationsOrdering - Class in com.apple.foundationdb.record.query.plan.cascades
Abstract static class that represents an ordering that is produced by an ordered set operation such as a union or intersection operation prior to the application of a comparison key.
Ordering.Union - Class in com.apple.foundationdb.record.query.plan.cascades
TODO.
orderingAliases(List<CorrelationIdentifier>, CorrelationIdentifier, List<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
OrderingPart<S extends OrderingPart.SortOrder> - Class in com.apple.foundationdb.record.query.plan.cascades
A class that is used to express ordered-ness.
OrderingPart(Value, S) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.OrderingPart
 
OrderingPart.MatchedOrderingPart - Class in com.apple.foundationdb.record.query.plan.cascades
An OrderingPart that is bound by a comparison during graph matching.
OrderingPart.MatchedSortOrder - Enum in com.apple.foundationdb.record.query.plan.cascades
Sort order that can be assigned during index matching.
OrderingPart.OrderingPartCreator<O extends OrderingPart.SortOrder,P extends OrderingPart<O>> - Interface in com.apple.foundationdb.record.query.plan.cascades
Functional interface to be used to create instances of a particular kind of OrderingPart.
OrderingPart.ProvidedOrderingPart - Class in com.apple.foundationdb.record.query.plan.cascades
Final class to tag provided ordering parts and to seal OrderingPart.
OrderingPart.ProvidedSortOrder - Enum in com.apple.foundationdb.record.query.plan.cascades
Enum implementing OrderingPart.SortOrder that provides sort orders that for instance a plan can provide to downstream operators.
OrderingPart.RequestedOrderingPart - Class in com.apple.foundationdb.record.query.plan.cascades
Final class to tag requested ordering parts and to seal OrderingPart.
OrderingPart.RequestedSortOrder - Enum in com.apple.foundationdb.record.query.plan.cascades
Sort order used to model requested orderings, that is orderings that a down stream operator or the client requires the result set of the upstream operator to adhere to.
OrderingPart.SortOrder - Interface in com.apple.foundationdb.record.query.plan.cascades
A common interface all sort orders have to implement.
OrderingProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
A property used for the ordering(s) of a plan.
OrderingProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty
 
OrderingProperty.OrderingVisitor - Class in com.apple.foundationdb.record.query.plan.cascades.properties
A property that determines the ordering of a RecordQueryPlan.
OrderingValueComputationRuleSet<O extends OrderingPart.SortOrder,P extends OrderingPart<O>> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A set of rules for simplifying Value trees used to expression ordering constraints.
OrderingVisitor() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
OrderQueryKeyExpression - Class in com.apple.foundationdb.record.query.expressions
Handle OrderFunctionKeyExpression in a query.
OrderQueryKeyExpression(OrderFunctionKeyExpression) - Constructor for class com.apple.foundationdb.record.query.expressions.OrderQueryKeyExpression
 
orElse(Iterable<T>, Iterable<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.IterableHelpers
Returns an alternative iterable if the given source iterable is empty.
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.
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(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 for key, retrieve the value using the provided asynchronous Supplier.
orElseOf(Iterable<T>, T) - Static method in class com.apple.foundationdb.record.query.plan.cascades.IterableHelpers
Returns an alternative singleton iterable if the given source iterable is empty.
OrFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue.OrFn
 
ORIGINAL_RANGE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
orOrFalse(Collection<? extends QueryPredicate>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
orOrTrue(Collection<? extends QueryPredicate>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
ORPHAN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.InvalidIndexEntry.Reasons
 
orPredicate(CollectionMatcher<P>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QueryPredicateMatchers
 
OrPredicate - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
A QueryPredicate that is satisfied when any of its child components is satisfied.
OrPredicate(OrPredicate) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.OrPredicate
 
OrPredicate(RecordMetaDataProto.OrPredicate) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.OrPredicate
 
OrPredicate(Collection<IndexPredicate>) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.OrPredicate
 
OrPredicate.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Deserializer.
orTermMappingBuilder(QueryPredicate, QueryPredicate, QueryPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
OTHER - Enum constant in enum com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.TupleSource
 
OTHER_FILTER - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
outDegree(N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
outEdges(N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
over(T) - Static method in class com.apple.foundationdb.record.query.plan.cascades.PreOrderIterator
Retuns an iterator that traverses treeLike in pre-order.
OVERLAP - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
overlaps(Tuple, Tuple) - Method in class com.apple.foundationdb.record.TupleRange
Method to compute if an inclusive/inclusive range given by two Tuples overlap with this tuple range.
overlapsMbrApproximately(RTree.Rectangle) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.And
 
overlapsMbrApproximately(RTree.Rectangle) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.Hypercube
 
overlapsMbrApproximately(RTree.Rectangle) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.Or
 
overlapsMbrApproximately(RTree.Rectangle) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds
Method to compute if the rectangle handed in overlaps with this scan bounds object.
overlapsMbrApproximately(RTree.Rectangle) - Method in interface com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.SpatialPredicate
 
overNewReference(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Existential
 
overNewReference(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach
 
overNewReference(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
overNewReference(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
owning(BindingMatcher<C>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
ownTimeInNs - Variable in class com.apple.foundationdb.record.query.plan.cascades.debug.Stats
 

P

packOrNull(Tuple) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
Pair<L,R> - Interface in com.apple.foundationdb.record.util.pair
A simple interface for pairs of two elements.
parameter - Variable in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
parameterComparison(Comparisons.Type, String) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
 
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
 
ParameterComparison(Comparisons.Type, String, Bindings.Internal, ParameterRelationshipGraph) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
 
ParameterComparisonBase(Comparisons.Type, String, Bindings.Internal, ParameterRelationshipGraph) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
parameterRelationshipGraph - Variable in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
parameterRelationshipGraph - Variable in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
ParameterRelationshipGraph - Class in com.apple.foundationdb.record.query
A class to keep track of the relationships of parameters in a query given a RecordQuery and a set of pre-bindings.
ParameterRelationshipGraph.Relationship - Class in com.apple.foundationdb.record.query
A relationship between two parameter values.
ParameterRelationshipGraph.RelationshipType - Enum in com.apple.foundationdb.record.query
parent - Variable in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
 
PARENT_DIR - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
PARENT_FILTER - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
parenthesizeChild(ExplainTokensWithPrecedence) - Method in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
parenthesizeChild(ExplainTokensWithPrecedence.Precedence, ExplainTokens, boolean) - Method in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
parenthesizeChild(ExplainTokensWithPrecedence, boolean) - Method in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
parseFrom(byte[]) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
 
parseFrom(InputStream) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
 
parseMetaDataProto(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
 
PartiallyOrderedSet<T> - Class in com.apple.foundationdb.record.query.combinatorics
A class to represent partially ordered set of elements of some type.
PartiallyOrderedSet.Builder<T> - Class in com.apple.foundationdb.record.query.combinatorics
Builder for PartiallyOrderedSet.
PartiallyOrderedSet.EligibleSet<T> - Class in com.apple.foundationdb.record.query.combinatorics
A class allowing to compute a subset of elements in a partial order that are said to be eligible.
PartialMatch - Class in com.apple.foundationdb.record.query.plan.cascades
Case class to represent a partial match.
PartialMatch(AliasMap, MatchCandidate, Reference, RelationalExpression, Reference, MatchInfo) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
PartialMatchEdge() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.PartialMatchEdge
 
PartialMatchEdge(String) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.PartialMatchEdge
 
PartialMatchMatchers - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Matchers of PartialMatch.
PARTITION_ID - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
PartitionBinarySelectRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that splits a SelectExpression into a new upper and two lower SelectExpression that can absorb predicates which may prove advantageous for the implementation rules.
PartitionBinarySelectRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PartitionBinarySelectRule
 
partitionFilters(List<QueryComponent>, AvailableFields, List<QueryComponent>, List<QueryComponent>, Set<KeyExpression>) - Static method in class com.apple.foundationdb.record.query.plan.visitor.FilterVisitor
 
PARTITIONING_KEY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
PartitionSelectRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that splits a SelectExpression into two SelectExpressions .
PartitionSelectRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PartitionSelectRule
 
PartlyBuiltException(IndexBuildProto.IndexBuildIndexingStamp, IndexBuildProto.IndexBuildIndexingStamp, Index, UUID, String) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.IndexingBase.PartlyBuiltException
 
PassThroughRecordStoreStateCache - Class in com.apple.foundationdb.record.provider.foundationdb.storestate
An implementation of the FDBRecordStoreStateCache interface that does not actually cache anything.
PassThroughRecordStoreStateCacheFactory - Class in com.apple.foundationdb.record.provider.foundationdb.storestate
A factory for creating PassThroughRecordStoreStateCaches.
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
pathFromKeyAsync(FDBRecordContext, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
PathValue - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
A class to represent the value stored at a particular element of a KeySpacePath.
PatternForLikeFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue.PatternForLikeFn
 
PatternForLikeValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value that applies a like operator on its child expressions.
PatternForLikeValue(Value, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
Constructs a new instance of PatternForLikeValue.
PatternForLikeValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
PatternForLikeValue.PatternForLikeFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The patternForLike operator.
PERFORM_NO_OP - Enum constant in enum 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
 
permutations(Set<T>) - Static method in class com.apple.foundationdb.record.query.combinatorics.TopologicalSort
Create an EnumeratingIterable based on a set.
PERMUTED_MAX - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
An index remembering maximum values in a way that can enumerate maxima ordered by value and not (part of the) group.
PERMUTED_MIN - Static variable in class com.apple.foundationdb.record.metadata.IndexTypes
An index remembering minimum values in a way that can enumerate minima ordered by value and not (part of the) group.
PERMUTED_SIZE_OPTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
Size of the portion of the grouping keys enumerated after the extrema by IndexTypes.PERMUTED_MIN and IndexTypes.PERMUTED_MAX indexes.
PermutedMinMaxIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
An index that maintains an extremum value in a way that can be enumerated by that value rather than by group.
PermutedMinMaxIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.PermutedMinMaxIndexMaintainer
 
PermutedMinMaxIndexMaintainer.Type - Enum in com.apple.foundationdb.record.provider.foundationdb.indexes
 
PermutedMinMaxIndexMaintainerFactory - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
A factory for PermutedMinMaxIndexMaintainer indexes.
PermutedMinMaxIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.PermutedMinMaxIndexMaintainerFactory
 
physical(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
physical(Reference, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
physicalBuilder() - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Create a builder for a physical quantifier containing record query plans.
PhysicalBuilder() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical.PhysicalBuilder
 
physicalQuantifier() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
physicalQuantifier(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
physicalQuantifier(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
PhysicalQuantifierEdge() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.PhysicalQuantifierEdge
 
PhysicalQuantifierEdge(String, Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.PhysicalQuantifierEdge
 
PhysicalQuantifierEdge(Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.PhysicalQuantifierEdge
 
physicalQuantifierOverRef(BindingMatcher<? extends Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QuantifierMatchers
 
PickValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value representing multiple "alternative" values.
PickValue(Value, Iterable<? extends Value>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
PickValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
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
 
Placeholder - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
A Placeholder is basically a PredicateWithValueAndRanges with an alias that is used solely used for index matching.
plan(FDBRecordStore) - Method in class com.apple.foundationdb.record.query.BoundRecordQuery
Plan this query using the given store.
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, ParameterRelationshipGraph) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
 
plan(RecordQuery, ParameterRelationshipGraph) - Method in interface com.apple.foundationdb.record.query.plan.QueryPlanner
Create a plan to get the results of the provided query.
plan(RecordQuery, ParameterRelationshipGraph) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
Create a plan to get the results of the provided query.
PLAN - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
PLAN_AGGREGATE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a RecordQueryStreamingAggregationPlan.
PLAN_COMPARATOR - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a RecordQueryComparatorPlan.
PLAN_COMPOSED_BITMAP_INDEX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a ComposedBitmapIndexQueryPlan.
PLAN_COVERING_INDEX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that use a covering index.
PLAN_DAM - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
 
PLAN_DISTINCT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a RecordQueryUnorderedDistinctPlan.
PLAN_FETCH - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a RecordQueryFetchFromPartialRecordPlan.
PLAN_FILTER - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a RecordQueryFilterPlan.
PLAN_HASH - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
PLAN_HASH - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
PLAN_IN_COMPARAND - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include an IN with values extracted from a comparison.
PLAN_IN_PARAMETER - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include an IN with parameters.
PLAN_IN_UNION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a IN type of Union.
PLAN_IN_VALUES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include an IN with literal values.
PLAN_INDEX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include an index.
PLAN_INTERSECTION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include an RecordQueryIntersectionPlan.
PLAN_LOAD_BY_KEYS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a loading records directly by their primary keys.
PLAN_OVERSCAN_INDEX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include an index scan which overscans to load additional data into a client-side cache.
PLAN_PK_DISTINCT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a RecordQueryUnorderedPrimaryKeyDistinctPlan.
PLAN_QUERY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent planning a query.
PLAN_RECURSIVE_UNION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of plans that include a RecordQueryRecursiveUnionPlan.
PLAN_SCAN - Enum constant in enum 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include translating a rank range into a score range.
PLAN_SELECTOR - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a RecordQuerySelectorPlan.
PLAN_SORT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a RecordQuerySortPlan.
PLAN_SYNTHETIC_TYPE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of synthetic record type plans.
PLAN_TYPE_FILTER - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a RecordQueryTypeFilterPlan.
PLAN_UNION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a RecordQueryUnionPlan.
PLAN_UNORDERED_UNION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of query plans that include a RecordQueryUnorderedUnionPlan.
planComparisonSubstitute(QueryComponent) - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons
 
planComparisonSubstitutes(List<QueryComponent>) - Method in class com.apple.foundationdb.record.query.plan.planning.RankComparisons
 
PlanContext - Interface in com.apple.foundationdb.record.query.plan.cascades
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
 
PlanDeserializer<M extends Message,T> - Interface in com.apple.foundationdb.record
Interface that needs to be implemented separately for every class that is PlanSerializable.
planGraph(Supplier<Reference>, Optional<Collection<String>>, IndexQueryabilityFilter, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
 
planHash() - Method in interface com.apple.foundationdb.record.PlanHashable
Deprecated, for removal: This API element is subject to removal in a future version.
planHash(PlanHashable.PlanHashKind) - Method in interface com.apple.foundationdb.record.PlanHashable
Deprecated, for removal: This API element is subject to removal in a future version.
planHash(PlanHashable.PlanHashKind, PlanHashable...) - Static method in interface com.apple.foundationdb.record.PlanHashable
Deprecated, for removal: This API element is subject to removal in a future version.
planHash(PlanHashable.PlanHashKind, Iterable<? extends PlanHashable>) - Static method in interface com.apple.foundationdb.record.PlanHashable
Deprecated, for removal: This API element is subject to removal in a future version.
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.IndexScanType
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.IndexRecordFunction
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.metadata.StoreRecordFunction
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.ObjectPlanHash
 
planHash(PlanHashable.PlanHashMode) - Method in interface com.apple.foundationdb.record.PlanHashable
Return a hash similar to hashCode, but with the additional guarantee that is is stable across JVMs.
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowRecordFunction
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.AndComponent
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextWithMaxDistanceComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.EmptyComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.NestedField
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.OrComponent
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithOneOfComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.ConditionalUponPathPredicate
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.TruePredicate
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.Column
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.FieldAccessTrieNode
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate.UsedIndex
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.CompilableRange
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.CoercionTrieNode
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.TransformationTrieNode
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.ArrayCoercionBiFunction
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.PrimitiveCoercionBiFunction
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RankValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.BinaryRelOpValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.UnaryRelOpValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldWithValueCopier
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.MessageCopier
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.ScoreForRank
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySelectorPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.RelativeProbabilityPlanSelector
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanResult
To make transition from RecordQueryPlan to QueryPlanResult smoother, this implements PlanHashable.
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortKey
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.query.plan.TextScan
 
planHash(PlanHashable.PlanHashMode) - Method in class com.apple.foundationdb.record.util.ProtoUtils.DynamicEnum
 
planHash(PlanHashable.PlanHashMode, PlanHashable...) - Static method in interface com.apple.foundationdb.record.PlanHashable
 
planHash(PlanHashable.PlanHashMode, Iterable<? extends PlanHashable>) - Static method in interface com.apple.foundationdb.record.PlanHashable
 
PlanHashable - Interface in com.apple.foundationdb.record
A more stable version of Object.hashCode().
PlanHashable.PlanHashKind - Enum in com.apple.foundationdb.record
The "kinds" of planHash calculations.
PlanHashable.PlanHashMode - Enum in com.apple.foundationdb.record
A mode for a plan hash which captures both kind and version.
planHashUnordered(PlanHashable.PlanHashKind, Iterable<? extends PlanHashable>) - Static method in interface com.apple.foundationdb.record.PlanHashable
Deprecated, for removal: This API element is subject to removal in a future version.
planHashUnordered(PlanHashable.PlanHashMode, 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
 
PlannableIndexTypes(Set<String>, 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.cascades.matching.structure
A map-like structure that supports a map from a binding to a collection of objects, such as RelationalExpressions and References.
PlannerBindings.Builder - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A mutable builder for a set of PlannerBindings which can be used to incrementally build up a set of bindings without repeatedly calling PlannerBindings.mergedWith(PlannerBindings), which is less efficient.
PlannerConstraint<T> - Interface in com.apple.foundationdb.record.query.plan.cascades
Base interface to capture constraints for the planner.
PlannerGraph - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Lightweight class to save some boilerplate.
PlannerGraph(PlannerGraph.Node, Network<PlannerGraph.Node, PlannerGraph.Edge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph
 
PlannerGraph.DataNodeWithInfo - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Node class for data objects.
PlannerGraph.Edge - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Edge class.
PlannerGraph.ExistentialQuantifierEdge - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Edge class for existential quantifiers.
PlannerGraph.ForEachQuantifierEdge - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Edge class for for-each quantifiers.
PlannerGraph.InternalPlannerGraphBuilder - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Specific builder for explain planner graph building.
PlannerGraph.LogicalOperatorNode - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Node class for logical operators.
PlannerGraph.LogicalOperatorNodeWithInfo - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Node class for logical operators that also have a NodeInfo.
PlannerGraph.ModificationLogicalOperatorNode - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Node class for logical operators that also have a NodeInfo.
PlannerGraph.ModificationOperatorNodeWithInfo - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Node class for actual plan operators.
PlannerGraph.ModificationTargetEdge - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Edge class for modification (delete, insert, update) targets.
PlannerGraph.Node - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Node class functioning as parent for any nodes in the network.
PlannerGraph.NodeWithInfo - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Node class that additionally captures a reference to a NodeInfo.
PlannerGraph.OperatorNodeWithInfo - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Node class for actual plan operators.
PlannerGraph.PartialMatchEdge - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Edge class for matches that connect a query reference to a match candidate reference.
PlannerGraph.PhysicalQuantifierEdge - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Edge class for physical quantifiers.
PlannerGraph.ReferenceEdge - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Edge class for Reference.
PlannerGraph.ReferenceHeadNode - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Node class for References -- head.
PlannerGraph.ReferenceInternalEdge - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Edge class for Reference.
PlannerGraph.ReferenceMemberNode - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Node class for Reference - member.
PlannerGraph.TemporaryDataNodeWithInfo - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Node class for temporary data objects.
PlannerGraph.WithExpression - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Interface to be implemented by all node classes that represent an RelationalExpression.
PlannerGraph.WithInfoId - Interface in com.apple.foundationdb.record.query.plan.cascades.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(AbstractPlannerGraph<N, E>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.PlannerGraphBuilder
 
PlannerGraphBuilder(N) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.AbstractPlannerGraph.PlannerGraphBuilder
 
PlannerGraphProperty - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Class to hold a graph for explain, optimization, and rewrite purposes.
PlannerGraphProperty.NamedCluster - Class in com.apple.foundationdb.record.query.plan.cascades.explain
Class to represent an actual sub cluster of inside the planner graph.
PlannerGraphRewritable - Interface in com.apple.foundationdb.record.query.plan.cascades.explain
Interface to allow RelationalExpressions to rewrite their own graph representation.
PlannerRule<R,C extends PlannerRuleCall<R>,T> - Interface in com.apple.foundationdb.record.query.plan.cascades
Basic rule interface.
PlannerRule.PreOrderRule - Interface in com.apple.foundationdb.record.query.plan.cascades
Marker interface for rules that run in pre-order.
PlannerRuleCall<R> - Interface in com.apple.foundationdb.record.query.plan.cascades
A PlannerRuleCall is a context object that supports a single application of a rule to a particular expression.
PlannerRuleSet - Class in com.apple.foundationdb.record.query.plan.cascades
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
 
planOther(RecordQueryPlanner.CandidateScan, Index, QueryComponent, KeyExpression, boolean, KeyExpression) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
 
PlanPartition - Class in com.apple.foundationdb.record.query.plan.cascades
A plan partition used for matching.
PlanPartition(Map<PlanProperty<?>, ?>, Collection<RecordQueryPlan>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.PlanPartition
 
planPartitions(BindingMatcher<? extends Iterable<? extends PlanPartition>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ReferenceMatchers
 
planPartitionWhere(Predicate<PlanPartition>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ReferenceMatchers
 
PlanProperty<A> - Interface in com.apple.foundationdb.record.query.plan.cascades
Base interface to capture attributes for plans.
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
 
planQuery(RecordQuery) - Method in interface com.apple.foundationdb.record.query.plan.QueryPlanner
 
planQuery(RecordQuery, ParameterRelationshipGraph) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
planQuery(RecordQuery, ParameterRelationshipGraph) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Plan a query.
planQuery(RecordQuery, ParameterRelationshipGraph) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
planQuery(RecordQuery, ParameterRelationshipGraph) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
 
planQuery(RecordQuery, ParameterRelationshipGraph) - Method in interface com.apple.foundationdb.record.query.plan.QueryPlanner
Create a plan to get the results of the provided query.
planQuery(RecordQuery, ParameterRelationshipGraph) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
Create a plan to get the results of the provided query.
planQuery(RecordQuery, ParameterRelationshipGraph, RecordQueryPlannerConfiguration) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
planQuery(RecordQuery, ParameterRelationshipGraph, RecordQueryPlannerConfiguration) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Plan a query with customized RecordQueryPlannerConfiguration rather than the default one.
planQuery(RecordQuery, ParameterRelationshipGraph, RecordQueryPlannerConfiguration) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
PlanSelector - Interface in com.apple.foundationdb.record.query.plan.plans
A plan selector selects one plan from the given list via some policy.
PlanSerializable - Interface in com.apple.foundationdb.record
Base interface to indicate that a java class is reachable through a RecordQueryPlan and therefore needs to be capable of serialization/deserialization.
PlanSerialization - Class in com.apple.foundationdb.record.query.plan.serialization
Class to facilitate serialization and deserialization of RecordQueryPlans.
PlanSerialization() - Constructor for class com.apple.foundationdb.record.query.plan.serialization.PlanSerialization
 
PlanSerializationContext - Class in com.apple.foundationdb.record
Context class defining the state of serialization/deserialization currently in-flight.
PlanSerializationContext(PlanSerializationRegistry, PlanHashable.PlanHashMode) - Constructor for class com.apple.foundationdb.record.PlanSerializationContext
 
PlanSerializationContext(PlanSerializationRegistry, PlanHashable.PlanHashMode, IdentityBiMap<RecordQueryPlan, Integer>, BiMap<Equivalence.Wrapper<Type.Record>, Integer>) - Constructor for class com.apple.foundationdb.record.PlanSerializationContext
 
PlanSerializationRegistry - Interface in com.apple.foundationdb.record.query.plan.serialization
Plugin interface to be used by the plan serialization framework to dispatch serialization/deserialiation invocations properly.
PlanWithOrderingKey - Interface in com.apple.foundationdb.record.query.plan
A plan that knows its own {#link PlanOrderingKey}.
PlanWithStoredFields - Interface in com.apple.foundationdb.record.query.plan
A plan that has some, but not all, stored fields.
policy - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
poll(K) - Method in class com.apple.foundationdb.record.provider.common.MappedPool
 
pool - Variable in class com.apple.foundationdb.record.provider.common.MappedPool
 
pop() - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
Method to pop and return the top of the states stack.
pop() - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
Method to pop and return the top of the states stack.
pop() - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
Method to pop and return the top of the states stack.
pop(T) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
Functional pop to facilitate a more fluent way of interacting with the states.
pop(T) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
Functional pop to facilitate a more fluent way of interacting with the states.
pop(T) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
Functional pop to facilitate a more fluent way of interacting with the states.
POP - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
popScope() - Method in class com.apple.foundationdb.record.query.plan.explain.DefaultExplainFormatter
 
popScope() - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
PopToken(int) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.PopToken
 
POSITIONS_FIELD - Static variable in class com.apple.foundationdb.record.metadata.UnnestedRecordType
Special field in the synthetic record that contains the positions of all of the nested constituents.
possibleEvents() - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer
 
postOrderIterable() - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Method that returns an Iterable of nodes as encountered in post-order traversal of this tree-like.
postOrderStream() - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Returns a Stream that traverses the nodes in post-order.
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.InJoinVisitor
 
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.InUnionVisitor
 
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
 
predecessors(N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
PREDICATE_FILTER_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
PredicatedMatcher - Interface in com.apple.foundationdb.record.query.plan.cascades.matching.graph
Tag interface for predicate matchers, that is instances of FindingMatcher.
PredicateMap - Class in com.apple.foundationdb.record.query.plan.cascades
Predicate map that enforces a constraint that a predicate can only be mapped to at most one candidate.
PredicateMap.Builder - Class in com.apple.foundationdb.record.query.plan.cascades
Builder class for a predicate maps.
PredicateMetrics(long, long, int) - Constructor for class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer.PredicateMetrics
 
PredicateMultiMap - Class in com.apple.foundationdb.record.query.plan.cascades
Map that maps from a QueryPredicate of a query to a QueryPredicate of a MatchCandidate.
PredicateMultiMap(SetMultimap<QueryPredicate, PredicateMultiMap.PredicateMapping>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap
 
PredicateMultiMap.Builder - Class in com.apple.foundationdb.record.query.plan.cascades
Builder class for a predicate maps.
PredicateMultiMap.PredicateCompensation - Interface in com.apple.foundationdb.record.query.plan.cascades
Functional interface to reapply a predicate if necessary.
PredicateMultiMap.PredicateCompensationFunction - Interface in com.apple.foundationdb.record.query.plan.cascades
Functional interface to reapply a predicate if necessary.
PredicateMultiMap.PredicateMapping - Class in com.apple.foundationdb.record.query.plan.cascades
Mapping class.
PredicateMultiMap.PredicateMapping.Builder - Class in com.apple.foundationdb.record.query.plan.cascades
PredicateMultiMap.PredicateMapping.MappingKey - Class in com.apple.foundationdb.record.query.plan.cascades
Class to capture the relationship between query predicate and candidate predicate.
PredicateMultiMap.PredicateMapping.MappingKind - Enum in com.apple.foundationdb.record.query.plan.cascades
Kind of mapping.
PredicateMultiMap.ResultCompensationFunction - Interface in com.apple.foundationdb.record.query.plan.cascades
Functional interface to finally adjust the shape of the records returned by the index/match.
predicates(BindingMatcher<? extends QueryPredicate>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
predicates(CollectionMatcher<? extends QueryPredicate>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
predicatesFilter(BindingMatcher<? extends QueryPredicate>, BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
predicatesFilter(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
predicatesFilter(CollectionMatcher<? extends QueryPredicate>, CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
predicatesFilter(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
predicatesFilterPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
predicatesFilterPlan(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
PredicateToLogicalUnionRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
Transform a SelectExpression with a set of QueryPredicates into a union operation.
PredicateToLogicalUnionRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PredicateToLogicalUnionRule
 
PredicateWithComparisons - Interface in com.apple.foundationdb.record.query.plan.cascades.predicates
Tag interface to announce that the implementing class can provide Comparisons.Comparisons upon request.
PredicateWithValue - Interface in com.apple.foundationdb.record.query.plan.cascades.predicates
A predicate consisting of a Value.
PredicateWithValueAndRanges - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
This class associates a Value with a set of range constraints (RangeConstraints).
PredicateWithValueAndRanges(PlanSerializationContext, PPredicateWithValueAndRanges) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
PredicateWithValueAndRanges(Value, Set<RangeConstraints>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
Creates a new instance of PredicateWithValueAndRanges.
PredicateWithValueAndRanges.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Deserializer.
PREFER_INDEX - Enum constant in enum com.apple.foundationdb.record.query.plan.QueryPlanner.IndexScanPreference
Prefer index scan over full scan.
PREFER_PRIMARY_KEY_INDEX - Enum constant in enum com.apple.foundationdb.record.query.plan.QueryPlanner.IndexScanPreference
Prefer a scan using an index for exactly the primary key.
PREFER_SCAN - Enum constant in enum com.apple.foundationdb.record.query.plan.QueryPlanner.IndexScanPreference
Prefer a full scan over an index scan.
prefix(int) - Method in class com.apple.foundationdb.record.TupleRange
Create a TupleRange over a prefix of the keys of this range.
prefix(BindingMatcher<? extends ScanComparisons>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
prefix(List<? extends OrderingPart<S>>, int) - Static method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart
 
PREFIX - Static variable in enum com.apple.foundationdb.record.Bindings.Internal
 
PREFIX_STRING - Enum constant in enum com.apple.foundationdb.record.EndpointType
 
prefixedBy(String) - Static method in class com.apple.foundationdb.record.TupleRange
Create a TupleRange over all keys prefixed by some String.
preloadMetaData(RecordMetaDataProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBMetaDataStore
Prepare a meta-data store for use by loading any existing RecordMetaData or 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 that FDBRecordStore.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 sets recordStoreStateRef.
preloadSubspaceAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Ensure that subspace provider has cached Subspace so that calling FDBStoreBase.getSubspace() will not block.
preOrderIterable() - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Method that returns an Iterable of nodes as encountered in pre-order traversal of this tree-like.
preOrderIterable(Predicate<T>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Method that returns an Iterable of nodes as encountered in pre-order traversal of this tree-like.
preOrderIterator() - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Returns an iterator that traverse the nodes in pre-order.
preOrderIterator(Predicate<T>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
 
PreOrderIterator<T extends TreeLike<T>> - Class in com.apple.foundationdb.record.query.plan.cascades
An iterator that accesses all elements of a TreeLike object in pre-order fashion.
preOrderStream() - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Returns a Stream that traverses the nodes in pre-order.
prepare() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
Called by subclasses to perform chacks and initialize all the required properties needed to construct cursors.
prepend(Tuple) - Method in class com.apple.foundationdb.record.TupleRange
Create a TupleRange over the same keys as this range but prepended by the supplied Tuple.
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
 
present(BindingMatcher<?>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.OptionalIfPresentMatcher
 
preserve() - Static method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
Method to create an ordering instance that preserves the order of records.
PRESERVE_DISTINCTNESS - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering.Distinctness
 
presetCommonParams(Index, boolean, boolean, Collection<RecordType>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexScrubbingToolsDangling
 
presetCommonParams(Index, boolean, boolean, Collection<RecordType>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexScrubbingToolsMissing
 
presetCommonParams(Index, boolean, boolean, Collection<RecordType>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScrubbingTools
This function should be called prior to any other operation to set common parameters.
prettyExplain(RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
prettyExplain(RecordQueryPlan, int) - Static method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
PrettyExplainFormatter - Class in com.apple.foundationdb.record.query.plan.explain
A formatter for tokens.
PrettyExplainFormatter(Supplier<ExplainSymbolMap>, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter
 
PrettyExplainFormatter.Color - Enum in com.apple.foundationdb.record.query.plan.explain
Utility class that encapsulates ANSI escape sequences for colors.
prev() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Returns a decremented version of the current FDBRecordVersion.
PRIMARY - Static variable in class com.apple.foundationdb.record.provider.common.text.TextCollator.Strength
Respect primary differences, which normally means base form.
PRIMARY_INDEX - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
PRIMARY_KEY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
PRIMARY_KEY - Enum constant in enum com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords
 
PRIMARY_KEY - Static variable in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty
 
PrimaryAccessExpansionVisitor - Class in com.apple.foundationdb.record.query.plan.cascades
Class to expand primary data access into a candidate.
PrimaryAccessExpansionVisitor(Collection<RecordType>, Collection<RecordType>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.PrimaryAccessExpansionVisitor
 
PrimaryAccessHint - Class in com.apple.foundationdb.record.query.plan.cascades
Represents reading a table directly without using an index plus fetch.
PrimaryAccessHint() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.PrimaryAccessHint
 
primaryKeyHasRecordTypePrefix() - Method in class com.apple.foundationdb.record.metadata.RecordType
Determine whether this record type has a RecordTypeKeyExpression prefix in the primary key.
primaryKeyHasRecordTypePrefix() - Method in class com.apple.foundationdb.record.RecordMetaData
Determine whether every record type in this meta-data has RecordType.primaryKeyHasRecordTypePrefix().
PrimaryKeyProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
The primary key property that computes the primary key of a sub graph if it exists.
PrimaryKeyProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty
 
PrimaryKeyProperty.PrimaryKeyVisitor - Class in com.apple.foundationdb.record.query.plan.cascades.properties
Planner property which indicates if the record flowed as the result of a RecordQueryPlan flows things stored records flow, e.g.
PrimaryKeyVisitor() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
primaryScanExpression() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
PrimaryScanExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A logical version of RecordQueryScanPlan.
PrimaryScanExpression(PrimaryScanMatchCandidate, Set<String>, Type.Record, List<ComparisonRange>, boolean, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
PrimaryScanMatchCandidate - Class in com.apple.foundationdb.record.query.plan.cascades
Case class to represent a match candidate that is backed by an index.
PrimaryScanMatchCandidate(Traversal, List<CorrelationIdentifier>, Collection<RecordType>, Collection<RecordType>, KeyExpression, Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
primitiveAccessorsForType(Type, Supplier<Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.Values
Method to construct a set of Value that can be used to express orderings based on the type of a flowed object.
PrimitiveAccumulatorOperation - Enum in com.apple.foundationdb.record.cursors.aggregate
The types of accumulation operations allowed for a primitive accumulator.
primitiveArrayHash(Object) - Static method in interface com.apple.foundationdb.record.PlanHashable
 
PrimitiveMatchers - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Binding matchers (BindingMatcher) for primitive types.
primitiveType(Type.TypeCode) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
For a given Type.TypeCode, it returns a corresponding nullable Type.
primitiveType(Type.TypeCode, boolean) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
For a given Type.TypeCode, it returns a corresponding Type.
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.
productAccumulator() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.ComputingMatcher
Method that returns an MatchAccumulator that accumulates Iterables of type M and finally produces an EnumeratingIterable of type M that is the cross product of all elements of the respective Iterables.
promoteToDirectional() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Intersection
 
promoteToDirectional() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.SetOperationsOrdering
 
promoteToDirectional() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Union
 
promoteToTypeMaybe(Type) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
PromoteValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value that promotes an object of a type to an object of another type.
PromoteValue(Value, Type, MessageHelpers.CoercionTrieNode) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
Constructs a new PromoteValue instance.
PromoteValue.ArrayCoercionBiFunction - Class in com.apple.foundationdb.record.query.plan.cascades.values
Coercion function for arrays.
PromoteValue.ArrayCoercionBiFunction.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
PromoteValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
PromoteValue.PrimitiveCoercionBiFunction - Class in com.apple.foundationdb.record.query.plan.cascades.values
A coercion function for primitive types.
PromoteValue.PrimitiveCoercionBiFunction.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
PropertiesMap - Class in com.apple.foundationdb.record.query.plan.cascades
Class to manage properties for plans.
PropertiesMap(Collection<? extends RelationalExpression>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.PropertiesMap
 
PROPERTY_NAME - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
PROPERTY_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
Proposition - Enum in com.apple.foundationdb.record.query.plan.cascades.predicates
Represents a three-valued logic operation.
protoEnumBiMap(Class<E1>, Class<E2>) - Static method in class com.apple.foundationdb.record.query.plan.serialization.PlanSerialization
BiMap to cache enum relationships.
protoObjectToAny(PlanSerializationContext, Message) - Static method in class com.apple.foundationdb.record.query.plan.serialization.PlanSerialization
Method that packs a Message passed in into an Any using the correct type url prefix.
ProtoSerializable - Interface in com.apple.foundationdb.record
A interface indicating whether a given type can be serialized into a ProtoBuf Message.
protoToValueObject(PComparableObject) - Static method in class com.apple.foundationdb.record.query.plan.serialization.PlanSerialization
Helper method to deserialize plan fragments that are essentially values of the underlying data model.
ProtoUtils - Class in com.apple.foundationdb.record.util
Utility functions for interacting with protobuf.
ProtoUtils.DynamicEnum - Class in com.apple.foundationdb.record.util
A dynamic enum when we don't want to worry about actual enum structures/descriptors etc.
PROVIDED_KEY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
PROVIDED_VALUE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
ProvidedOrderingPart(Value, OrderingPart.ProvidedSortOrder) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedOrderingPart
 
pruneWith(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Method that replaces the current members of this reference with a new value.
PULL_UP_DEPENDS_ON - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.PullUpValueRuleSet
 
PULL_UP_RULES - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.PullUpValueRuleSet
 
pullUp(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
pullUp(Value, AliasMap, Set<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
pullUp(Iterable<? extends Value>, AliasMap, Set<CorrelationIdentifier>, CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedValue
 
pullUp(Iterable<? extends Value>, AliasMap, Set<CorrelationIdentifier>, CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Method to pull up a list of values through this value.
PullUp - Class in com.apple.foundationdb.record.query.plan.cascades.values.translation
Chain to pull up Value trees through a series of relational expressions.
pullUpAllExistingQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
pullUpAllQuantifiers(Iterable<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
pullUpAndComposeTranslationMapsMaybe(RelationalExpression, AliasMap, IdentityBiMap<Quantifier, PartialMatch>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
pullUpMaxMatchMapMaybe(MaxMatchMap, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Existential
 
pullUpMaxMatchMapMaybe(MaxMatchMap, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach
 
pullUpMaxMatchMapMaybe(MaxMatchMap, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
pullUpMaxMatchMapMaybe(MaxMatchMap, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
Method that produces a TranslationMap comprising a single item which replaces this.getAlias() with the queryResultValue that is rewritten in terms of candidateAlias according this map of maximum matches between the queryResultValue and the candidateResultValue.
pullUpMaybe(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.PullUp
Pull up a Value expressed in the appropriate scope of matching (some expression in the matching path) using this PullUp.
PullUpNullOnEmptyRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rewrite rule that splits a SelectExpression expression that ranges over a child with a Quantifier that has null-on-empty semantics into two parts: a lower SelectExpression expression that ranges over the old child with a normal Quantifier, i.e.
PullUpNullOnEmptyRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PullUpNullOnEmptyRule
 
pullUpQuantifier(Quantifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
pullUpResultColumns(Type, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
pullUpToParent(CorrelationIdentifier, Predicate<QueryPredicate>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
pullUpToParent(CorrelationIdentifier, Set<QueryPredicate>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
PullUpValueRuleSet - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A set of rules for use by a planner that supports quickly finding rules that could match a given planner expression.
PullUpValueRuleSet() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.PullUpValueRuleSet
 
push(KeyExpressionExpansionVisitor.VisitorState) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
 
push(ScalarTranslationVisitor.ScalarVisitorState) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
push(ExpressionToTuplePathVisitor.State) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
PUSH - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
pushConstraint(Reference, PlannerConstraint<T>, T) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
PushDistinctBelowFilterRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
PushDistinctBelowFilterRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushDistinctBelowFilterRule
 
PushDistinctThroughFetchRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes a RecordQueryUnorderedPrimaryKeyDistinctPlan through a RecordQueryFetchFromPartialRecordPlan in order to reduce the number of records prior to a potentially expensive fetch operation.
PushDistinctThroughFetchRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushDistinctThroughFetchRule
 
pushDown(Value, AliasMap, Set<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
pushDown(Value, CorrelationIdentifier, AliasMap, Set<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
Method to push this requested ordering through the value that is passed in.
pushDown(Iterable<? extends Value>, AbstractValueRuleSet<Value, ValueSimplificationRuleCall>, AliasMap, Set<CorrelationIdentifier>, CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Method to push down a list of values through this value.
PushFilterThroughFetchRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes a set of predicates that can be evaluated on a partial record of keys and values that were retrieved by an index scan underneath a RecordQueryFetchFromPartialRecordPlan in order to filter out records not satisfying the pushed predicates prior to a potentially expensive fetch operation.
PushFilterThroughFetchRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushFilterThroughFetchRule
 
PushInJoinThroughFetchRule<P extends RecordQueryInJoinPlan> - Class in com.apple.foundationdb.record.query.plan.cascades.rules
PushInJoinThroughFetchRule(Class<P>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushInJoinThroughFetchRule
 
PushMapThroughFetchRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes a map expression containing a Value that can be evaluated on a partial record of keys and values that were retrieved by an index scan underneath a RecordQueryFetchFromPartialRecordPlan in order to eliminate the fetch altogether.
PushMapThroughFetchRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushMapThroughFetchRule
 
pushProperty(PlannerConstraint<T>, T) - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
Push a constraint into this map.
PushReferencedFieldsThroughDistinctRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
PushReferencedFieldsThroughDistinctRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushReferencedFieldsThroughDistinctRule
 
PushReferencedFieldsThroughFilterRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes a ReferencedFieldsConstraint through a LogicalFilterExpression.
PushReferencedFieldsThroughFilterRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushReferencedFieldsThroughFilterRule
 
PushReferencedFieldsThroughSelectRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes a ReferencedFieldsConstraint through a SelectExpression.
PushReferencedFieldsThroughSelectRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushReferencedFieldsThroughSelectRule
 
PushReferencedFieldsThroughUniqueRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes a ReferencedFieldsConstraint through a LogicalUniqueExpression.
PushReferencedFieldsThroughUniqueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushReferencedFieldsThroughUniqueRule
 
PushRequestedOrderingThroughDeleteRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes an ordering RequestedOrderingConstraint through a DeleteExpression.
PushRequestedOrderingThroughDeleteRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughDeleteRule
 
PushRequestedOrderingThroughDistinctRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
PushRequestedOrderingThroughDistinctRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughDistinctRule
 
PushRequestedOrderingThroughGroupByRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
Rule that passes sorting requirements from GROUP BY expression downstream.
PushRequestedOrderingThroughGroupByRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughGroupByRule
 
PushRequestedOrderingThroughInLikeSelectRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes an RequestedOrderingConstraint through a specific SelectExpression.
PushRequestedOrderingThroughInLikeSelectRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughInLikeSelectRule
 
PushRequestedOrderingThroughInsertRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes an ordering RequestedOrderingConstraint through an InsertExpression.
PushRequestedOrderingThroughInsertRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughInsertRule
 
PushRequestedOrderingThroughInsertTempTableRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes an ordering RequestedOrderingConstraint through an TempTableInsertExpression.
PushRequestedOrderingThroughInsertTempTableRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughInsertTempTableRule
 
PushRequestedOrderingThroughRecursiveUnionRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes an ordering RequestedOrderingConstraint through a RecursiveUnionExpression.
PushRequestedOrderingThroughRecursiveUnionRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughRecursiveUnionRule
 
PushRequestedOrderingThroughSelectExistentialRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes a ReferencedFieldsConstraint through a SelectExpression.
PushRequestedOrderingThroughSelectExistentialRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughSelectExistentialRule
 
PushRequestedOrderingThroughSelectRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes a ReferencedFieldsConstraint through a SelectExpression.
PushRequestedOrderingThroughSelectRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughSelectRule
 
PushRequestedOrderingThroughSortRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes an ordering RequestedOrderingConstraint through a LogicalSortExpression.
PushRequestedOrderingThroughSortRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughSortRule
 
PushRequestedOrderingThroughUnionRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes an ordering RequestedOrderingConstraint through a LogicalUnionExpression.
PushRequestedOrderingThroughUnionRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughUnionRule
 
PushRequestedOrderingThroughUniqueRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes an RequestedOrderingConstraint through a LogicalUniqueExpression.
PushRequestedOrderingThroughUniqueRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughUniqueRule
 
PushRequestedOrderingThroughUpdateRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that pushes an ordering RequestedOrderingConstraint through an UpdateExpression.
PushRequestedOrderingThroughUpdateRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushRequestedOrderingThroughUpdateRule
 
pushScope() - Method in class com.apple.foundationdb.record.query.plan.explain.DefaultExplainFormatter
 
pushScope() - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
PushSetOperationThroughFetchRule<P extends RecordQuerySetPlan> - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A (prototype) rule that pushes a set operation (e.g.
PushSetOperationThroughFetchRule(Class<P>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushSetOperationThroughFetchRule
 
PushToken(int) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.PushToken
 
PushTypeFilterBelowFilterRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
PushTypeFilterBelowFilterRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.PushTypeFilterBelowFilterRule
 
pushValue(Value, CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
pushValueFunction(List<TranslateValueFunction>) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan
 
pushValueThroughFetch(Value, CorrelationIdentifier, CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.ScanWithFetchMatchCandidate
 
pushValueThroughFetch(Value, CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
pushValueThroughFetch(Value, CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
pushValueThroughFetch(Value, CorrelationIdentifier, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
pushValueThroughFetch(Value, CorrelationIdentifier, CorrelationIdentifier, CorrelationIdentifier, Iterable<? extends Value>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.ScanWithFetchMatchCandidate
 
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.cascades.AliasMap.Builder
Put a new binding between source and target.
put(BindingMatcher<? extends T>, T) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings.Builder
 
put(QueryPredicate, PredicateMultiMap.PredicateMapping) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.Builder
 
put(QueryPlanInfo.QueryPlanInfoKey<T>, T) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo.Builder
Set a value for the given key.
put(Equivalence.Wrapper<K>, Equivalence.Wrapper<V>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
put(K, V) - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentityMap
 
putAll(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap.Builder
Put all binding that are contained in another AliasMap.
putAll(BindingMatcher<? extends T>, Iterable<? extends T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings.Builder
 
putAll(PlannerBindings) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings.Builder
 
putAll(PredicateMultiMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.Builder
 
putAll(QueryPredicate, Set<PredicateMultiMap.PredicateMapping>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.Builder
 
putAll(Map<? extends Equivalence.Wrapper<K>, ? extends Equivalence.Wrapper<V>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
putIfAbsent(Equivalence.Wrapper<K>, Equivalence.Wrapper<V>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
putIfAbsentUnwrapped(K, V) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
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.
putInSessionIfAbsent(Object, T) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Put an object into the session of the FDBRecordContext.
putOrReplaceForTesting(FDBRecordContext, ScopedValue<String>, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
Write an entry to the reverse directory, STRICTLY FOR TESTING.
putReverse(FDBRecordContext, long, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
 
putReverse(FDBRecordContext, long, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Explicitly write an entry to the reverse directory for the resolver.
putReverse(FDBRecordContext, long, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
 
putReverse(FDBRecordContext, long, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
 
putReverse(FDBRecordContext, Long, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.StringInterningLayer
 
putUnwrapped(K, V) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 

Q

quantifiedObjectValue() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
QuantifiedObjectValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value representing the quantifier as an object.
QuantifiedObjectValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
QuantifiedRecordValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value representing the quantifier as an object.
QuantifiedRecordValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
QuantifiedValue - Interface in com.apple.foundationdb.record.query.plan.cascades.values
A scalar value type that is directly derived from an alias.
Quantifier - Class in com.apple.foundationdb.record.query.plan.cascades
Models the concept of quantification.
Quantifier(CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
Quantifier.Builder<Q extends Quantifier,B extends Quantifier.Builder<Q,B>> - Class in com.apple.foundationdb.record.query.plan.cascades
Builder class for quantifiers.
Quantifier.Existential - Class in com.apple.foundationdb.record.query.plan.cascades
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.cascades
Builder subclass for existential quantifiers.
Quantifier.ForEach - Class in com.apple.foundationdb.record.query.plan.cascades
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.cascades
Builder subclass to build for-each quantifiers.
Quantifier.Physical - Class in com.apple.foundationdb.record.query.plan.cascades
Physical quantifier.
Quantifier.Physical.PhysicalBuilder - Class in com.apple.foundationdb.record.query.plan.cascades
Builder subclass for physical quantifiers.
QuantifierMatchers - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Matchers for Quantifiers.
quantifiers - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
Quantifiers - Class in com.apple.foundationdb.record.query.plan.cascades
Auxiliary class containing factory methods and helpers for Quantifier.
Quantifiers.AliasResolver - Class in com.apple.foundationdb.record.query.plan.cascades
Resolver to resolve aliases to quantifiers.
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.
QueriedValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value representing the source of a value derivation.
QueriedValue() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
QueriedValue(Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
QueriedValue(Type, Iterable<String>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
QueriedValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
Query - Class in com.apple.foundationdb.record.query.expressions
Holder class for creating querying expressions.
QUERY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
QUERY - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
QUERY - Enum constant in enum com.apple.foundationdb.record.provider.common.text.TextTokenizer.TokenizerMode
Tokenize a String as if it were about to be used as the arguments to a query.
QUERY_AGGREGATE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in RecordQueryStreamingAggregationPlan as part of executing a query.
QUERY_AGGREGATE_GROUP_MAX_SIZE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The max size of aggregate group created by RecordQueryStreamingAggregationPlan.
QUERY_AGGREGATE_GROUPS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of aggregate groups created by RecordQueryStreamingAggregationPlan.
QUERY_COMPARATOR - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in RecordQueryComparatorPlan as part of executing a query.
QUERY_COMPARATOR_COMPARED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of comparisons made by RecordQueryComparatorPlan.
QUERY_COMPARATOR_MATCH - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of matching records by RecordQueryComparatorPlan.
QUERY_COMPARATOR_MISMATCH - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of comparison failures by RecordQueryComparatorPlan.
QUERY_DISCARDED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of records filtered out as not matching or duplicate.
QUERY_DISTINCT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in RecordQueryUnorderedDistinctPlan as part of executing a query.
QUERY_DISTINCT_PLAN_DUPLICATES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of duplicate records found by RecordQueryUnorderedDistinctPlan.
QUERY_DISTINCT_PLAN_UNIQUES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of unique records found by RecordQueryUnorderedDistinctPlan.
QUERY_FILTER - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in RecordQueryFilterPlan as part of executing a query.
QUERY_FILTER_GIVEN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of records given given to any filter within any plan.
QUERY_FILTER_PASSED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of records passed by any filter within any plan.
QUERY_FILTER_PLAN_GIVEN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of records given to RecordQueryFilterPlan.
QUERY_FILTER_PLAN_PASSED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of records passed by RecordQueryFilterPlan.
QUERY_INTERSECTION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in RecordQueryIntersectionPlan as part of executing a query.
QUERY_INTERSECTION_PLAN_MATCHES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of matching records found by RecordQueryIntersectionPlan.
QUERY_INTERSECTION_PLAN_NONMATCHES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of non-matching records found by RecordQueryIntersectionPlan.
QUERY_PK_DISTINCT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in RecordQueryUnorderedPrimaryKeyDistinctPlan as part of executing a query.
QUERY_PK_DISTINCT_PLAN_DUPLICATES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of duplicate records found by RecordQueryUnorderedPrimaryKeyDistinctPlan.
QUERY_PK_DISTINCT_PLAN_UNIQUES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of unique records found by RecordQueryUnorderedPrimaryKeyDistinctPlan.
QUERY_RESULT_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
QUERY_SELECTOR - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in RecordQuerySelectorPlan as part of executing a query.
QUERY_TEXT_FILTER - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent filtering by text contents in RecordQueryTextIndexPlan as part of executing a query.
QUERY_TEXT_FILTER_PLAN_GIVEN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of records given to a filter within a RecordQueryTextIndexPlan.
QUERY_TEXT_FILTER_PLAN_PASSED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of records passed by a filter within a RecordQueryTextIndexPlan.
QUERY_TYPE_FILTER - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in RecordQueryTypeFilterPlan as part of executing a query.
QUERY_TYPE_FILTER_PLAN_GIVEN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of records given to RecordQueryTypeFilterPlan.
QUERY_TYPE_FILTER_PLAN_PASSED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of records passed by RecordQueryTypeFilterPlan.
QUERY_UNION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in RecordQueryUnionPlan as part of executing a query.
QUERY_UNION_PLAN_DUPLICATES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of duplicate records found by RecordQueryUnorderedDistinctPlan.
QUERY_UNION_PLAN_UNIQUES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of unique records found by RecordQueryUnorderedDistinctPlan.
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
QueryComponent - Interface in com.apple.foundationdb.record.query.expressions
Base component interface for checking whether a given record matches a query.
queryComponents(CollectionMatcher<? extends QueryComponent>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.EmptyKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.GroupingKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.KeyWithValueExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.ListKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.NestingKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.SplitKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.ThenKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.IndexRecordFunction
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.metadata.StoreRecordFunction
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.ObjectPlanHash
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.AndComponent
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextContainsAllPrefixesComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextWithMaxDistanceComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.EmptyComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.FieldWithComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.NestedField
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.NotComponent
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComponent
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.OrComponent
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithOneOfComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
queryHash(QueryHashable.QueryHashKind) - Method in interface com.apple.foundationdb.record.query.IndexQueryabilityFilter
queryHash(QueryHashable.QueryHashKind) - Method in class com.apple.foundationdb.record.query.RecordQuery
 
queryHash(QueryHashable.QueryHashKind) - Method in interface com.apple.foundationdb.record.QueryHashable
Return a hash similar to hashCode, but with the additional guarantee that is is stable across JVMs.
queryHash(QueryHashable.QueryHashKind, Object) - Static method in class com.apple.foundationdb.record.util.HashUtils
 
queryHash(QueryHashable.QueryHashKind, Object...) - Static method in class com.apple.foundationdb.record.util.HashUtils
 
QueryHashable - Interface in com.apple.foundationdb.record
Query hash - calculate and return identifying hash values for queries.
QueryHashable.QueryHashKind - Enum in com.apple.foundationdb.record
The "kinds" of queryHash calculations.
queryIndexingStamps() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Query the current indexing session.
QueryKeyExpression - Class in com.apple.foundationdb.record.query.expressions
Allow use of a QueryableKeyExpression in a query.
QueryKeyExpression(QueryableKeyExpression) - Constructor for class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
 
QueryKeyExpression.OneOfThem - Class in com.apple.foundationdb.record.query.expressions
Allow comparisons against a member of a multi-valued expression.
QueryKeyExpressionWithComparison - Class in com.apple.foundationdb.record.query.expressions
QueryKeyExpressionWithComparison(QueryableKeyExpression, Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithComparison
 
QueryKeyExpressionWithOneOfComparison - Class in com.apple.foundationdb.record.query.expressions
A QueryComponent that implements a Comparisons.Comparison against a multi-valued QueryableKeyExpression.
QueryKeyExpressionWithOneOfComparison(QueryableKeyExpression, Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.expressions.QueryKeyExpressionWithOneOfComparison
 
QueryPlan<T> - Interface in com.apple.foundationdb.record.query.plan.plans
An executable query plan.
QueryPlanConstraint - Class in com.apple.foundationdb.record.query.plan
Represents a query plan constraint.
QueryPlanInfo - Class in com.apple.foundationdb.record.query.plan
This class holds some additional information regarding the query plan that can be attached to the plan itself, without impacting its structure.
QueryPlanInfo.Builder - Class in com.apple.foundationdb.record.query.plan
A Builder for the QueryPlanInfo class.
QueryPlanInfo.QueryPlanInfoKey<T> - Class in com.apple.foundationdb.record.query.plan
An implementation of a type-safe Enum.
QueryPlanInfoKey(String) - Constructor for class com.apple.foundationdb.record.query.plan.QueryPlanInfo.QueryPlanInfoKey
 
QueryPlanInfoKeys - Class in com.apple.foundationdb.record.query.plan
Container for QueryPlanInfo.QueryPlanInfoKey static instances used in the planner.
QueryPlanner - Interface in com.apple.foundationdb.record.query.plan
A common interface for classes that can plan a RecordQuery into a RecordQueryPlan.
QueryPlanner.IndexScanPreference - Enum in com.apple.foundationdb.record.query.plan
Preference between index scan and record scan.
QueryPlanResult - Class in com.apple.foundationdb.record.query.plan
The result of planning a query.
QueryPlanResult(RecordQueryPlan) - Constructor for class com.apple.foundationdb.record.query.plan.QueryPlanResult
 
QueryPlanResult(RecordQueryPlan, QueryPlanInfo) - Constructor for class com.apple.foundationdb.record.query.plan.QueryPlanResult
 
QueryPlanUtils - Class in com.apple.foundationdb.record.query.plan.plans
Utility class for query planning.
QueryPredicate - Interface in com.apple.foundationdb.record.query.plan.cascades.predicates
Class to model the concept of a predicate.
QueryPredicateComputationRule<ARGUMENT,RESULT,TYPE extends QueryPredicate> - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
Intermediate class that fixes the type of the PlannerRuleCall.
QueryPredicateComputationRule(BindingMatcher<TYPE>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateComputationRule
 
QueryPredicateComputationRuleCall<ARGUMENT,RESULT> - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A rule call implementation for the computation of a result while traversing QueryPredicate trees.
QueryPredicateComputationRuleCall(AbstractRule<NonnullPair<QueryPredicate, RESULT>, QueryPredicateComputationRuleCall<ARGUMENT, RESULT>, QueryPredicate, ? extends QueryPredicate>, QueryPredicate, QueryPredicate, ARGUMENT, PlannerBindings, AliasMap, Set<CorrelationIdentifier>, Function<QueryPredicate, NonnullPair<QueryPredicate, RESULT>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateComputationRuleCall
 
QueryPredicateComputationRuleSet<ARGUMENT,RESULT> - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A set of rules for use by a planner that supports quickly finding rules that could match a given planner expression.
QueryPredicateComputationRuleSet(Set<? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, RESULT>, QueryPredicateComputationRuleCall<ARGUMENT, RESULT>, ? extends QueryPredicate>>, SetMultimap<? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, RESULT>, QueryPredicateComputationRuleCall<ARGUMENT, RESULT>, ? extends QueryPredicate>, ? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, RESULT>, QueryPredicateComputationRuleCall<ARGUMENT, RESULT>, ? extends QueryPredicate>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateComputationRuleSet
 
QueryPredicateMatchers - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A BindingMatcher is an expression that can be matched against a RelationalExpression tree, while binding certain expressions/references in the tree to expression matcher objects.
QueryPredicateWithChild - Interface in com.apple.foundationdb.record.query.plan.cascades.predicates
A scalar value type that has children.
QueryPredicateWithCnfRuleSet - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A set of rules for use by a planner that supports quickly finding rules that could match a given QueryPredicate.
QueryPredicateWithCnfRuleSet(Set<? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, List<QueryPlanConstraint>>, QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>, ? extends QueryPredicate>>, SetMultimap<? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, List<QueryPlanConstraint>>, QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>, ? extends QueryPredicate>, ? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, List<QueryPlanConstraint>>, QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>, ? extends QueryPredicate>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateWithCnfRuleSet
 
QueryPredicateWithDnfRuleSet - Class in com.apple.foundationdb.record.query.plan.cascades.predicates.simplification
A set of rules for use by a planner that supports quickly finding rules that could match a given QueryPredicate.
QueryPredicateWithDnfRuleSet(Set<? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, List<QueryPlanConstraint>>, QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>, ? extends QueryPredicate>>, SetMultimap<? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, List<QueryPlanConstraint>>, QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>, ? extends QueryPredicate>, ? extends AbstractQueryPredicateRule<NonnullPair<QueryPredicate, List<QueryPlanConstraint>>, QueryPredicateComputationRuleCall<EvaluationContext, List<QueryPlanConstraint>>, ? extends QueryPredicate>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateWithDnfRuleSet
 
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
 
QueryRecordFunction(RecordFunction<T>, QueryComponent) - Constructor for class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
 
QueryRecordFunctionWithComparison - Class in com.apple.foundationdb.record.query.expressions
A Comparisons.Comparison whose value from the record, to be compared with the comparison's value, is the result of applying a RecordFunction to the record.
QueryRecordFunctionWithComparison(RecordFunction<?>, Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.expressions.QueryRecordFunctionWithComparison
 
QueryResult - Class in com.apple.foundationdb.record.query.plan.plans
QueryResult is the general result that encapsulates the data that is flowed up from plan to plan as well as from plan to consumer.
QueryToKeyMatcher - Class in com.apple.foundationdb.record.query
Match a query filter, represented by a QueryComponent, to a KeyExpression.
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 particular KeyExpression.
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
 
range(String) - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
RANGE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RANGE_BYTES - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RANGE_DELETES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Total number of range delete (clear) operations.
RANGE_END - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RANGE_EXCLUSIVE - Enum constant in enum com.apple.foundationdb.record.EndpointType
 
RANGE_FETCHES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Number of network fetches performed.
RANGE_INCLUSIVE - Enum constant in enum com.apple.foundationdb.record.EndpointType
 
RANGE_KEYVALUES_FETCHED - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Number of Key-values fetched during a range scan.
RANGE_READS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Total number of range read (get) operations.
RANGE_SET_CLEAR - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of times an RangeSet is cleared.
RANGE_SET_CONTAINS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time checking if a RangeSet contains a specific key.
RANGE_SET_FIND_FIRST_MISSING - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time finding the first missing range from a RangeSet.
RANGE_SET_INSERT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent inserting ranges into a RangeSet.
RANGE_SET_IS_EMPTY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time checking if a RangeSet is empty.
RANGE_SET_LIST_MISSING - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time listing missing ranges from a RangeSet.
RANGE_START - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RANGE_VALUE_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RangeConstraints - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Represents a compile-time range that can be evaluated against other compile-time ranges with an optional list of deferred ranges that cannot be evaluated at compile-time but can still be used as scan index prefix.
RangeConstraints.Builder - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Builds an instance of RangeConstraints.
RangeConstraints.CompilableRange - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Represents a range that comprises an intersection of a set of Comparisons.Comparison with reference operands (i.e.
RangeCursor - Class in com.apple.foundationdb.record.cursors
A cursor that returns a sequence from 0 to an (exclusive) limit.
RangeCursor(Executor, int, byte[]) - Constructor for class com.apple.foundationdb.record.cursors.RangeCursor
 
RangeCursor(Executor, int, int) - Constructor for class com.apple.foundationdb.record.cursors.RangeCursor
 
rank(EvaluationContext, IndexRecordFunction<Long>, FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.RankIndexMaintainer
 
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 - Enum constant in enum 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 the IndexTypes.RANK skip list RankedSet.
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 the IndexTypes.RANK skip list RankedSet.
RANK_NLEVELS - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
The number of levels in the IndexTypes.RANK skip list RankedSet.
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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
The amount of time spent incrementing an existing level key of a RankedSet skip list.
RANKED_SET_ADD_INSERT_LEVEL_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
The amount of time spent incrementing an splitting a level of a RankedSet skip list by inserting another key.
RANKED_SET_ADD_LEVEL_ZERO_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
The amount of time spent adding to the finest level of a RankedSet skip list.
RANKED_SET_CONTAINS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
The amount of time spent checking for a key in a RankedSet skip list.
RANKED_SET_INIT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
The amount of time spent initializing a RankedSet skip list.
RANKED_SET_NEXT_LOOKUP - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
The amount of time spent looking up the next level of a RankedSet skip list.
RANKED_SET_NEXT_LOOKUP_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
The amount of time spent looking up the next entry of a RankedSet skip list.
RANKED_SET_RANK_FOR_SCORE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.Events
 
RANKED_SET_SCORE_FOR_RANK - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.Events
 
RANKED_SET_UPDATE - Enum constant in enum 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 a RankedSet.
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
A RankedSet that adds StoreTimer instrumentation.
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 a RankedSet of 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 for RankIndexMaintainer indexes.
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
 
RankValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A windowed value that computes the RANK of a list of expressions which can optionally be partitioned by expressions defining a window.
RankValue(PlanSerializationContext, PRankValue) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RankValue
 
RankValue(Iterable<? extends Value>, Iterable<? extends Value>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RankValue
 
RankValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
RAW_BYTES - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RD_CACHE_DIRECTORY_SCAN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
The amount of time spent scanning the directory subspace after a hard miss in FDBReverseDirectoryCache.
read() - Method in class com.apple.foundationdb.record.sorting.SortedFileReader
 
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(CodedInputStream) - Method in class com.apple.foundationdb.record.provider.foundationdb.SortedRecordSerializer
 
read(Function<? super ReadTransaction, T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
read(Function<? super ReadTransaction, V>) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
READ_CHILD_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
READ_LAST_KEY_MICROS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
READ_SAMPLE_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent reading a sample key to measure read latency.
READ_STATE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
READ_VERSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
READABLE - Enum constant in enum com.apple.foundationdb.record.IndexState
This is the default state for an index.
READABLE_UNIQUE_PENDING - Enum constant in enum com.apple.foundationdb.record.IndexState
Indicates that this unique index is fully "indexed", but some uniqueness violations still exist.
READABLE_UNIQUE_PENDING_FORMAT_VERSION - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
readAsync(Function<? super ReadTransaction, ? extends CompletableFuture<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
readAsync(Function<? super ReadTransaction, ? extends CompletableFuture<V>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
readInTransaction(FDBRecordContext, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Read a value within the context of a single transaction.
readReverse(FDBRecordContext, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ExtendedDirectoryLayer
 
readReverse(FDBRecordContext, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Resolve the key associated with a given value saved in this locatable resolver.
readReverse(FDBRecordContext, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
 
readReverse(FDBRecordContext, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
 
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
Deprecated.
implementors should switch to using ExtendedDirectoryLayer.readReverse(FDBRecordContext, Long) instead
readReverse(FDBStoreTimer, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Deprecated.
implementors should switch to using LocatableResolver.readReverse(FDBRecordContext, Long) instead
readReverse(FDBStoreTimer, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ScopedDirectoryLayer
Deprecated.
implementors should switch to using ScopedDirectoryLayer.readReverse(FDBRecordContext, Long) instead
readReverse(FDBStoreTimer, Long) - Method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
Deprecated.
implementors should switch to using ScopedInterningLayer.readReverse(FDBRecordContext, Long) instead
READS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Total number of read (get) operations.
readSortKeyAndRecord(CodedInputStream) - Method in class com.apple.foundationdb.record.provider.foundationdb.SortedRecordSerializer
 
readTransaction(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
 
readValue(CodedInputStream) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
readValue(CodedInputStream) - Method in interface com.apple.foundationdb.record.sorting.FileSortAdapter
Read the value from a Protobuf stream.
ReadVersionRecordStoreStateCache - Class in com.apple.foundationdb.record.provider.foundationdb.storestate
An implementation of the FDBRecordStoreStateCache that 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 creating ReadVersionRecordStoreStateCaches.
REAL_END - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
REASON - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
rebase(AliasMap) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
rebase(AliasMap) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
rebase(AliasMap) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
rebase(AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Correlated
Rebases this and all other objects this objects is composed of using a given translation map.
rebase(AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
rebase(AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
rebase(AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
rebase(AliasMap) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
rebaseLeaf(CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.LeafValue
 
rebaseLeaf(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
rebaseLeaf(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
rebaseLeaf(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
rebaseWithAliasMap(AliasMap) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap
 
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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.DesiredAction
 
REBUILD_ALL - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
 
REBUILD_INDEX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent rebuilding an index for any reason.
REBUILD_INDEX_COUNTS_UNKNOWN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent rebuilding an index when count is unknown.
REBUILD_INDEX_EXPLICIT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent rebuilding an index by explicit request.
REBUILD_INDEX_FEW_RECORDS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent rebuilding an index for stores with few records.
REBUILD_INDEX_NEW_STORE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent rebuilding an index for a new store.
REBUILD_INDEX_REBUILD_ALL - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent rebuilding an index during rebuild all.
REBUILD_INDEX_TEST - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent rebuilding an index during a test.
REBUILD_RECORD_COUNTS - Enum constant in enum 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, 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.IndexingBase
 
rebuildIndexAsync(FDBRecordStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Transactionally rebuild an entire index.
rebuildIndexes(Map<Index, List<RecordType>>, Map<Index, CompletableFuture<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, StringBuilder) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
record(long) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer.Counter
Add value incurred in the occurrence of the associated event.
record(StoreTimer.Event, long) - Method in class com.apple.foundationdb.record.provider.common.StoreSubTimer
 
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(boolean, List<Type.Record.Field>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Constructs a new Type.Record using a list of Type.Record.Fields.
Record(String, boolean, List<Type.Record.Field>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Constructs a new Type.Record using a list of Type.Record.Fields and an explicit name.
RECORD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
 
RECORD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
RECORD_ASYNC_FILTER - Static variable in class com.apple.foundationdb.record.PipelineOperation
 
RECORD_BYTES_AFTER_COMPRESSION - Enum constant in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Counts
Total record bytes after compression was attempted.
RECORD_BYTES_BEFORE_COMPRESSION - Enum constant in enum com.apple.foundationdb.record.provider.common.RecordSerializer.Counts
Total record bytes for which compression was attempted.
RECORD_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RECORD_COUNT - Enum constant in enum 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_DOES_NOT_CONTAIN_FIELD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
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 - Enum constant in enum 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 - Enum constant in enum 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreKeyspace
 
RecordAlreadyExistsException - Exception in com.apple.foundationdb.record.provider.foundationdb
Exception thrown when FDBRecordStoreBase.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
 
recordConstructorValue(BindingMatcher<? extends Value>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
recordConstructorValue(CollectionMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
RecordConstructorValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value that encapsulates its children Values into a single Value of a Type.Record type.
RecordConstructorValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
RecordConstructorValue.RecordFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The record function.
RecordCoreArgumentException - Exception in com.apple.foundationdb.record
Functional equivalent of IllegalArgumentException.
RecordCoreArgumentException(String, Object...) - Constructor for exception com.apple.foundationdb.record.RecordCoreArgumentException
 
RecordCoreArgumentException(String, Throwable) - 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(String, Throwable, boolean, boolean) - 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 of InterruptedException.
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.ContinuationConvertor - Interface in com.apple.foundationdb.record
Transformation to apply to a continuation.
RecordCursor.NoNextReason - Enum in com.apple.foundationdb.record
The reason that RecordCursorResult.hasNext() returned false.
RecordCursorContinuation - Interface in com.apple.foundationdb.record
An interface for types that represent the continuation of a RecordCursor.
RecordCursorEndContinuation - Class in com.apple.foundationdb.record
A concrete continuation representing that a RecordCursor has returned all of the records that it ever will.
RecordCursorIterator<T> - Class in com.apple.foundationdb.record
An asynchronous iterator that wraps a RecordCursor and presents an iterator-style interface for advancing the cursor.
RecordCursorResult<T> - Class in com.apple.foundationdb.record
A result obtained when a RecordCursor advances.
RecordCursorResult.IllegalResultNoNextReasonAccessException - Exception in com.apple.foundationdb.record
An exception thrown when RecordCursorResult.getNoNextReason() is called on a result that has a next value.
RecordCursorResult.IllegalResultValueAccessException - Exception in com.apple.foundationdb.record
An exception thrown when RecordCursorResult.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 the RecordCursor interface.
RecordDoesNotExistException - Exception in com.apple.foundationdb.record.provider.foundationdb
Exception thrown when FDBRecordStoreBase.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
 
RecordFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue.RecordFn
 
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
 
recordFunctionIndexEntry(FDBRecordStore, Index, EvaluationContext, IndexRecordFunction<?>, FDBRecord<?>, int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
Get the index entry for use by the given index to evaluate the given record function.
recordFunctionWithSubrecordCondition(FDBRecordStore, IndexRecordFunction<T>, FDBRecord<?>, QueryComponent) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexFunctionHelper
recordIfInIndexedTypes(FDBStoredRecord<Message>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
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
 
RecordLayerPropertyKey<T> - Class in com.apple.foundationdb.record.provider.foundationdb.properties
A key for a property that adopter configures for Record Layer.
RecordLayerPropertyKey(String, T, Class<T>) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
 
RecordLayerPropertyStorage - Class in com.apple.foundationdb.record.provider.foundationdb.properties
Adopter can use this mapping of RecordLayerPropertyKeys to RecordLayerPropertyValues to configure Record Layer parameters.
RecordLayerPropertyStorage.Builder - Class in com.apple.foundationdb.record.provider.foundationdb.properties
Builder for RecordLayerPropertyStorage.
RecordLayerPropertyValue<T> - Class in com.apple.foundationdb.record.provider.foundationdb.properties
A value and its associated RecordLayerPropertyKey for a property that adopter configures for Record Layer.
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(RecordMetaData) - Constructor for class com.apple.foundationdb.record.RecordMetaData
 
RecordMetaData(Descriptors.FileDescriptor, Descriptors.Descriptor, Map<Descriptors.Descriptor, Descriptors.FieldDescriptor>, Map<String, RecordType>, Map<String, SyntheticRecordType<?>>, Map<Object, 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 for RecordMetaData.
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 of RecordMetaData.
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 for RecordQuery.
RecordQueryAbstractDataModificationPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that performs transformations on the incoming record according to a set of transformation instructions in conjunction with a target Type and a target Descriptors.Descriptor which both together define a set of instructions for type promotion and for protobuf coercion.
RecordQueryAbstractDataModificationPlan(PlanSerializationContext, PRecordQueryAbstractDataModificationPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
RecordQueryAbstractDataModificationPlan(Quantifier.Physical, String, Type.Record, MessageHelpers.TransformationTrieNode, MessageHelpers.CoercionTrieNode, Value, CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
RecordQueryAggregateIndexPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that reconstructs records from the entries in an aggregate index.
RecordQueryAggregateIndexPlan(RecordQueryIndexPlan, String, IndexKeyValueToPartialRecord, Value, Value, QueryPlanConstraint) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
Creates an instance of RecordQueryAggregateIndexPlan.
RecordQueryAggregateIndexPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryChooserPlanBase - Class in com.apple.foundationdb.record.query.plan.plans
A RecordQueryChooserPlanBase is a plan that, at runtime, chooses to execute plans from multiple alternatives.
RecordQueryChooserPlanBase(List<Quantifier.Physical>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryChooserPlanBase
 
RecordQueryComparatorPlan - Class in com.apple.foundationdb.record.query.plan.plans
A RecordQueryChooserPlanBase that executes all child plans and compares their results using the provided comparison key.
RecordQueryCoveringIndexPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that reconstructs records from the entries in a covering index.
RecordQueryCoveringIndexPlan(PlanSerializationContext, PRecordQueryCoveringIndexPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
RecordQueryCoveringIndexPlan(RecordQueryPlanWithIndex, String, AvailableFields, IndexKeyValueToPartialRecord) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
RecordQueryCoveringIndexPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryDamPlan - Class in com.apple.foundationdb.record.query.plan.sorting
A query plan implementing a dam in-memory.
RecordQueryDamPlan(RecordQueryPlan, RecordQuerySortKey) - Constructor for class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
RecordQueryDamPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.sorting
Deserializer.
RecordQueryDefaultOnEmptyPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that only flows all the records it processes from its inner.
RecordQueryDefaultOnEmptyPlan(Quantifier.Physical, Value) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
RecordQueryDefaultOnEmptyPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryDeletePlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that deletes records.
RecordQueryDeletePlan(Quantifier.Physical) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
RecordQueryDeletePlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryExplodePlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that applies the values it contains over the incoming ones.
RecordQueryExplodePlan(Value) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
RecordQueryExplodePlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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 the RecordQueryCoveringIndexPlan) into full records by fetching the records by primary key.
RecordQueryFetchFromPartialRecordPlan(PlanSerializationContext, PRecordQueryFetchFromPartialRecordPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
RecordQueryFetchFromPartialRecordPlan(Quantifier.Physical, TranslateValueFunction, Type, RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
RecordQueryFetchFromPartialRecordPlan(RecordQueryPlan, TranslateValueFunction, Type, RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
RecordQueryFetchFromPartialRecordPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords - Enum in com.apple.foundationdb.record.query.plan.plans
Enum to govern how to interpret the primary key of an index entry when accessing its base record(s).
RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords.FetchIndexRecordsFunction - Interface in com.apple.foundationdb.record.query.plan.plans
The function to apply.
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(Quantifier.Physical, List<QueryComponent>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
 
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
 
RecordQueryFilterPlanBase - Class in com.apple.foundationdb.record.query.plan.plans
A base class for all query plans that filter based on predicates.
RecordQueryFilterPlanBase(PlanSerializationContext, PRecordQueryFilterPlanBase) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
RecordQueryFilterPlanBase(Quantifier.Physical) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
RecordQueryFirstOrDefaultPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that only flows the first record it processes from its inner and then stops.
RecordQueryFirstOrDefaultPlan(Quantifier.Physical, Value) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
RecordQueryFirstOrDefaultPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryFlatMapPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that applies the values it contains over the incoming ones.
RecordQueryFlatMapPlan(Quantifier.Physical, Quantifier.Physical, Value, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
RecordQueryFlatMapPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryInComparandJoinPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that executes a child plan once for each of the elements extracted from a Comparison object's comparand.
RecordQueryInComparandJoinPlan(PlanSerializationContext, PRecordQueryInComparandJoinPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
RecordQueryInComparandJoinPlan(Quantifier.Physical, InComparandSource, Bindings.Internal) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
RecordQueryInComparandJoinPlan(Quantifier.Physical, String, Bindings.Internal, Comparisons.Comparison, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
RecordQueryInComparandJoinPlan(RecordQueryPlan, String, Bindings.Internal, Comparisons.Comparison, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
RecordQueryInComparandJoinPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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(PlanSerializationContext, PRecordQueryIndexPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
RecordQueryIndexPlan(String, KeyExpression, IndexScanParameters, IndexFetchMethod, RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
RecordQueryIndexPlan(String, KeyExpression, IndexScanParameters, IndexFetchMethod, RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords, boolean, boolean, MatchCandidate, Type.Record, QueryPlanConstraint) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
RecordQueryIndexPlan(String, KeyExpression, IndexScanParameters, IndexFetchMethod, RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords, boolean, boolean, Optional<? extends MatchCandidate>, Type, QueryPlanConstraint) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
RecordQueryIndexPlan(String, IndexScanParameters, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
RecordQueryIndexPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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 some IN list.
RecordQueryInJoinPlan(PlanSerializationContext, PRecordQueryInJoinPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
RecordQueryInJoinPlan(Quantifier.Physical, InSource, Bindings.Internal) - 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 an IN list taken from a parameter.
RecordQueryInParameterJoinPlan(PlanSerializationContext, PRecordQueryInParameterJoinPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
 
RecordQueryInParameterJoinPlan(Quantifier.Physical, InSource, Bindings.Internal) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
 
RecordQueryInParameterJoinPlan(Quantifier.Physical, String, Bindings.Internal, String, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
 
RecordQueryInParameterJoinPlan(RecordQueryPlan, String, Bindings.Internal, String, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
 
RecordQueryInParameterJoinPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryInsertPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that inserts records into the database.
RecordQueryInsertPlan(PlanSerializationContext, PRecordQueryInsertPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan
 
RecordQueryInsertPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryIntersectionOnKeyExpressionPlan - Class in com.apple.foundationdb.record.query.plan.plans
Intersection plan that compares using a KeyExpression.
RecordQueryIntersectionOnKeyExpressionPlan(PlanSerializationContext, PRecordQueryIntersectionOnKeyExpressionPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan
 
RecordQueryIntersectionOnKeyExpressionPlan(List<Quantifier.Physical>, KeyExpression, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan
 
RecordQueryIntersectionOnKeyExpressionPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryIntersectionOnValuesPlan - Class in com.apple.foundationdb.record.query.plan.plans
Intersection plan that compares using a Value.
RecordQueryIntersectionOnValuesPlan(PlanSerializationContext, PRecordQueryIntersectionOnValuesPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
RecordQueryIntersectionOnValuesPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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(PlanSerializationContext, PRecordQueryIntersectionPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
RecordQueryIntersectionPlan(List<Quantifier.Physical>, RecordQuerySetPlan.ComparisonKeyFunction, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
RecordQueryInUnionOnKeyExpressionPlan - Class in com.apple.foundationdb.record.query.plan.plans
Union plan that compares using a KeyExpression.
RecordQueryInUnionOnKeyExpressionPlan(PlanSerializationContext, PRecordQueryInUnionOnKeyExpressionPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan
 
RecordQueryInUnionOnKeyExpressionPlan(Quantifier.Physical, List<? extends InSource>, KeyExpression, boolean, int, Bindings.Internal) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan
 
RecordQueryInUnionOnKeyExpressionPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryInUnionOnValuesPlan - Class in com.apple.foundationdb.record.query.plan.plans
Union plan that compares using a Value.
RecordQueryInUnionOnValuesPlan(PlanSerializationContext, PRecordQueryInUnionOnValuesPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
RecordQueryInUnionOnValuesPlan(Quantifier.Physical, List<? extends InSource>, List<OrderingPart.ProvidedOrderingPart>, List<? extends Value>, boolean, int, Bindings.Internal) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
RecordQueryInUnionOnValuesPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryInUnionPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that executes union over instantiations of a child plan for each of the elements of some IN list(s).
RecordQueryInUnionPlan(PlanSerializationContext, PRecordQueryInUnionPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
RecordQueryInUnionPlan(Quantifier.Physical, List<? extends InSource>, RecordQuerySetPlan.ComparisonKeyFunction, boolean, int, Bindings.Internal) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
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 constant IN list.
RecordQueryInValuesJoinPlan(PlanSerializationContext, PRecordQueryInValuesJoinPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
 
RecordQueryInValuesJoinPlan(Quantifier.Physical, InValuesSource, Bindings.Internal) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
 
RecordQueryInValuesJoinPlan(RecordQueryPlan, String, Bindings.Internal, List<Object>, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
 
RecordQueryInValuesJoinPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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.
RecordQueryMapPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that applies the values it contains over the incoming ones.
RecordQueryMapPlan(Quantifier.Physical, Value) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
RecordQueryMapPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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
 
RecordQueryPlanMatchers - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Matchers for descendants of RecordQueryPlan.
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.CandidateScan - Class in com.apple.foundationdb.record.query.plan
 
RecordQueryPlanner.ScoredInfo<T,S extends RecordQueryPlanner.ScoredInfo<T,S>> - Class in com.apple.foundationdb.record.query.plan
 
RecordQueryPlanner.ScoredMatch - Class in com.apple.foundationdb.record.query.plan
 
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 the RecordQueryPlanner.
RecordQueryPlannerConfiguration.Builder - Class in com.apple.foundationdb.record.query.plan
RecordQueryPlannerSortConfiguration - Class in com.apple.foundationdb.record.query.plan.sorting
Configuration for planning of non-index sort queries.
RecordQueryPlannerSortConfiguration() - Constructor for class com.apple.foundationdb.record.query.plan.sorting.RecordQueryPlannerSortConfiguration
 
RecordQueryPlannerSubstitutionVisitor - Class in com.apple.foundationdb.record.query.plan.visitor
Visitor interface for performing substitution-type rules on RecordQueryPlans.
RecordQueryPlannerSubstitutionVisitor(RecordMetaData, PlannableIndexTypes, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.visitor.RecordQueryPlannerSubstitutionVisitor
 
RecordQueryPlanVisitor<T> - Interface in com.apple.foundationdb.record.query.plan.plans
 
RecordQueryPlanVisitorWithDefaults<T> - Interface in com.apple.foundationdb.record.query.plan.plans
 
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.
RecordQueryPlanWithComparisonKeyValues - Interface in com.apple.foundationdb.record.query.plan.plans
Interface to be implemented by plans that provide comparison key values.
RecordQueryPlanWithComparisons - Interface in com.apple.foundationdb.record.query.plan.plans
A query plan that uses ScanComparisons or Comparisons.Comparison to drive some scan of the record store.
RecordQueryPlanWithConstraint - Interface in com.apple.foundationdb.record.query.plan.plans
Mixin for a RecordQueryPlan that has a QueryPlanConstraint.
RecordQueryPlanWithExplain - Interface in com.apple.foundationdb.record.query.plan.plans
Interface for plans in downstream modules to implement explain functionality.
RecordQueryPlanWithIndex - Interface in com.apple.foundationdb.record.query.plan.plans
A query plan that uses a single index.
RecordQueryPlanWithMatchCandidate - Interface in com.apple.foundationdb.record.query.plan.plans
A query plan that was created using a MatchCandidate to match a physical access path.
RecordQueryPlanWithNoChildren - Interface in com.apple.foundationdb.record.query.plan.plans
A query plan that does not have any child plans.
RecordQueryPredicatesFilterPlan - 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 QueryPredicate.
RecordQueryPredicatesFilterPlan(PlanSerializationContext, PRecordQueryPredicatesFilterPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
RecordQueryPredicatesFilterPlan(Quantifier.Physical, Iterable<? extends QueryPredicate>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
RecordQueryPredicatesFilterPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryRangePlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that produced a stream of integers for 0(inclusive) to some limit (exclusive).
RecordQueryRangePlan(Value) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
RecordQueryRangePlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryRecursiveUnionPlan - Class in com.apple.foundationdb.record.query.plan.plans
A physical representation of a recursive union.
RecordQueryRecursiveUnionPlan(Quantifier.Physical, Quantifier.Physical, CorrelationIdentifier, CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
RecordQueryRecursiveUnionPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
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>, Type, KeyExpression, ScanComparisons, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
Overloaded constructor for heuristic (old planner).
RecordQueryScanPlan(Set<String>, Type, KeyExpression, ScanComparisons, boolean, boolean, WithPrimaryKeyMatchCandidate) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
Overloaded constructor.
RecordQueryScanPlan(Set<String>, Type, KeyExpression, ScanComparisons, boolean, boolean, Optional<? extends WithPrimaryKeyMatchCandidate>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
Overloaded constructor.
RecordQueryScanPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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.
RecordQuerySelectorPlan - Class in com.apple.foundationdb.record.query.plan.plans
A RecordQueryChooserPlanBase that selects one of its children to be executed.
RecordQuerySetPlan - Interface in com.apple.foundationdb.record.query.plan.plans
Interface for query plans that represent set-based operators such as union or intersection.
RecordQuerySetPlan.ComparisonKeyFunction - Interface in com.apple.foundationdb.record.query.plan.plans
A comparison key function that extracts a comparison key for binary comparison by some set operations which also provides a stable plan hash and hash code.
RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression - Class in com.apple.foundationdb.record.query.plan.plans
Class to encapsulate the functionality of extracting a comparison key from a QueryResult while also providing comparability and the ability to compute a stable plan hash.
RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQuerySetPlan.ComparisonKeyFunction.OnValues - Class in com.apple.foundationdb.record.query.plan.plans
Class to encapsulate the functionality of extracting a comparison key from a QueryResult while also providing comparability and the ability to compute a stable plan hash.
RecordQuerySetPlan.ComparisonKeyFunction.OnValues.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQuerySortAdapter<M extends Message> - Class in com.apple.foundationdb.record.query.plan.sorting
RecordQuerySortAdapter(int, boolean, BiFunction<MemorySortAdapter<Tuple, FDBQueriedRecord<M>>, Tuple, MemorySortAdapter.MemorySortComparator<Tuple>>, RecordQuerySortKey, FDBRecordStoreBase<M>) - Constructor for class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
RecordQuerySortKey - Class in com.apple.foundationdb.record.query.plan.sorting
Defines, logically, how RecordQuerySortPlan should sort the records.
RecordQuerySortKey(KeyExpression, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortKey
 
RecordQuerySortPlan - Class in com.apple.foundationdb.record.query.plan.sorting
A query plan implementing sorting in-memory, possibly spilling to disk.
RecordQuerySortPlan(RecordQueryPlan, RecordQuerySortKey) - Constructor for class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
RecordQuerySortPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.sorting
Deserializer.
RecordQueryStreamingAggregationPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that applies an aggregate function(s) to its inputs and also places them into groups.
RecordQueryStreamingAggregationPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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(Quantifier.Physical, Collection<String>, Type) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
RecordQueryTypeFilterPlan(RecordQueryPlan, Collection<String>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
RecordQueryTypeFilterPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryUnionOnKeyExpressionPlan - Class in com.apple.foundationdb.record.query.plan.plans
Union plan that compares using a KeyExpression.
RecordQueryUnionOnKeyExpressionPlan(PlanSerializationContext, PRecordQueryUnionOnKeyExpressionPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan
 
RecordQueryUnionOnKeyExpressionPlan(List<Quantifier.Physical>, KeyExpression, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan
 
RecordQueryUnionOnKeyExpressionPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryUnionOnValuesPlan - Class in com.apple.foundationdb.record.query.plan.plans
Union plan that compares using a Value.
RecordQueryUnionOnValuesPlan(PlanSerializationContext, PRecordQueryUnionOnValuesPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
RecordQueryUnionOnValuesPlan(List<Quantifier.Physical>, List<OrderingPart.ProvidedOrderingPart>, List<? extends Value>, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
RecordQueryUnionOnValuesPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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(PlanSerializationContext, PRecordQueryUnionPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
 
RecordQueryUnionPlan(List<Quantifier.Physical>, RecordQuerySetPlan.ComparisonKeyFunction, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
 
RecordQueryUnionPlanBase - Class in com.apple.foundationdb.record.query.plan.plans
Common base class for plans that perform stream union operations.
RecordQueryUnionPlanBase(PlanSerializationContext, PRecordQueryUnionPlanBase) - 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
 
RecordQueryUnorderedDistinctPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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(Quantifier.Physical) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
 
RecordQueryUnorderedPrimaryKeyDistinctPlan(RecordQueryPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
 
RecordQueryUnorderedPrimaryKeyDistinctPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
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.
RecordQueryUnorderedUnionPlan(PlanSerializationContext, PRecordQueryUnorderedUnionPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
 
RecordQueryUnorderedUnionPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
RecordQueryUpdatePlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that updates records in the database using a stream of incoming records, that are transformed according to a transformation map, then coerced into a target type, and then saved using FDBRecordStoreBase.saveRecord(Message).
RecordQueryUpdatePlan(PlanSerializationContext, PRecordQueryUpdatePlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
 
RecordQueryUpdatePlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
recordRead(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
RECORDS - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
RECORDS_PER_SECOND - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RECORDS_PER_SECOND - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
RECORDS_SCANNED - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RECORDS_SIZE_ESTIMATE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RECORDS_WHILE_BUILDING - Enum constant in enum 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 of RecordScanLimiters.
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
 
RecordSerializationValidationException - Exception in com.apple.foundationdb.record.provider.common
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.
recordSinceNanoTime(StoreTimer.Event, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
recordSize(StoreTimer.SizeEvent, long) - Method in class com.apple.foundationdb.record.provider.common.StoreSubTimer
 
recordSize(StoreTimer.SizeEvent, long) - Method in class com.apple.foundationdb.record.provider.common.StoreTimer
Record an event that has a size.
recordSize(StoreTimer.SizeEvent, long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTransactionContext
Record an event that has an associated size.
recordsSubspace() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
RecordStoreAlreadyExistsException - Exception in com.apple.foundationdb.record.provider.foundationdb
Exception thrown when FDBRecordStoreBase.BaseBuilder.create() is called, but the record store already exists.
RecordStoreAlreadyExistsException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.RecordStoreAlreadyExistsException
 
RecordStoreDoesNotExistException - Exception in com.apple.foundationdb.record.provider.foundationdb
Exception thrown when FDBRecordStoreBase.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 when FDBRecordStoreBase.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
 
RecordStoreNoInfoAndNotEmptyException(String, Throwable) - 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 given RecordMetaDataProvider.
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 given FDBRecordStoreBase.UserVersionChecker.
RecordStoreStaleUserVersionException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.RecordStoreStaleUserVersionException
 
RecordStoreState - Class in com.apple.foundationdb.record
The RecordStoreState interface handles information that might differ between otherwise identical record stores.
RecordStoreState(RecordMetaDataProto.DataStoreInfo, Map<String, IndexState>) - Constructor for class com.apple.foundationdb.record.RecordStoreState
Creates a RecordStoreState with the given index states.
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 for RecordType.
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 for RecordTypeBuilder that copies all fields except the descriptor.
RecordTypeBuilder.NonbuildableException - Exception in com.apple.foundationdb.record.metadata
Exception thrown when a RecordTypeBuilder is not yet in a state where it can be built.
RecordTypeChangedException - Exception in com.apple.foundationdb.record.provider.foundationdb
Exception thrown when FDBRecordStoreBase.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
 
RecordTypeIndexesBuilder - Class in com.apple.foundationdb.record.metadata
A base builder for RecordType.
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
A QueryComponent that implements checking for a given record type.
RecordTypeKeyComparison(String) - Constructor for class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
 
RecordTypeKeyComparison.RecordTypeComparison - Class in com.apple.foundationdb.record.query.expressions
Equality comparison to check for records of a particular record type.
RecordTypeKeyComparison.RecordTypeComparison.Deserializer - Class in com.apple.foundationdb.record.query.expressions
Deserializer.
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 the RecordType and RecordTypeBuilder classes that contains accessors that they are both expected to have.
recordTypes - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon.IndexContext
 
recordTypes - Variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.Builder
 
recordTypes(CollectionMatcher<? extends String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
recordTypesForIndex(Index) - Method in class com.apple.foundationdb.record.RecordMetaData
 
RecordTypesProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
A property visitor that determines the set of record type names (as Strings) that a RelationalExpression could produce.
RecordTypeValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value which is unique for each record type produced by its quantifier.
RecordTypeValue(Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
RecordTypeValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
RECOUNT_RECORDS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent counting records for the deprecated record count key.
RECURSIVE_UNION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
RecursiveUnionCursor<T> - Class in com.apple.foundationdb.record.cursors
A cursor that repeatedly executes its children until reaching a fix-point.
RecursiveUnionCursor(RecursiveUnionCursor.RecursiveStateManager<T>, Executor) - Constructor for class com.apple.foundationdb.record.cursors.RecursiveUnionCursor
 
RecursiveUnionCursor.Continuation - Class in com.apple.foundationdb.record.cursors
Continuation that captures the state of execution of a RecursiveUnionCursor that is orchestrated by RecordQueryRecursiveUnionPlan through a RecursiveUnionCursor.RecursiveStateManager.
RecursiveUnionCursor.RecursiveStateManager<T> - Interface in com.apple.foundationdb.record.cursors
Interface for recursive state management, the caller is expected to invoke respective callbacks when certain events occur so the internal state mutates accordingly, it also offers a set of methods that enable examining current state and whether the execution can proceed to a subsequent recursive state or not.
recursiveUnionExpression(BindingMatcher<? extends Quantifier>, BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
recursiveUnionExpression(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
RecursiveUnionExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
This is a logical representation of a recursive union, a recursive union is similar to a normal unordered union, however its legs have special execution semantics; just like a union, it returns the results verbatim of one particular leg called the "initial state" leg.
RecursiveUnionExpression(Quantifier, Quantifier, CorrelationIdentifier, CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
RED - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
reduce(U, BiFunction<U, ? super T, U>) - Method in interface com.apple.foundationdb.record.RecordCursor
Reduce contents of cursor to single value.
reduce(U, BiFunction<U, ? super T, U>, Predicate<U>) - Method in interface com.apple.foundationdb.record.RecordCursor
A reduce variant which allows stopping the processing when the value has been successfully reduced.
reference() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Memoizer.ReferenceBuilder
 
Reference - Class in com.apple.foundationdb.record.query.plan.cascades
The memo data structure can compactly represent a large set of similar RelationalExpressions through careful memoization.
Reference.UngettableReferenceException - Exception in com.apple.foundationdb.record.query.plan.cascades
An exception thrown when Reference.get() is called on a reference that does not support it, such as a reference containing more than one expression.
REFERENCED_FIELDS - Static variable in class com.apple.foundationdb.record.query.plan.cascades.ReferencedFieldsConstraint
 
ReferencedFields(Set<FieldValue>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ReferencedFieldsConstraint.ReferencedFields
 
ReferencedFieldsConstraint - Class in com.apple.foundationdb.record.query.plan.cascades
A constraint holding a set of referenced field values.
ReferencedFieldsConstraint() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ReferencedFieldsConstraint
 
ReferencedFieldsConstraint.ReferencedFields - Class in com.apple.foundationdb.record.query.plan.cascades
A set of referenced field values.
ReferenceEdge() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceEdge
 
ReferenceEdge(String, Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceEdge
 
ReferenceEdge(Set<? extends AbstractPlannerGraph.AbstractEdge>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceEdge
 
referenceFromMembers(Collection<? extends RelationalExpression>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Re-reference members of this group, i.e., use a subset of members to from a new Reference.
ReferenceHeadNode(Reference) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceHeadNode
 
ReferenceInternalEdge() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceInternalEdge
 
ReferenceMatchers - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Matchers for References.
ReferenceMemberNode() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceMemberNode
 
ReferenceMemberNode(String) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.ReferenceMemberNode
 
ReferencePath(Reference, RelationalExpression, Quantifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Traversal.ReferencePath
 
ReferencePrinter - Class in com.apple.foundationdb.record.query.plan.cascades
A utility class for printing out a Reference in a readable form.
ReferencePrinter(Reference) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ReferencePrinter
 
References - Class in com.apple.foundationdb.record.query.plan.cascades
Utility methods for References.
ReferencesAndDependenciesProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
This property establishes a partial order over the expressions contained in a subgraph.
ReferencesAndDependenciesProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.ReferencesAndDependenciesProperty
 
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
 
registerAlias(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.DefaultExplainFormatter
 
registerAlias(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.DefaultExplainSymbolMap
 
registerAlias(CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
registerAlias(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainSelfContainedSymbolMap
 
registerAlias(CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainSymbolMap
 
registerAliasExplicitly(CorrelationIdentifier, String) - Method in class com.apple.foundationdb.record.query.plan.explain.DefaultExplainFormatter
 
registerAliasExplicitly(CorrelationIdentifier, String) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
registerAliasWithExplicitSymbol(CorrelationIdentifier, String) - Method in class com.apple.foundationdb.record.query.plan.explain.DefaultExplainSymbolMap
 
registerAliasWithExplicitSymbol(CorrelationIdentifier, String) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainSelfContainedSymbolMap
 
registerAliasWithExplicitSymbol(CorrelationIdentifier, String) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainSymbolMap
 
registerExpression(RelationalExpression) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
registerQuantifier(Quantifier) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
registerReference(Reference) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
registerReferenceIdForRecordType(Type.Record) - Method in class com.apple.foundationdb.record.PlanSerializationContext
 
registerReferenceIdForRecordType(Type.Record, int) - Method in class com.apple.foundationdb.record.PlanSerializationContext
 
registerScannedBytes(long) - Method in interface com.apple.foundationdb.record.ByteScanLimiter
Atomically decrement the number of remaining bytes by the given number of bytes.
registerTypeToTypeNameMapping(Type, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
registerValue(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
REGULAR_IMPLIES_CANDIDATE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.MappingKind
 
regularMappingBuilder(QueryPredicate, QueryPredicate, QueryPredicate) - Static method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
Relation() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
Constructs a new Type.Relation object without a value type.
Relation(Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
Constructs a new Type.Relation object.
RELATION - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
RelationalExpression - Interface in com.apple.foundationdb.record.query.plan.cascades.expressions
A relational expression is a RelationalExpression that represents a stream of records.
RelationalExpression.CombineFunction<R,S> - Interface in com.apple.foundationdb.record.query.plan.cascades.expressions
RelationalExpression.CombinePredicate - Interface in com.apple.foundationdb.record.query.plan.cascades.expressions
A functional interface to combine the matches computed over pairs of quantifiers during matching into a boolean result (for the bound correlatedTo set handed into RelationalExpression.CombinePredicate.combine(com.apple.foundationdb.record.query.plan.cascades.AliasMap, java.lang.Iterable<com.apple.foundationdb.record.query.plan.cascades.AliasMap>)).
RelationalExpressionDepthProperty - Class in com.apple.foundationdb.record.query.plan.cascades.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.cascades.properties.RelationalExpressionDepthProperty
 
RelationalExpressionMatchers - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Matchers for descendants of RelationalExpression.
RelationalExpressionVisitor<T> - Interface in com.apple.foundationdb.record.query.plan.cascades.expressions
 
RelationalExpressionVisitorWithDefaults<T> - Interface in com.apple.foundationdb.record.query.plan.cascades.expressions
 
RelationalExpressionWithChildren - Interface in com.apple.foundationdb.record.query.plan.cascades.expressions
A parent interface for RelationalExpressions that have relational children (as opposed to non-relation children, such as QueryComponents).
RelationalExpressionWithChildren.ChildrenAsSet - Interface in com.apple.foundationdb.record.query.plan.cascades.expressions
Tag interface to signal that the children this expression owns, that is the owned Quantifiers, are to be treated as an unordered set.
RelationalExpressionWithPredicates - Interface in com.apple.foundationdb.record.query.plan.cascades.expressions
A (relational) expression that has a predicate on it.
Relationship(ParameterRelationshipGraph.RelationshipType, String, String) - Constructor for class com.apple.foundationdb.record.query.ParameterRelationshipGraph.Relationship
 
RelativeProbabilityPlanSelector - Class in com.apple.foundationdb.record.query.plan.plans
A utility class to implement an algorithm to make a random selection based off of relative probabilities.
RelativeProbabilityPlanSelector(List<Integer>) - Constructor for class com.apple.foundationdb.record.query.plan.plans.RelativeProbabilityPlanSelector
Create a new probability selector with the given probabilities list.
release() - Method in class com.apple.foundationdb.record.locking.AsyncLock
Releases the lock.
RelOpValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value that returns the comparison result between its children.
RelOpValue(PlanSerializationContext, PRelOpValue) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue
 
RelOpValue(String, Comparisons.Type, Iterable<? extends Value>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue
Creates a new instance of RelOpValue.
RelOpValue.BinaryRelOpValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
Binary rel ops.
RelOpValue.BinaryRelOpValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
RelOpValue.EqualsFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The equals function.
RelOpValue.GteFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The gte function.
RelOpValue.GtFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The gt function.
RelOpValue.IsNullFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The isNull function.
RelOpValue.LteFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The lte function.
RelOpValue.LtFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The lt function.
RelOpValue.NotEqualsFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The notequals function.
RelOpValue.NotNullFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The notNull function.
RelOpValue.UnaryRelOpValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
Unary rel ops.
RelOpValue.UnaryRelOpValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
REMOTE_FETCH - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Total number of remote fetch (get) operations.
remoteFetchFallbackFrom(Index, IndexScanType, TupleRange, byte[], IndexOrphanBehavior, ScanProperties, RecordCursorResult<FDBIndexedRecord<M>>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
 
remove(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
remove(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentityMap
 
remove(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
REMOVE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
REMOVE_FORMER_INDEX - Enum constant in enum 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.
REMOVE_LOGICAL_EXPRESSIONS - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
REMOVE_PLANS - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
removeAllPlaceholders() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
removeAllPredicates() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
removeAllQuantifiers() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
removeAllResultColumns() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Builder
 
removeCommitChecks(Function<FDBRecordContext.CommitCheckAsync, Boolean>, Predicate<Throwable>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Remove commit checks based on a predicate, once the commit check completes.
removeEdge(E) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
removeEligibleElements(Set<T>) - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet.EligibleSet
 
removeExpression(Reference, RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Traversal
 
removeFormerIndex(FormerIndex) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
removeFromSession(String, Class<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Put an object into the session of the FDBRecordContext.
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
 
removeLast(K) - Method in class com.apple.foundationdb.record.sorting.MemoryDam
 
removeLast(K) - Method in class com.apple.foundationdb.record.sorting.MemoryScratchpad
 
removeLast(K) - Method in class com.apple.foundationdb.record.sorting.MemorySorter
 
removeLogicalExpressions() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
removeNode(N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
removePlansIfPossible() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
removePostCommit(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Remove a previously installed post-commit hook.
RemoveProjectionRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that removes a LogicalProjectionExpression and if appropriate a RecordQueryFetchFromPartialRecordPlan if all fields needed by the projection are already available prior to the fetch.
RemoveProjectionRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.RemoveProjectionRule
 
removesDuplicates() - Method in class com.apple.foundationdb.record.query.RecordQuery
 
RemoveSortRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that implements a sort expression by removing this expression if appropriate.
RemoveSortRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.RemoveSortRule
 
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 a SET_VERSIONSTAMPED_KEY mutation that would have been run at commit time.
removeVersionMutationRange(Range) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Remove a range of version mutations that are currently in the local cache.
renameRecordType(RecordMetaDataProto.MetaData.Builder, String, String) - Static method in class com.apple.foundationdb.record.provider.foundationdb.MetaDataProtoEditor
Rename a record type.
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.AliasDefinitionToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.AliasReferenceToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.BracketLikeToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.CommaLikeToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.CurrentAliasDefinitionToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.IdentifierToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.KeywordToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.LineBreakOrSpaceToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.NestedToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.OptionalWhitespaceToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.PopToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.PushToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
Render all tokens on the given explain level, using the given formatter, and a given budget of number of characters.
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.ToStringToken
 
render(int, ExplainFormatter, int) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.WhitespaceToken
 
render(ExplainFormatter) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens
 
RENDER_SINGLE_GROUPS - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
Indicates if Reference instances that contain exactly one variation are rendered.
renderCluster(GraphExporter.ExporterContext, String, GraphExporter.Cluster<N, E>, Map<String, Attribute>, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.DotExporter
Render a sub cluster.
renderClusters(GraphExporter.ExporterContext, Set<N>, Collection<GraphExporter.Cluster<N, E>>, String, String) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.DotExporter
 
renderClusters(GraphExporter.ExporterContext, Collection<GraphExporter.Cluster<N, E>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.DotExporter
 
renderClusters(GraphExporter.ExporterContext, Collection<GraphExporter.Cluster<N, E>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GmlExporter
 
renderClusters(GraphExporter.ExporterContext, Collection<GraphExporter.Cluster<N, E>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.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.cascades.explain.DotExporter
 
renderEdge(GraphExporter.ExporterContext, boolean, N, N, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GmlExporter
 
renderEdge(GraphExporter.ExporterContext, boolean, N, N, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter
Render an edge.
renderEdges(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter
Render all edges in a given network.
renderFooter(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.DotExporter
Compute the footer.
renderFooter(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GmlExporter
 
renderFooter(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter
Render the footer.
renderGraphAttributes(GraphExporter.ExporterContext, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.DotExporter
 
renderGraphAttributes(GraphExporter.ExporterContext, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GmlExporter
 
renderGraphAttributes(GraphExporter.ExporterContext, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter
Render the global graph attributes.
renderHeader(GraphExporter.ExporterContext, ImmutableNetwork<N, E>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.DotExporter
 
renderHeader(GraphExporter.ExporterContext, ImmutableNetwork<N, E>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GmlExporter
 
renderHeader(GraphExporter.ExporterContext, ImmutableNetwork<N, E>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter
Render the header.
renderIfEnabled(int, String, BiFunction<T, CharSequence, CharSequence>) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
renderNode(GraphExporter.ExporterContext, N, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.DotExporter
 
renderNode(GraphExporter.ExporterContext, N, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GmlExporter
 
renderNode(GraphExporter.ExporterContext, N, Map<String, Attribute>) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter
Render a node.
renderNodes(GraphExporter.ExporterContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.GraphExporter
Render all nodes in the given network.
renderSingleGroups() - Method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
 
REPAIR_RECORD_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
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.
REPARTITION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl.LastStep
 
repartitionCapped() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Repartitioning capped due to hitting maximum limit.
replace(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Legacy method that calls Reference.pruneWith(RelationalExpression) while being synchronized on this.
replace(Equivalence.Wrapper<K>, Equivalence.Wrapper<V>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
replace(Equivalence.Wrapper<K>, Equivalence.Wrapper<V>, Equivalence.Wrapper<V>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
replace(UnaryOperator<T>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Replaces elements in the tree with new elements returned by the user-defined operator.
REPLACE_RECORD_VALUE_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The previous size of values for record key-value pairs that are updated.
replaceAll(BiFunction<? super Equivalence.Wrapper<K>, ? super Equivalence.Wrapper<V>, ? extends Equivalence.Wrapper<V>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentityMap
 
REPLACED_BY_OPTION_PREFIX - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
Option indicating one (or more) indexes that replace this index.
replaceLeavesMaybe(UnaryOperator<T>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Method that maps the tree-like rooted at this to another tree-like of the same type.
replaceLeavesMaybe(UnaryOperator<T>, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Method that maps the tree-like rooted at this to another tree-like of the same type.
replaceReferenceWithField(FieldValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
replaceReferenceWithField(FieldValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
replaceReferenceWithField(FieldValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
replaceReferenceWithField(FieldValue) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.LeafValue
 
replaceReferenceWithField(FieldValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
replaceReferenceWithField(FieldValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
replaceReferenceWithField(FieldValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
replaceReferenceWithField(FieldValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
replaceReferenceWithField(FieldValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
replaceReferenceWithField(FieldValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
replaceValuesMaybe(Function<Value, Optional<Value>>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
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 - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
REQUESTED_ORDERING - Static variable in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrderingConstraint
 
REQUESTED_START - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RequestedOrdering - Class in com.apple.foundationdb.record.query.plan.cascades
This class captures a requested ordering.
RequestedOrdering.Distinctness - Enum in com.apple.foundationdb.record.query.plan.cascades
Whether the ordered records are distinct.
RequestedOrderingConstraint - Class in com.apple.foundationdb.record.query.plan.cascades
A constraint requesting a set of sort orderings.
RequestedOrderingConstraint() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.RequestedOrderingConstraint
 
RequestedOrderingPart(Value, OrderingPart.RequestedSortOrder) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedOrderingPart
 
RequestedOrderingValueSimplificationRuleSet - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A set of rules for simplifying Value trees used to expression ordering constraints.
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 new ByteScanLimiter with this limiter's original limit, ignoring any calls to ByteScanLimiter.hasBytesRemaining() and ByteScanLimiter.registerScannedBytes(long).
reset() - Method in class com.apple.foundationdb.record.ExecuteState
Create a new ExecuteState that 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 new RecordScanLimiter with this limiter's original limit, ignoring any calls to RecordScanLimiter.tryRecordScan().
RESET - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
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, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Map the String name to 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 String name to 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 String name to 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 String name to a Long within the scope of the path that this object was constructed with.
resolve(KeySpaceTreeResolver.Resolved, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver
 
resolve(KeySpaceTreeResolver, KeySpaceTreeResolver.Resolved) - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
 
resolve(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Map the String name to a Long within the scope of the path that this object was constructed with.
resolve(String, int) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FunctionCatalog
 
resolve(String, ResolverCreateHooks) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Map the String name to 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
 
resolveAndEncapsulateFunction(String, List<? extends Value>) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
 
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
 
resolveComparisonDirection(Iterable<OrderingPart.ProvidedOrderingPart>) - Static method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan
Helper to resolve a comparison direction.
resolveCorrelationAlias(RelationalExpression, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers.AliasResolver
 
resolveCorrelationAlias(Reference, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers.AliasResolver
 
Resolved(KeySpaceTreeResolver.Resolved) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.Resolved
 
ResolvedAccessor(String, int, Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
ResolvedIndexKeyspace(KeySpaceTreeResolver.Resolved, Index) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedIndexKeyspace
 
ResolvedKeyField(KeySpaceTreeResolver.Resolved, String, Object, Object) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedKeyField
 
ResolvedKeySpacePath - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
A KeySpacePath that 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(KeySpaceTreeResolver.Resolved, ResolvedKeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedPath
 
ResolvedPrefixRoot(KeySpaceTreeResolver.Resolved, Object) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedPrefixRoot
 
ResolvedRecordStoreKeyspace(KeySpaceTreeResolver.Resolved, FDBRecordStoreKeyspace, RecordMetaData, Object) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRecordStoreKeyspace
 
ResolvedRecordTypeKeyspace(KeySpaceTreeResolver.Resolved, RecordType) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRecordTypeKeyspace
 
ResolvedRoot(KeySpace) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRoot
 
ResolvedRoot(KeySpaceTreeResolver.Resolved, KeySpaceDirectory) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedRoot
 
resolveFetchIndexRecords(RecordQueryPlanner.PlanContext) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
Method to statically resolve the method of how records are fetched given an index key.
resolveFetchIndexRecordsFromPlan(RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.visitor.RecordQueryPlannerSubstitutionVisitor
 
resolveFieldPath(Type, List<FieldValue.Accessor>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
resolveFromKey(FDBRecordContext, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpace
Synchronous/blocking version of resolveFromKeyAsync.
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 a ResolvedKeySpacePath representing the leaf-most directory in the path.
resolveIndexField(KeySpaceTreeResolver.Resolved, Object, Index, KeyExpression, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver
 
resolveKeyField(KeySpaceTreeResolver.Resolved, Object, KeyExpression) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver
 
resolveKeySpacePath(KeySpace, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver
 
resolveNonDirectory(KeySpaceTreeResolver.Resolved, Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver
Resolve something other than a KeySpaceDirectory node.
resolveParameterType(int) - Method in class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
 
resolveParameterTypes(int) - Method in class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
 
resolvePathAndRemainder(KeySpaceTreeResolver.Resolved, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver
 
resolvePrimaryKeyField(KeySpaceTreeResolver.Resolved, Object, KeyExpression, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver
 
RESOLVER - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RESOLVER_KEY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RESOLVER_METADATA - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RESOLVER_PATH - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RESOLVER_REVERSE_VALUE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RESOLVER_STATE_READ - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.DetailEvents
The amount of time spent reading the lock state of a LocatableResolver.
RESOLVER_VALUE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
ResolverCreateHooks - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
Set of hooks to be run only when creating a mapping in a LocatableResolver.
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 the LocatableResolver.
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 the LocatableResolver.
ResolverKeyValue - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
Encapsulates both the key and its resolved value from a LocatableResolver.
ResolverKeyValue(String, ResolverResult) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverKeyValue
 
ResolverMappingDigest - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
Computes a message digest for all of the string to integer mappings in the provided LocatableResolver.
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 one LocatableResolver to 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 with LocatableResolver.
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
 
ResolverValidator - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
Validator that ensures that the resolver mappings are consistent with the reverse directory mappings.
ResolverValidator() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator
 
ResolverValidator.ValidatedEntry - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
Represents a bad/incorrect entry in the resolvers mapping.
ResolverValidator.ValidationResult - Enum in com.apple.foundationdb.record.provider.foundationdb.keyspace
The type of bad entry discovered when validating a LocatableResolver's mappings.
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 not null).
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 not null).
resolveUniquenessViolation(Index, Tuple, Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
resolveVisibleChildren(KeySpaceTreeResolver) - 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 String name to a ResolverResult within 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 String name to a ResolverResult within 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 String name to a ResolverResult within the scope of the path that this object was constructed with.
RestartException - Exception in com.apple.foundationdb.record.query.plan.cascades.debug
Tag-exception that is specifically thrown by implementations of Debugger to signal the planner to restart planning.
RestartException() - Constructor for exception com.apple.foundationdb.record.query.plan.cascades.debug.RestartException
 
Result<V,E extends Throwable> - Class in com.apple.foundationdb.record.util
A struct representing the result of an operation, containing either the return value or an error.
Result(ListMultimap<KeyExpression, AvailableFields.FieldData>, int) - Constructor for class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor.Result
 
RESULT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RESULT_COUNT - Enum constant in enum 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 this LocatableResolver, indicating that it should not be used for any future resolve operations.
RETRY_DELAY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
RETURN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.IndexOrphanBehavior
Return the index entry but with no record associated with it.
RETURN_LIMIT_REACHED - Enum constant in enum com.apple.foundationdb.record.RecordCursor.NoNextReason
The limit on the number record to return was reached.
returnCipher(Cipher) - Static method in class com.apple.foundationdb.record.provider.common.CipherPool
 
REUSED - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
 
reusedExp(RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
reusedExpWithReferences(RelationalExpression, List<Reference>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
reverse - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
reverse - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
reverse - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
REVERSE_DIR_PERSISTENT_CACHE_HIT_COUNT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of reverse directory cache hits.
REVERSE_DIR_PERSISTENT_CACHE_MISS_COUNT - Enum constant in enum 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_ENTRY_MISMATCH - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator.ValidationResult
Indicates that an entry in the mapping has a corresponding reverse entry, but that reverse entry belong to a different key than the one that referenced it.
REVERSE_ENTRY_MISSING - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator.ValidationResult
Indicates that an entry in the mapping has no corresponding reverse entry.
REVERSE_SCAN - Static variable in class com.apple.foundationdb.record.ScanProperties
 
reverseLookup(FDBRecordContext, 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.
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.
reverseLookupInTransaction(FDBRecordContext, 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.cascades.explain.ExplainPlannerGraphRewritable
Method to rewrite the planner graph.
rewriteInternalPlannerGraph(List<? extends PlannerGraph>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.explain.InternalPlannerGraphRewritable
Method to rewrite the planner graph.
rewriteInternalPlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
rewriteInternalPlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
rewriteInternalPlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
rewriteInternalPlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
rewriteInternalPlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
rewriteInternalPlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
rewriteInternalPlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphRewritable
Method to rewrite the planner graph.
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
Create a planner graph for better visualization.
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
Create a planner graph for better visualization.
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
Create a planner graph for better visualization of a query index plan.
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
Create a planner graph for better visualization.
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
Create a planner graph for better visualization.
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
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.RecordQueryDefaultOnEmptyPlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
Rewrite the planner graph for better visualization.
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
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.RecordQueryFirstOrDefaultPlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
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.RecordQueryInsertPlan
Rewrite the planner graph for better visualization.
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.RecordQueryInUnionPlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
Rewrite the planner graph for better visualization of this plan.
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
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.RecordQueryPredicatesFilterPlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
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.RecordQuerySelectorPlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
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.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 class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
Rewrite the planner graph for better visualization.
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
Rewrite the planner graph for better visualization.
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
rewritePlannerGraph(List<? extends PlannerGraph>) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
rollUp(BindingMatcher<? extends Iterable<? extends PlanPartition>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ReferenceMatchers
 
rollUpTo(BindingMatcher<? extends Iterable<? extends PlanPartition>>, PlanProperty<?>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ReferenceMatchers
 
rollUpTo(BindingMatcher<? extends Iterable<? extends PlanPartition>>, Set<PlanProperty<?>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ReferenceMatchers
 
rollUpTo(Collection<PlanPartition>, PlanProperty<?>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.PlanPartition
 
rollUpTo(Collection<PlanPartition>, Set<PlanProperty<?>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.PlanPartition
 
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
 
RTREE_MAX_M - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
Maximum number of slots in a node of an R-tree.
RTREE_MIN_M - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
Minimum number of slots in a node of an R-tree (except for the root node for which that minimum number may be as low as 0.
RTREE_SPLIT_S - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
The R-tree magic split number.
RTREE_STORAGE - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
The R-tree storage format.
RTREE_STORE_HILBERT_VALUES - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
Option to indicate whether the R-tree stores Hilbert values of objects together with the point or not.
RTREE_USE_NODE_SLOT_INDEX - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
Option to indicate whether the R-tree manages and uses a secondary index to quickly find the update path.
RULE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RULE_MATCHES_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
RULECALL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
 
RULES - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ExtractFromIndexKeyValueRuleSet
 
run() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext.AfterCommit
 
run() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
run(boolean, Function<? super FDBRecordContext, ? extends T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.runners.TransactionalRunner
Run a function against a context synchronously.
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 this FDBDatabase with 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 this FDBDatabase with 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 this FDBDatabase with 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
 
run(Function<? super Transaction, T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
RUN_LOOP_PROFILING - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
runAsync(boolean, Function<? super FDBRecordContext, CompletableFuture<? extends T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.runners.TransactionalRunner
Run some code with a given context, and commit the context.
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 this FDBDatabase with 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 this FDBDatabase with retry logic.
runAsync(FDBStoreTimer, Map<String, String>, Function<? super FDBRecordContext, CompletableFuture<? extends T>>, List<Object>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
Runs a transactional function asynchronously against this FDBDatabase with 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 this FDBDatabase with 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, Result<? 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, Result<? 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, Result<? 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, Result<? extends T, ? extends Throwable>>, List<Object>) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
 
runAsync(Function<? super FDBRecordContext, CompletableFuture<? extends T>>, List<Object>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
Runs a transactional function asynchronously against this FDBDatabase with retry logic.
runAsync(Function<? super FDBRecordContext, CompletableFuture<? extends T>>, List<Object>) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
Runs a transactional function asynchronously with retry logic.
runAsync(Function<? super Transaction, ? extends CompletableFuture<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
runAsync(Function<? super Transaction, ? extends CompletableFuture<T>>) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
runCommitChecks() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
Run any FDBRecordContext.CommitCheckAsyncs that are still outstanding.
RunnerClosed() - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner.RunnerClosed
 

S

sameInstanceAsBound(BindingMatcher<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.InstanceMatcher
 
sanityCheck(Runnable) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
Invoke the Consumer on the currently set debugger.
sargable(Value, RangeConstraints) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
satisfies(AccessHints) - Method in class com.apple.foundationdb.record.query.plan.cascades.AccessHints
 
satisfies(RequestedOrdering) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
satisfies(Predicate<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PrimitiveMatchers
 
satisfiesGroupingValues(Set<Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
satisfyingPermutations(PartiallyOrderedSet<T>, List<P>, Function<T, P>, Function<List<T>, Integer>) - Static method in class com.apple.foundationdb.record.query.combinatorics.TopologicalSort
 
satisfyingPermutations(PartiallyOrderedSet<T>, List<T>, Function<List<T>, Integer>) - Static method in class com.apple.foundationdb.record.query.combinatorics.TopologicalSort
 
save() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer.UpdateState
 
SAVE_INDEX_ENTRY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent saving an entry to a secondary index.
SAVE_INDEX_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of index key-value pairs saved.
SAVE_INDEX_KEY_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of keys for index key-value pairs saved.
SAVE_INDEX_VALUE_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of values for index key-value pairs saved.
SAVE_META_DATA - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken persisting meta-data to a FDBMetaDataStore.
SAVE_RECORD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken saving records.
SAVE_RECORD_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of record key-value pairs saved.
SAVE_RECORD_KEY_BYTES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The size of keys for record key-value pairs saved.
SAVE_RECORD_VALUE_BYTES - Enum constant in enum 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.
saveIndexingTypeStamp(Index, IndexBuildProto.IndexBuildIndexingStamp) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
Update the indexing type stamp for the given index.
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(FDBRecordStoreBase<M>, EvaluationContext, M, boolean) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
saveRecordAsync(FDBRecordStoreBase<M>, EvaluationContext, M, boolean) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan
 
saveRecordAsync(FDBRecordStoreBase<M>, EvaluationContext, M, boolean) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
 
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
saveRecordAsync(M, FDBRecordStoreBase.RecordExistenceCheck) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
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
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.
saveResolverState(FDBRecordContext, ResolverStateProto.State) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Update the resolver's state in the context of a single transaction.
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
 
saveTypedRecord(RecordSerializer<M>, M, FDBRecordStoreBase.RecordExistenceCheck, FDBRecordVersion, FDBRecordStoreBase.VersionstampSaveBehavior, boolean) - 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.
scalarOf(Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
 
ScalarTranslationVisitor - Class in com.apple.foundationdb.record.query.plan.cascades
Visitor that translates a KeyExpression into a Value, keeping a state of the currently processed input type while it is processing the KeyExpression.
ScalarTranslationVisitor(KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
ScalarTranslationVisitor.ScalarVisitorState - Class in com.apple.foundationdb.record.query.plan.cascades
State class.
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.MultidimensionalIndexMaintainer
 
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.PermutedMinMaxIndexMaintainer
 
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(FDBRecordContext, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.LocatableResolver
Scan the mapping space used by the resolver, returning all of the key/value mappings that are stored there.
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(IndexScanBounds, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.MultidimensionalIndexMaintainer
 
scan(IndexScanBounds, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
Scan entries in the index.
scan(IndexScanBounds, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
 
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_AND_FETCH - Enum constant in enum com.apple.foundationdb.record.IndexFetchMethod
 
SCAN_INDEX_KEYS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken scanning the entries of an index.
SCAN_LIMIT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
SCAN_LIMIT_REACHED - Enum constant in enum com.apple.foundationdb.record.RecordCursor.NoNextReason
The limit on the number of records to scan was reached.
SCAN_MILLIS - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
SCAN_PROPERTIES - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
SCAN_RECORDS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken scanning records directly without any index.
SCAN_REMOTE_FETCH_ENTRY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time taken performing an index prefetch operation.
SCAN_TYPE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
scanComparisons() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
scanComparisons(BindingMatcher<ScanComparisons>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
ScanComparisons - Class in com.apple.foundationdb.record.query.plan
A set of Comparisons.Comparison for 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 for ScanComparisons.
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 interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Scan the entries in an index.
scanIndex(Index, IndexScanBounds, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
scanIndex(Index, IndexScanBounds, byte[], ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Scan the entries in an index.
scanIndex(Index, IndexScanBounds, byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
scanIndexRecords(Index, IndexFetchMethod, IndexScanBounds, byte[], IndexOrphanBehavior, ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Scan the records pointed to by an index.
scanIndexRecords(Index, IndexFetchMethod, IndexScanBounds, int, byte[], IndexOrphanBehavior, ScanProperties) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Scan the records pointed to by an index.
scanIndexRecords(Index, 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) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Scan the records pointed to by an index.
scanIndexRecords(String, IndexFetchMethod, IndexScanBounds, 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) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Scan the records pointed to by an index.
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, 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.
scanIndexRemoteFetch(Index, IndexScanBounds, byte[], ScanProperties, IndexOrphanBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Scan the records pointed to by an index, using a single scan-and-dereference FDB operation.
scanIndexRemoteFetch(Index, IndexScanBounds, int, byte[], ScanProperties, IndexOrphanBehavior) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
scanIndexRemoteFetch(Index, IndexScanBounds, int, byte[], ScanProperties, IndexOrphanBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Scan the records pointed to by an index, using a single scan-and-dereference FDB operation.
scanIndexRemoteFetch(Index, IndexScanBounds, int, byte[], ScanProperties, IndexOrphanBehavior) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore
 
scanIndexRemoteFetch(String, IndexScanBounds, byte[], ScanProperties, IndexOrphanBehavior) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Scan the records pointed to by an index, using a single scan-and-dereference FDB operation.
scanIndexRemoteFetchInternal(Index, IndexScanBounds, int, byte[], RecordSerializer<M>, ScanProperties, IndexOrphanBehavior) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
scanIndexRemoteFetchRecordsEqual(String, Object...) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Scan the records pointed to by an index equal to indexed values using the Index Prefetch method.
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 - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
ScanNonReadableIndexException - Exception in com.apple.foundationdb.record.provider.foundationdb
An exception that can be thrown by FDBRecordStores if they are scanning non-readable indexes.
scanParameters - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
scanPlan() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
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.
scanPropertiesWithLimits(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
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
 
scanRemoteFetch(IndexScanBounds, byte[], ScanProperties, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainer
 
scanRemoteFetch(IndexScanBounds, byte[], ScanProperties, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.VersionIndexMaintainer
 
scanRemoteFetch(IndexScanBounds, byte[], ScanProperties, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
Use the getMappedRange scan method to return a range scan with the dereferenced record for each index entry.
scanRemoteFetchByValue(IndexScanBounds, byte[], ScanProperties, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
 
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.
ScanWithFetchMatchCandidate - Interface in com.apple.foundationdb.record.query.plan.cascades
Interface to represent a candidate that replaces with an index scan.
ScanWithFetchMatchCandidate.IndexEntryToLogicalRecord - Class in com.apple.foundationdb.record.query.plan.cascades
Helper structure that allows us to precompute the mapping from index entry to the logical (partial record).
SCOPED_DIRECTORY_LAYER_CREATE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent adding a new entry to a ScopedDirectoryLayer.
SCOPED_DIRECTORY_LAYER_READ - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent reading an entry from a ScopedDirectoryLayer.
ScopedDirectoryLayer - Class in com.apple.foundationdb.record.provider.foundationdb.keyspace
An implementation of LocatableResolver that 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
ScopedInterningLayer - Class in com.apple.foundationdb.record.provider.foundationdb.layers.interning
An implementation of LocatableResolver that is backed by the StringInterningLayer.
ScopedInterningLayer(FDBDatabase, ResolvedKeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
Creates a resolver rooted at the provided KeySpacePath.
ScopedInterningLayer(FDBRecordContext, KeySpacePath) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.layers.interning.ScopedInterningLayer
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.cascades.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
 
ScoredInfo(T, List<QueryComponent>, List<QueryComponent>, Set<Comparisons.Comparison>, int, boolean, boolean, boolean, Set<RankComparisons.RankComparison>) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
ScoredMatch(int, ComparisonRanges) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredMatch
 
ScoredMatch(int, ComparisonRanges, List<QueryComponent>) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredMatch
 
ScoredMatch(int, ComparisonRanges, List<QueryComponent>, boolean, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredMatch
 
ScoredMatch(ComparisonRanges, List<QueryComponent>, List<QueryComponent>, Set<Comparisons.Comparison>, int, boolean, boolean, boolean, Set<RankComparisons.RankComparison>) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredMatch
 
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, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
 
ScoredPlan(RecordQueryPlan, List<QueryComponent>, List<QueryComponent>, Set<Comparisons.Comparison>, int, boolean, boolean, 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, BindingFunction, 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
 
ScrubbingPolicy(int, boolean, long, boolean, boolean) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy
 
scrubDanglingIndexEntries() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber
Scrub the index, find and repair dangling entries.
scrubMissingIndexEntries() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber
Scrub the index, find and repair missing entries.
seal() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
seal(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
Method to seal a graph expansion in an instance of GraphExpansion.Sealed.
Sealed() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion.Sealed
 
SECOND_PREFIX - Enum constant in enum 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 - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
SelectDataAccessRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that utilizes index matching information compiled by CascadesPlanner to create one or more expressions for data access specifically for a SelectExpression.
SelectDataAccessRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.SelectDataAccessRule
 
selectExpression() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
selectExpression(BindingMatcher<? extends QueryPredicate>, BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
selectExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
selectExpression(CollectionMatcher<? extends QueryPredicate>, CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
selectExpression(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
SelectExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A select expression.
SelectExpression(Value, List<? extends Quantifier>, List<? extends QueryPredicate>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
SELECTOR_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
selectPlan(List<RecordQueryPlan>) - Method in interface com.apple.foundationdb.record.query.plan.plans.PlanSelector
 
selectPlan(List<RecordQueryPlan>) - Method in class com.apple.foundationdb.record.query.plan.plans.RelativeProbabilityPlanSelector
 
self() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexPrefetchRangeKeyValueCursor.Builder
 
self() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
 
self() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
Self pattern is used to return the appropriate THIS for the builder set* methods.
selfOrDescendantPlans(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
selfOrDescendantPlans(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
semanticEquals(Correlated<S>, Correlated<S>, AliasMap) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.Correlated
Static helper to shorten boilerplate for callers that have to deal with nullable objects.
semanticEquals(Object) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Overloaded method to call RelationalExpression.semanticEquals(java.lang.Object) with an empty alias map.
semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
semanticEquals(Object, AliasMap) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
semanticEquals(Object, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Correlated
Determine equality with respect to an equivalence map between CorrelationIdentifiers based on semantic equality: equality of the plan fragments implementing under the given correlation bindings.
semanticEquals(Object, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Method to establish whether this relational expression is equal to another object under the bindings given by the AliasMap passed in.
semanticEquals(Object, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.TransformationTrieNode
 
semanticEquals(Object, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
semanticEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
semanticEquals(Object, ValueEquivalence) - Method in interface com.apple.foundationdb.record.query.plan.cascades.UsesValueEquivalence
Method to determine the semantic equality under a given ValueEquivalence.
semanticEquals(Object, ValueEquivalence) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Overriding method of UsesValueEquivalence.semanticEquals(Object, ValueEquivalence) that attempts to assert equivalence of this and other using the ValueEquivalence that was passed in.
semanticEquals(Set<T>, Set<T>) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence
 
semanticEqualsForResults(RelationalExpression, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
semanticEqualsTyped(Comparisons.Comparison, ValueEquivalence) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
semanticEqualsTyped(Comparisons.Comparison, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
semanticEqualsTyped(Comparisons.Comparison, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
semanticEqualsTyped(Comparisons.Comparison, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
semanticEqualsTyped(QueryPredicate, ValueEquivalence) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
semanticEqualsTyped(RangeConstraints, ValueEquivalence) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
semanticEqualsTyped(Value, ValueEquivalence) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
semanticEqualsTyped(T, ValueEquivalence) - Method in interface com.apple.foundationdb.record.query.plan.cascades.UsesValueEquivalence
Method that is overridden by implementors.
semanticEqualsWithoutChildren(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach
 
semanticEqualsWithoutChildren(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
SemanticException - Exception in com.apple.foundationdb.record.query.plan.cascades
Semantic exceptions that could occur e.g.
SemanticException(SemanticException.ErrorCode, String, Throwable) - Constructor for exception com.apple.foundationdb.record.query.plan.cascades.SemanticException
 
SemanticException.ErrorCode - Enum in com.apple.foundationdb.record.query.plan.cascades
Semantic error codes.
semanticHashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
semanticHashCode() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
semanticHashCode() - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
semanticHashCode() - Method in interface com.apple.foundationdb.record.query.plan.cascades.Correlated
Return a semantic hash code for this object.
semanticHashCode() - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Compute the semantic hash code of this expression.
semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AbstractQueryPredicate
 
semanticHashCode() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach
 
semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractValue
 
semanticHashCode() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
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 - Enum constant in enum 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(FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.SortedRecordSerializer
 
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 - Enum constant in enum 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 standard Tuple encoding.
serializeKey(Tuple) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
serializeKey(K) - Method in interface com.apple.foundationdb.record.sorting.MemorySortAdapter
Convert key into a byte array.
serializer - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
serializeToBytes(Message) - Method in class com.apple.foundationdb.record.provider.common.DynamicMessageRecordSerializer
 
serializeValue(FDBQueriedRecord<M>) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
serializeValue(V) - Method in interface com.apple.foundationdb.record.sorting.MemorySortAdapter
Convert value into a byte array.
serialVersionUID - Static variable in exception com.apple.foundationdb.record.cursors.FallbackCursor.FallbackExecutionFailedException
 
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
 
ServiceLoaderProvider - Class in com.apple.foundationdb.record.util
A singleton that supports alternatives to ServiceLoader, for example if you want to use a dependency injection framework.
SESSION_ID - Enum constant in enum 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.KeyCheckingTransaction
 
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 - Enum constant in enum 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
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.
setAllowNonIndexSort(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set whether the planner is allowed to use an in-memory sort plan.
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.
setAllowRepair(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy.Builder
Set whether the scrubber, if it finds an error, will repair it.
setAllowUnblock(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
setAllowUnblock(boolean, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
If the index is partly built and blocked, allowed (or disallow) unblocking before indexing.
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.
setAPIVersion(APIVersion) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Set the API version for this database factory.
setAPIVersion(APIVersion) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
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, Duration>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
 
setAttemptFailedInJoinAsOr(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
 
setAttemptFailedInJoinAsUnionMaxSize(int) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
 
setAutoMergeDuringCommit(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Indicate to the index maintenance to automatically merge indexes during commit (if applicable).
setBinding(CorrelationIdentifier, Object) - Method in class com.apple.foundationdb.record.EvaluationContextBuilder
Bind an alias to a value.
setBinding(String, Object) - Method in class com.apple.foundationdb.record.EvaluationContextBuilder
Bind a name to a value.
setBlockingInAsyncDetection(BlockingInAsyncDetection) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Controls if calls to FDBDatabase#asyncToSync(FDBStoreTimer, FDBStoreTimer.Wait, CompletableFuture) or FDBRecordContext#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 to FDBDatabase#asyncToSync(FDBStoreTimer, FDBStoreTimer.Wait, CompletableFuture) or FDBRecordContext#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.
setComparisonRange(ComparisonRange) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.Builder
 
setComparisonRangeOptional(Optional<ComparisonRange>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.Builder
 
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(UnaryOperator<OnlineIndexOperationConfig>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
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.cascades.CascadesPlanner
 
setConfiguration(RecordQueryPlannerConfiguration) - Method in interface com.apple.foundationdb.record.query.plan.QueryPlanner
Set the RecordQueryPlannerConfiguration for this planner.
setConfiguration(RecordQueryPlannerConfiguration) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
 
setConstant(CorrelationIdentifier, Object) - Method in class com.apple.foundationdb.record.EvaluationContextBuilder
 
setConstraint(QueryPlanConstraint) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.Builder
 
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.KeyValueCursorBase.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 a FDBRecordContext is created, taking as input the Executor that is configured for the database, returning the Executor that will be used to execute all asynchronous completions produced from the FDBRecordContext.
setContinuation(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.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.OnlineIndexOperationBaseBuilder
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.
setDebugger(Debugger) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
Set the debugger.
setDefaultCursorStreamingMode(CursorStreamingMode) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
Set the default CursorStreamingMode for new ScanProperties.
setDefaultCursorStreamingMode(CursorStreamingMode) - Method in class com.apple.foundationdb.record.ExecuteProperties
Set the default CursorStreamingMode for new ScanProperties.
setDeferCrossProducts(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set whether the query planner should defer cross products during join enumeration.
setDeferFetchAfterInJoinAndInUnion(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
 
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
 
setDisabledTransformationRuleNames(Set<String>, PlannerRuleSet) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set a set of rules names that identify planner transformation rules that should be considered disabled for any planning effort.
setDisabledTransformationRules(Set<Class<? extends CascadesRule<?>>>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set a set of planner transformation rules that should be considered disabled for any planning effort.
setDisallowTypeRenames(boolean) - Method in class com.apple.foundationdb.record.metadata.MetaDataEvolutionValidator.Builder
Set whether the validator will disallow record types from being renamed.
setDryRun(boolean) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
setDryRun(boolean) - Method in class com.apple.foundationdb.record.ExecuteProperties
 
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.
setEntriesScanLimit(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy.Builder
Set records/index entries scan limit.
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.cascades.ConstraintsMap
Method to immediately indicate the group has been explored.
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.
setForbidRecordScan(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
If set to true, throw an exception when the requested indexing method cannot be used.
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.OnlineIndexOperationBaseBuilder
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.KeyValueCursorBase.Builder
 
setHigh(Tuple, EndpointType) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
setHookForAsyncToSync(Consumer<StoreTimer.Wait>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
 
setIfDisabled(OnlineIndexer.IndexingPolicy.DesiredAction) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
Set the desired action if the index is disabled.
setIfMismatchPrevious(OnlineIndexer.IndexingPolicy.DesiredAction) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
Set the desired action if the index is in a write-only mode but the previous indexing method mismatches the requested one.
setIfReadable(OnlineIndexer.IndexingPolicy.DesiredAction) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
Set the desired action if the index is readable.
setIfWriteOnly(OnlineIndexer.IndexingPolicy.DesiredAction) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
Set the desired action if the index is in a write-only mode (i.e.
setIncreaseLimitAfter(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
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.OnlineIndexOperationConfig.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(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.Builder
Set the index to be scrubbed.
setIndex(String) - 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.OnlineIndexScrubber.Builder
Set the index to be scrubbed.
setIndexFetchMethod(IndexFetchMethod) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set whether the planner should use FDB remote fetch operations for the index scan plans.
setIndexingPolicy(OnlineIndexer.IndexingPolicy) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
setIndexingPolicy(OnlineIndexer.IndexingPolicy.Builder) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
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 the index filter to 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.OnlineIndexOperationBaseBuilder
Set the IndexMaintenanceFilter to 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 class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
 
setIndexScanPreference(QueryPlanner.IndexScanPreference) - Method in interface com.apple.foundationdb.record.query.plan.QueryPlanner
Set whether RecordQueryIndexPlan is preferred over RecordQueryScanPlan even when it does not satisfy any additional conditions.
setIndexScanPreference(QueryPlanner.IndexScanPreference) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner
Set whether RecordQueryIndexPlan is preferred over RecordQueryScanPlan even when it does not satisfy any additional conditions.
setIndexScanPreference(QueryPlanner.IndexScanPreference) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
 
setIndexStatePrecondition(OnlineIndexer.IndexStatePrecondition) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
Deprecated.
use OnlineIndexer.IndexingPolicy.Builder instead. Example:

setIndexingPolicy(OnlineIndexer.IndexingPolicy.newBuilder() .setIfDisabled(OnlineIndexer.IndexingPolicy.DesiredAction.CONTINUE) .setIfWriteOnly(OnlineIndexer.IndexingPolicy.DesiredAction.CONTINUE) .setIfMismatchPrevious(OnlineIndexer.IndexingPolicy.DesiredAction.REBUILD) .setIfReadable(OnlineIndexer.IndexingPolicy.DesiredAction.ERROR));

For backward compatibility, calling this function in any order will override the OnlineIndexer.IndexingPolicy.Builder methods: setIfDisabled, setIfWriteOnly, setIfMismatchPrevious, setIfReadable
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.OnlineIndexOperationBaseBuilder
Set the initial delay between transaction retry attempts.
setInitialDelayMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
 
setInitialLimit(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Set the initial number of records to process in one transaction.
setInitialLimit(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Set the initial number of records to process in one transaction.
setInitialMergesCountLimit(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
Set the initial merges count limit for OnlineIndexer.mergeIndex() and the indexing process.
setIsolationLevel(IsolationLevel) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
setKeyChecker(KeyChecker) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Set the key checker to hook operations' keys.
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 the KeySpacePath location of the FDBRecordStore.
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.
setLastStep(IndexDeferredMaintenanceControl.LastStep) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
During the deferred operation, each step should record its action.
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.OnlineIndexOperationBaseBuilder
Set the lease length in milliseconds if the synchronized session is used.
setLeaseLengthMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Set the lease length in milliseconds if the synchronized session is used.
setLimit(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
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 in other, using the limit specified by other except where it is unlimited, in which case the limit from this ExecuteProperties is used instead.
setListener(TransactionListener) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Installs a listener to be notified of transaction events, such as creation, commit, and close.
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.
setLocalityProvider(FDBLocalityProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
setLogTransaction(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Set whether transaction is logged to FDB client logs.
setLogWarningsLimit(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy.Builder
Set a rigid limit on the max number of warnings to log..
setLow(byte[], EndpointType) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
setLow(Tuple, EndpointType) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.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
 
setMatchedOrderingParts(List<OrderingPart.MatchedOrderingPart>) - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedBuilder
 
SetMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A multi matcher that binds a sub collection of the collection it is being matched by pairing up the items in the collection (in iteration order) with a list of downstream matchers.
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.OnlineIndexOperationBaseBuilder
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.OnlineIndexOperationBaseBuilder
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.OnlineIndexOperationConfig.Builder
Set the maximum number of records to process in one transaction.
setMaxMatchMap(MaxMatchMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.AdjustedBuilder
 
setMaxMillisPerTransaction(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBReverseDirectoryCache
 
setMaxNumMatchesPerRuleCall(int) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
Set the maximum number of yields that are permitted per rule call within the Cascades planner.
setMaxNumMatchesPerRuleCall(int) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set the maximum number of matches that are permitted per rule call within the Cascades planner.
setMaxNumReplansForInToJoin(int) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set the maximum number of replanning-attempts during IN-to-JOIN transformations in the planner.
setMaxNumReplansForInUnion(int) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set the maximum number of replanning-attempts during IN-union transformations in the planner.
setMaxRetries(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Set the maximum number of times to retry a single range rebuild.
setMaxRetries(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.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.
setMaxTaskQueueSize(int) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
Set the size limit of the Cascades planner task queue.
setMaxTaskQueueSize(int) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set the size limit of the Cascades planner task queue.
setMaxTotalTaskCount(int) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner
Set a limit on the number of tasks that can be executed as part of the Cascades planner planning.
setMaxTotalTaskCount(int) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set a limit on the number of tasks that can be executed as part of the Cascades planner planning.
setMaxWriteLimitBytes(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
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.OnlineIndexOperationBaseBuilder
Set the logging context used during the online index operation.
setMergeRequiredIndexes(Index) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Indicate to the caller if a deferred merge operation is required.
setMergesFound(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
setMergesLimit(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
setMergesTried(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
setMetaData(RecordMetaDataProvider) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
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 the FDBMetaDataStore to 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.
setMutualIndexing() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
setMutualIndexing(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
If set, allow mutual (parallel) indexing.
setMutualIndexingBoundaries(List<Tuple>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
Same as OnlineIndexer.IndexingPolicy.Builder.setMutualIndexing(), but will use a pre-defined set of keys to split the records space to fragments.
setName(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
setNetworkExecutor(Executor) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
setNormalizeNestedFields(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
 
setNullOnEmpty(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach.ForEachBuilder
 
setOmitPrimaryKeyInOrderingKeyForInUnion(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
 
setOmitPrimaryKeyInUnionOrderingKey(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
 
SetOperationsOrdering(SetMultimap<Value, Ordering.Binding>, PartiallyOrderedSet<Value>, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Ordering.SetOperationsOrdering
 
setOptimizeForIndexFilters(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
 
setOptimizeForRequiredResults(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set whether the query planner should attempt to consider the set of required result fields while finding the best index for a record type access.
setOrToUnionMaxNumConjuncts(int) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set the maximum number of conjuncts whose combinations are enumerated when PredicateToLogicalUnionRule is applied.
setPackage(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository.Builder
 
setParameterAlias(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.Builder
 
setParameterAliasOptional(Optional<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.Builder
 
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 the object to 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
 
setPlanOtherAttemptWholeFilter(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set whether the planner attempts to plan a complex filter using non-VALUE indexes before splitting it up.
setPlanSerializationRegistry(PlanSerializationRegistry) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
 
setPredicateCompensation(PredicateMultiMap.PredicateCompensation) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.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 the FDBTransactionPriority to use when creating a transaction.
setPriority(FDBTransactionPriority) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Set the priority of transactions used for this index build.
setProgressLogIntervalMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Set the minimum time between successful progress logs when building across transactions.
setProgressLogIntervalMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Set the minimum time between successful progress logs when building across transactions.
setRange(KeyRange) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.Builder
 
setRange(TupleRange) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursorBase.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
 
setReadVersion(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
setRecord(M) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBStoredRecordBuilder
 
setRecordContextProperties(RecordLayerPropertyStorage) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Set the properties' wrapper to be used by this context to pass in the parameters configured by adopter.
setRecordCountKey(KeyExpression) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
Deprecated.
use COUNT type indexes instead
setRecordLayerPropertyStorage(RecordLayerPropertyStorage) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseRunner
Set the properties configured by adopter of Record-Layer for transactions opened by this runner.
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 the RecordMetaData and processes the extension options.
setRecords(Descriptors.FileDescriptor, boolean) - Method in class com.apple.foundationdb.record.RecordMetaDataBuilder
Adds the root file descriptor of the RecordMetaData.
setRecordsPerSecond(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Set the maximum number of records to process in a single second.
setRecordsPerSecond(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Set the maximum number of records to process in a single second.
setRecordStore(FDBRecordStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
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.OnlineIndexOperationBaseBuilder
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<RecordType>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.Builder
Set the explicit set of record types to be scrubbed.
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
 
setRepartitionCapped(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Set repartitioning capped due to hitting maximum limit.
setRepartitionDocumentCount(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Max number of documents to move during repartitioning (per partition).
setReportConflictingKeys(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Set whether to report conflicting key rangs on commit conflict.
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 a FDBReverseDirectoryCache and 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 a past_version.
setReverseDirectoryRowsPerTransaction(int) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
When a reverse directory lookup is performed from a FDBReverseDirectoryCache and 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 a past_version.
setReverseScanOrder(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
Set a reverse records scan order for indexing.
setRunLoopProfilingEnabled(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Set whether additional run-loop profiling of the FDB client is enabled.
setRunLoopProfilingEnabled(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
setRunner(FDBDatabaseRunner) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Set the runner that will be used to call into the database.
setSargable(CorrelationIdentifier, ComparisonRange) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.Builder
 
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.KeyValueCursorBase.Builder
 
setScheduledExecutor(ScheduledExecutorService) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Set the scheduled executor used by this factory.
setScheduledExecutorSupplier(Supplier<ScheduledExecutorService>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Provide a supplier that can construct ScheduledExecutorServices.
setScrubbingPolicy(OnlineIndexScrubber.ScrubbingPolicy) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.Builder
setScrubbingPolicy(OnlineIndexScrubber.ScrubbingPolicy.Builder) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.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.OnlineIndexOperationBaseBuilder
Set the RecordSerializer to 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
 
setServerRequestTracing(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Set whether FDB server request tracing is enabled for this transaction.
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
 
setSizeQuotaBytes(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Set by the caller - if applicable, request to auto-commit after this size quota.
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
 
setSortConfiguration(RecordQueryPlannerSortConfiguration) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set configuration for planning sorting, including whether the planner is allowed to use an in-memory sort plan.
setSourceIndex(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
Use this source index to scan records for indexing.
setSourceIndexSubspaceKey(Object) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.Builder
Use this source index's subspace key to scan records for indexing.
setsPlanHash(PlanHashable.PlanHashMode, Set<?>) - Static method in interface com.apple.foundationdb.record.PlanHashable
 
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 new ExecuteProperties with the given ExecuteState.
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.
setStateCacheabilityOnOpen(FDBRecordStore.StateCacheabilityOnOpen) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
 
setStateCacheabilityOnOpen(FDBRecordStore.StateCacheabilityOnOpen) - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
Sets the behavior for how the store state cacheability should be modified when the store is opened.
setStateCacheabilityOnOpen(FDBRecordStore.StateCacheabilityOnOpen) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
 
setStateRefreshTimeMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Set the refresh time for the cached LocatableResolver state.
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.OnlineIndexOperationBaseBuilder
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.OnlineIndexOperationBaseBuilder
Set the subspace of the record store in which to build the index.
setSynchronizedSessionRunner(SynchronizedSessionRunner) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingCommon
 
setTags(Set<String>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContextConfig.Builder
Set tags used for throttling.
setTargetIndexes(List<Index>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
Replace any previous target indexes list with this new one.
setTargetIndexesByName(List<String>) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.Builder
Replace any previous target indexes list with this new one.
setThreadsPerClientVersion(int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Deprecated.
Call directly on FDBDatabaseFactoryImpl. This will be removed in a future release.
setThreadsPerClientVersion(int) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
Set the number of threads per FDB client version.
setTimeLimit(long) - Method in class com.apple.foundationdb.record.ExecuteProperties.Builder
 
setTimeLimitMilliseconds(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Set the time limit.
setTimeLimitMilliseconds(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Set the time limit.
setTimeQuotaMillis(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
Set by the caller - if applicable, request to auto-commit after this time quota.
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
Deprecated.
in favor of setting the timer in FDBDatabase.openContext(FDBRecordContextConfig)
setTimer(FDBStoreTimer) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Set the timer used during the online index operation.
setTrace(String, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Configure the client trace directory and log group.
setTrace(String, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
setTraceFormat(FDBTraceFormat) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Set the output format for the client trace logs.
setTraceFormat(FDBTraceFormat) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
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 associated FDBDatabase.
setTrackProgress(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
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.
setTransactionIsTracedSupplier(Supplier<Boolean>) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
setTransactionListener(TransactionListener) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
Installs a listener to be notified of transaction events, such as creation, commit, and close.
setTransactionTimeLimitMilliseconds(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
Set the time limit for a single transaction.
setTransactionTimeLimitMilliseconds(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Set the time limit for a single transaction.
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.
setTranslatedQueryPredicate(QueryPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.Builder
 
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.
setup() - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
setUpdateTimestamp(long) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardDirectory
 
setUseFullKeyForValueIndex(boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration.Builder
Set whether the planner uses the entire key, including the primary key, for value indexes.
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 the function to 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.OnlineIndexOperationBaseBuilder
Set the use of a synchronized session during the index operation.
setUseSynchronizedSession(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig.Builder
Set the use of a synchronized session during the index operation.
setValue(R) - Method in class com.apple.foundationdb.record.util.pair.ComparablePair
 
setValue(R) - Method in class com.apple.foundationdb.record.util.pair.ImmutablePair
 
setValue(R) - Method in class com.apple.foundationdb.record.util.pair.NonnullPair
 
setValue(T) - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNodeBuilder
 
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.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 the FDBDatabase.WeakReadSemantics to use when creating a transaction.
setWeakReadSemantics(FDBDatabase.WeakReadSemantics) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
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.OnlineIndexOperationConfig.Builder
Set the maximum transaction size in a single transaction.
setWriteValidationRatio(double) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
Allows the user to specify a portion of serializations that will be validated.
setWriteValidationRatio(double) - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializerJCE.Builder
Allows the user to specify a portion of serializations that will be validated.
SHARED_READ_VERSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
SHIFT - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
SHOULD_BUILD_INDEX - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
SHOULD_CLEAR_EXISTING_DATA - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
SHOULD_MARK_READABLE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
shouldAllowNonIndexSort() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryPlannerSortConfiguration
Get whether the planner is allowed to use an in-memory sort plan.
shouldAllowTypeConversionContinue(IndexBuildProto.IndexBuildIndexingStamp, IndexBuildProto.IndexBuildIndexingStamp) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
If true, allow - in some specific cases - to continue building an index that was partly built by a different indexing method.
shouldAllowUnblock(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
If true, allow indexing continuation of a blocked partly built index.
shouldAllowUniquePendingState(FDBRecordStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy
If true, mark readable (after indexing) should allow the IndexState.READABLE_UNIQUE_PENDING index state.
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 a RecordQueryInJoinPlan into an equivalent OR of equality predicates, which might be plannable as a union.
shouldAttemptFailedInJoinAsUnion() - 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 a RecordQueryInJoinPlan into a RecordQueryInUnionPlan.
shouldAutoMergeDuringCommit() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexDeferredMaintenanceControl
If thrue, indicates to the index maintenance to automatically merge indexes during commit.
shouldCheckForDuplicateConditions() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Get whether normalization of query conditions should check for redundant conditions.
shouldDeferCrossProducts() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Return whether the query planner should defer cross products during join enumeration.
shouldDeferFetchAfterInJoinAndInUnion() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Get whether the query planner should attempt to delay the fetch of the whole record until after in-join or in union operators.
shouldDeferFetchAfterUnionAndIntersection() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Get whether the query planner should attempt to delay the fetch of the whole record until after union, intersection, and primary key distinct operators, as implemented in the various RecordQueryPlannerSubstitutionVisitors.
shouldIndexThisRecord(FDBRecordStore, FDBIndexableRecord<M>) - Method in class com.apple.foundationdb.record.metadata.IndexPredicate
Check if a given record should be indexed.
shouldLessenWork(FDBException) - Static method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
shouldNormalizeNestedFields() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
 
shouldOmitPrimaryKeyInOrderingKeyForInUnion() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Get whether the query planner should omit the common primary key from the ordering key for RecordQueryInUnionPlans.
shouldOmitPrimaryKeyInUnionOrderingKey() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Get whether the query planner should omit the common primary key from the ordering key for RecordQueryUnionPlans.
shouldOptimizeForIndexFilters() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Get whether the query planner should attempt to consider the applicability of filters that could then be evaluated on index entries into the planning process.
shouldOptimizeForRequiredResults() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Get whether the query planner should attempt to consider the set of required result fields while finding the best index for a record type access.
shouldPlanOtherAttemptWholeFilter() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
 
shouldReExplore() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
shouldUpdateExtremum(Tuple, Tuple) - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.PermutedMinMaxIndexMaintainer.Type
 
shouldUseFullKeyForValueIndex() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Get whether the planner uses the entire key, including the primary key, for value indexes.
shouldUseSynchronizedSession() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
 
shouldVisit(RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.ExpressionProperty
Return whether the property should visit the subgraph rooted at the given expression.
shouldVisit(Quantifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.ExpressionProperty
Return whether the property should visit the given quantifier and the references that the quantifier ranges over.
shouldVisit(Reference) - Method in interface com.apple.foundationdb.record.query.plan.cascades.ExpressionProperty
Return whether the property should visit the given reference and, transitively, the members of the reference.
show(boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
This is needed for graph integration into IntelliJ as IntelliJ only ever evaluates selfish methods.
show(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
Method to render the graph rooted at this reference.
show(boolean, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
Show the planner expression that is passed in as a graph rendered in your default browser.
show(boolean, Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
Show the planner expression that is passed in as a graph rendered in your default browser.
show(boolean, Reference, Set<MatchCandidate>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
Show the planner expression that and all the match candidates rendered in your default browser.
show(int, RelationalExpression) - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
Show the planner expression that is passed in as a graph rendered in your default browser.
show(int, Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraphProperty
Show the planner expression that is passed in as a graph rendered in your default browser.
show(Reference) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
showComparisonKey - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
 
showStats() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
shutdown() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
shutdown() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
simpleComparison(Comparisons.Type, Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryKeyExpression
 
SimpleComparison(IndexComparison.SimpleComparison.ComparisonType, Object) - Constructor for class com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison
 
SimpleComparison(Comparisons.SimpleComparison) - Constructor for class com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison
 
SimpleComparison(Comparisons.Type, Object) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
 
SimpleComparison(RecordMetaDataProto.SimpleComparison) - Constructor for class com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison
 
SimpleComparisonBase(Comparisons.Type, Object) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
Simplification - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
Main class of a mini rewrite engine to simplify (or to compute over) Value trees.
Simplification() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.Simplification
 
SIMPLIFICATION_DEPENDS_ON - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.DefaultValueSimplificationRuleSet
 
SIMPLIFICATION_DEPENDS_ON - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MaxMatchMapSimplificationRuleSet
 
SIMPLIFICATION_RULES - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.DefaultValueSimplificationRuleSet
 
SIMPLIFICATION_RULES - Static variable in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.MaxMatchMapSimplificationRuleSet
 
Simplification.RuleCallCreator<RESULT,CALL extends AbstractRuleCall<RESULT,CALL,BASE>,BASE> - Interface in com.apple.foundationdb.record.query.plan.cascades.values.simplification
Functional interface to create a specific rule call object.
simplify(AliasMap, Set<CorrelationIdentifier>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Method to simplify this value using the default simplification rule set.
simplify(AbstractValueRuleSet<Value, ValueSimplificationRuleCall>, AliasMap, Set<CorrelationIdentifier>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Method to simplify this value using a rule set passed in.
simplify(Value, AliasMap, Set<CorrelationIdentifier>, AbstractValueRuleSet<Value, ValueSimplificationRuleCall>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.Simplification
Main function that simplifies the given value using the AbstractValueRuleSet passed in.
simplify(Iterable<Value>, AbstractValueRuleSet<Value, ValueSimplificationRuleCall>, AliasMap, Set<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.Values
 
simplifyComparisonMaybe(Value, Comparisons.Comparison) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
 
simplifyCurrent(Value, AliasMap, Set<CorrelationIdentifier>, AbstractValueRuleSet<Value, ValueSimplificationRuleCall>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.Simplification
Main function that simplifies the given value using the AbstractValueRuleSet passed in.
simplifyLocalValues() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.Derivations
 
singleIterable(T) - Static method in interface com.apple.foundationdb.record.query.combinatorics.EnumeratingIterable
 
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
 
singularFixedBindingCheck(SetMultimap<Value, Ordering.Binding>, PartiallyOrderedSet<Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
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.combinatorics.PartiallyOrderedSet
 
size() - Method in class com.apple.foundationdb.record.query.plan.cascades.AccessHints
 
size() - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Returns the size of the alias map, i.e., the number of contained bindings.
size() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
size() - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
size() - Method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
size() - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
 
size() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
size() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
size(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
size(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
size(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
size(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
size(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
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 class com.apple.foundationdb.record.query.combinatorics.EnumeratingIterable.SingleIterator
 
skip(int) - Method in interface com.apple.foundationdb.record.query.combinatorics.EnumeratingIterator
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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.IndexOrphanBehavior
Silently ignore the index entry.
SKIP_INDEX_ENTRY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent maintaining an index when an entry is skipped by the IndexMaintenanceFilter.
SKIP_INDEX_RECORD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent at index predicates when an entry is used by the IndexMaintenanceFilter.
SKIP_INDEX_RECORD_BY_PREDICATE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent maintaining an index when the entire record is skipped by the IndexMaintenanceFilter.
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
 
skipNextSubtree() - Method in class com.apple.foundationdb.record.query.plan.cascades.PreOrderIterator
 
skipSortKeyAndReadRecord(CodedInputStream) - Method in class com.apple.foundationdb.record.provider.foundationdb.SortedRecordSerializer
 
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
 
slice(Map<Class<? extends RelationalExpression>, Set<RelationalExpression>>, Class<? extends RelationalExpression>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.FindExpressionProperty
 
SMALL - Enum constant in enum com.apple.foundationdb.record.CursorStreamingMode
Advanced.
snapshot - Variable in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
snapshot() - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
snapshot() - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
SNAPSHOT - Enum constant in enum com.apple.foundationdb.record.IsolationLevel
 
some(BindingMatcher<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.MultiMatcher
 
SOME - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.IndexMaintenanceFilter.IndexValues
 
SOME_DETAILS - Static variable in class com.apple.foundationdb.record.query.plan.explain.ExplainLevel
Nice to have details are rendered, other details not absolutely needed for the understanding of the plan are omitted.
SORT - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
SORT_FILE_VERSION - Static variable in class com.apple.foundationdb.record.sorting.FileSorter
 
SORT_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
sortByClauses() - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
 
sorted(boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Binding
 
sorted(OrderingPart.ProvidedSortOrder) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Binding
 
sortedBindingsForValues(Collection<? extends Value>, OrderingPart.ProvidedSortOrder) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
SortedFileReader<V> - Class in com.apple.foundationdb.record.sorting
Read values from files written by FileSorter.
SortedFileReader(File, FileSortAdapter<?, V>, StoreTimer, int, int) - Constructor for class com.apple.foundationdb.record.sorting.SortedFileReader
 
SortedInComparandSource - Class in com.apple.foundationdb.record.query.plan.plans
Variation of InComparandSource where the values should be returned in a sorted order.
SortedInComparandSource(PlanSerializationContext, PSortedInComparandSource) - Constructor for class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource
 
SortedInComparandSource(String, Comparisons.Comparison, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource
 
SortedInComparandSource.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
SortedInParameterSource - Class in com.apple.foundationdb.record.query.plan.plans
Helper class which represents a specialized InSource whose input is an outer binding (a parameter).
SortedInParameterSource(PlanSerializationContext, PSortedInParameterSource) - Constructor for class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
SortedInParameterSource(String, String, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
SortedInParameterSource.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
SortedInValuesSource - Class in com.apple.foundationdb.record.query.plan.plans
Helper class which represents a specialized InSource whose input is a list of literal values.
SortedInValuesSource(PlanSerializationContext, PSortedInValuesSource) - Constructor for class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource
 
SortedInValuesSource(String, List<Object>, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource
 
SortedInValuesSource.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
SortedRecordSerializer<M extends Message> - Class in com.apple.foundationdb.record.provider.foundationdb
Serialize records during sorting, either in a continuation or in a file.
SortedRecordSerializer(RecordSerializer<M>, RecordMetaData, StoreTimer) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.SortedRecordSerializer
 
SortEvents - Class in com.apple.foundationdb.record.sorting
StoreTimer events related to sorting.
SortEvents.Counts - Enum in com.apple.foundationdb.record.sorting
Instrumentation counts related to sorting.
SortEvents.Events - Enum in com.apple.foundationdb.record.sorting
Events related to sorting.
sortOrder(Collection<Ordering.Binding>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
sortValues(List<Object>, boolean) - Static method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
SOURCE_EXHAUSTED - Enum constant in enum com.apple.foundationdb.record.RecordCursor.NoNextReason
The underlying scan, irrespective of any limit, has reached the end.
SOURCE_FILE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
SOURCE_INDEX - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
sources() - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Returns the set of CorrelationIdentifiers that are mapped by this AliasMap.
SPATIAL_INDEX_SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
split(int) - Method in class com.apple.foundationdb.record.metadata.expressions.FieldKeyExpression
 
SPLIT_LONG_RECORDS - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
SPLIT_NEXT_INDEX - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
SPLIT_RANGES - Enum constant in enum 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 - Enum constant in enum 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.IndexingByRecords
Deprecated.
splitIndexBuildRange(int, int) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Deprecated, for removal: This API element is subject to removal in a future version.
for removal to be replaced by mutual indexing
SplitKeyExpression - Class in com.apple.foundationdb.record.metadata.expressions
Turn a key with repeated single values into multiple Key.Evaluated containing 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
 
splitNewChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
SplitSelectExtractIndependentQuantifiersRule - Class in com.apple.foundationdb.record.query.plan.cascades.rules
A rule that splits a SelectExpression into two SelectExpressions if one or more quantifiers this expression owns satisfy the following criteria: the quantifier is not correlated to any other quantifier in this SelectExpression the quantifier ranges over a sub expression of limited cardinality.
SplitSelectExtractIndependentQuantifiersRule() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.rules.SplitSelectExtractIndependentQuantifiersRule
 
StableStandardMutableNetwork<N,E> - Class in com.google.common.graph
This is mostly a copy of StandardMutableNetwork that delegates the construction of its underlying connections to a class providing stable iteration order over them.
StableStandardMutableNetwork(NetworkBuilder<? super N, ? super E>) - Constructor for class com.google.common.graph.StableStandardMutableNetwork
 
stampToString(IndexBuildProto.IndexBuildIndexingStamp) - Static method in exception com.apple.foundationdb.record.provider.foundationdb.IndexingBase.PartlyBuiltException
 
StandardIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
Base class for IndexMaintainer implementation.
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 - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
startExploration() - Method in class com.apple.foundationdb.record.query.plan.cascades.ConstraintsMap
Method to be called when exploration of a group is started.
startExploration() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
startingFrom(long) - Static method in class com.apple.foundationdb.record.provider.foundationdb.layers.interning.HighContentionAllocator.AllocationWindow
 
STARTS_WITH - Enum constant in enum com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison.ComparisonType
 
STARTS_WITH - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
startSession(Subspace, long, FDBDatabaseRunnerImpl) - Static method in class com.apple.foundationdb.record.provider.foundationdb.synchronizedsession.SynchronizedSessionRunner
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 new SynchronizedSession.
startsWith(ByteString) - Method in class com.apple.foundationdb.record.query.expressions.Field
Checks if the field starts with the given byte string.
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.OneOfThem
 
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
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 new SynchronizedSession.
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
 
stateCacheabilityOnOpen - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
staticOptionsSet - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
When set to true, static options have been set on the FDB instance.
Stats - Class in com.apple.foundationdb.record.query.plan.cascades.debug
 
Stats(Map<Debugger.Location, Long>, long, long) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.Stats
 
STATS_MAPS - Static variable in class com.apple.foundationdb.record.query.plan.QueryPlanInfoKeys
 
StatsMaps - Class in com.apple.foundationdb.record.query.plan.cascades.debug
 
StatsMaps(Map<Class<? extends Debugger.Event>, ? extends Stats>, Map<Class<? extends CascadesRule<?>>, ? extends Stats>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.StatsMaps
 
STOP - Enum constant in enum com.apple.foundationdb.record.sorting.MemoryScratchpad.RecordCountInMemoryLimitMode
Map retains getMaxRecordCountInMemory values and then stops.
stopOngoingOnlineIndexBuilds() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Synchronous/blocking version of OnlineIndexer.stopOngoingOnlineIndexBuildsAsync().
stopOngoingOnlineIndexBuilds(FDBRecordStore, Index) - Static method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Stop any ongoing online index build (only if it uses SynchronizedSessions) 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 uses SynchronizedSessions) by forcefully releasing the lock.
store - Variable in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainerState
 
STORE_INFO - Enum constant in enum 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
The number of times the store state cache returned a cached result.
STORE_STATE_CACHE_MISS - Enum constant in enum 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_RECORD - Static variable in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty
 
STORED_VERSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
StoredRecordProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
An attribute used to communicate to the planner that a plan flows instances of FDBQueriedRecord (and its subclasses) which can only represent records that reside stored on disk and were retrieved by this query.
StoredRecordProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty
 
StoredRecordProperty.StoredRecordVisitor - Class in com.apple.foundationdb.record.query.plan.cascades.properties
Planner property which indicates if the record flowed as the result of a RecordQueryPlan flows things stored records flow, e.g.
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.
storedRecordTypesForIndex(RecordMetaData, Index, Collection<RecordType>) - Static 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.
StoredRecordVisitor() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
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 an FDBRecordStoreBase instance.
StoreRecordFunction(String) - Constructor for class com.apple.foundationdb.record.metadata.StoreRecordFunction
 
storeStateCache - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
storeStateCacheFactory - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
StoreSubTimer - Class in com.apple.foundationdb.record.provider.common
A StoreTimer wrapping an underlying StoreTimer that accumulates the events that are issued to it, as well as sending those events along to the underlying store timer.
StoreSubTimer(StoreTimer) - Constructor for class com.apple.foundationdb.record.provider.common.StoreSubTimer
 
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 cumulative time spent/cumulative value of all occurrences of the associated StoreTimer.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.SizeEvent - Interface in com.apple.foundationdb.record.provider.common
StoreTimer.Events that count the number of occurrences of an operation and also the size of the operation.
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 a StoreTimer.
StoreTimerSnapshot.CounterSnapshot - Class in com.apple.foundationdb.record.provider.common
An immutable snapshot of a StoreTimer.Counter.
streamableAggregateValue() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
streamableAggregateValue(CollectionMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
StreamableAggregateValue - Interface in com.apple.foundationdb.record.query.plan.cascades.values
Tag interface used to mark AggregateValue implementations that can be calculated by a RecordQueryStreamingAggregationPlan operator.
StreamGrouping<M extends Message> - Class in com.apple.foundationdb.record.cursors.aggregate
StreamGrouping breaks streams of records into groups, based on grouping criteria.
StreamGrouping(Value, AggregateValue, Value, CorrelationIdentifier, CorrelationIdentifier, FDBRecordStoreBase<M>, EvaluationContext, CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.cursors.aggregate.StreamGrouping
Create a new group aggregator.
STREAMING_AGGREGATE_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
streamingAggregationPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
strictlySorted - Variable in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
strictlySorted(Memoizer) - Method in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
Return a copy of this plan that has the QueryPlan.isStrictlySorted() property.
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
strictlySorted(Memoizer) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
 
strictlySorted(Memoizer) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
STRING - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
 
STRING - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
STRING - Enum constant in enum com.apple.foundationdb.record.query.plan.planning.BindingFunction
 
stringHashUnordered(Iterable<String>) - Static method in interface com.apple.foundationdb.record.PlanHashable
Deprecated, for removal: This API element is subject to removal in a future version.
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
 
stringPropertyKey(String, String) - Static method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyKey
 
stripFieldPrefixMaybe(FieldValue.FieldPath, FieldValue.FieldPath) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
STRUCTURAL_WITH_LITERALS - Enum constant in enum com.apple.foundationdb.record.QueryHashable.QueryHashKind
 
STRUCTURAL_WITHOUT_LITERALS - Enum constant in enum com.apple.foundationdb.record.QueryHashable.QueryHashKind
 
structuralEquals(Object) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
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 empty AliasMap.
structuralEquals(Object, AliasMap) - Method in class com.apple.foundationdb.record.query.plan.cascades.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 class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
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.
STRUCTURE - Static variable in class com.apple.foundationdb.record.query.plan.explain.ExplainLevel
Only the structure of the plan, i.e.
SUB - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
 
SUB_DD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_DF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_DI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_DL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_FD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_FF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_FI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_FL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_ID - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_IF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_II - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_IL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_LD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_LF - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_LI - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUB_LL - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
SUBDIRECTORY - Enum constant in enum 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
 
SubFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.SubFn
 
subKey(int, int) - Method in class com.apple.foundationdb.record.IndexEntry
Produces a new IndexEntry whose key is a subset of this IndexEntry.
subKey(int, int) - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
 
subList(int) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
subList(int, int) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
subRanges(int, int) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
SUBSPACE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
SUBSPACE_KEY - Enum constant in enum 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
 
subsumedBy(RelationalExpression, AliasMap, IdentityBiMap<Quantifier, PartialMatch>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
subsumedBy(RelationalExpression, AliasMap, IdentityBiMap<Quantifier, PartialMatch>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
subsumedBy(RelationalExpression, AliasMap, IdentityBiMap<Quantifier, PartialMatch>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
subsumedBy(RelationalExpression, AliasMap, IdentityBiMap<Quantifier, PartialMatch>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
subsumedBy(RelationalExpression, AliasMap, IdentityBiMap<Quantifier, PartialMatch>, EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
Try to establish if otherExpression subsumes this one.
subsumedBy(RelationalExpression, AliasMap, IdentityBiMap<Quantifier, PartialMatch>, EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
SUBTRACT - Static variable in class com.apple.foundationdb.record.FunctionNames
 
success(V) - Static method in class com.apple.foundationdb.record.util.Result
Create a successful result wrapping a value.
SUCCESSFUL_TRANSACTIONS_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
successors(N) - Method in class com.google.common.graph.StableStandardMutableNetwork
 
suffix(BindingMatcher<? extends ScanComparisons>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
Sum(PlanSerializationContext, PNumericAggregationValue.PSum) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Sum
 
Sum(NumericAggregationValue.PhysicalOperator, Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Sum
 
SUM - Enum constant in enum com.apple.foundationdb.record.cursors.aggregate.PrimitiveAccumulatorOperation
 
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_D - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
SUM_F - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
SUM_I - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
SUM_L - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
SUM_LONG - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
 
SUM_LONG_CLEAR_WHEN_ZERO - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.indexes.AtomicMutation.Standard
 
SumAccumulator(CountValue.PhysicalOperator) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.CountValue.SumAccumulator
 
sumAggregationValue() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
sumAggregationValue(BindingMatcher<V>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
SumFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.SumFn
 
SynchronizedSessionRunner - Class in com.apple.foundationdb.record.provider.foundationdb.synchronizedsession
An FDBDatabaseRunner implementation that performs all work in the context of a SynchronizedSession.
SYNONYM_NAME - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
synthetic(Index, IndexEntry, FDBSyntheticRecord) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBQueriedRecord
 
SYNTHETIC_CONSTITUENTS - Enum constant in enum com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords
 
SYNTHETIC_RECORD_JOIN - Static variable in class com.apple.foundationdb.record.PipelineOperation
 
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
SyntheticRecordPlanner(FDBRecordStore) - Constructor for class com.apple.foundationdb.record.query.plan.synthetic.SyntheticRecordPlanner
Initialize a new planner.
SyntheticRecordPlanner(FDBRecordStore, RecordQueryPlanner) - 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 for SyntheticRecordType.
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 - Enum constant in enum 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.cascades.explain.NodeInfo
 
tailValues(K) - Method in class com.apple.foundationdb.record.sorting.MemoryDam
 
tailValues(K) - Method in class com.apple.foundationdb.record.sorting.MemoryScratchpad
 
tailValues(K) - Method in class com.apple.foundationdb.record.sorting.MemorySorter
 
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.
target(BindingMatcher<? extends String>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
TARGET_INDEX_NAME - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TARGET_INDEX_STATE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
targets() - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Returns the set of all CorrelationIdentifiers that this map maps to using the set of CorrelationIdentifiers returned by AliasMap.sources().
TASK - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
 
TASK_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TASK_QUEUE_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
tautology() - Static method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
TAUTOLOGY - Static variable in interface com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.SpatialPredicate
 
TEMP_TABLE_SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
TEMPORARY_BUFFER_DATA - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
TemporaryDataNodeWithInfo(Type, List<String>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.TemporaryDataNodeWithInfo
 
TemporaryDataNodeWithInfo(Type, List<String>, Map<String, Attribute>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.explain.PlannerGraph.TemporaryDataNodeWithInfo
 
TempTable - Class in com.apple.foundationdb.record.query.plan.cascades
A mutable, temporary, serializable, and in-memory buffer of QueryResults.
TempTable.Factory - Class in com.apple.foundationdb.record.query.plan.cascades
Factory of TempTable instances.
TempTableInsertCursor - Class in com.apple.foundationdb.record.cursors
A cursor that returns the items of a child cursor, and as a side effect, it adds the items to a designated TempTable.
tempTableInsertExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
TempTableInsertExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A logical expression for inserting into a temporary memory buffer TempTable.
tempTableInsertPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
TempTableInsertPlan - Class in com.apple.foundationdb.record.query.plan.plans
A query plan that inserts records into a temporary in-memory buffer TempTable.
TempTableInsertPlan(PlanSerializationContext, PTempTableInsertPlan) - Constructor for class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
TempTableInsertPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
tempTableScanExpression() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
TempTableScanExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A logical expression for scanning from a table-valued Bindings.Internal.CORRELATION that can correspond to a temporary memory buffer, i.e.
tempTableScanPlan() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
TempTableScanPlan - Class in com.apple.foundationdb.record.query.plan.plans
Scans records from a table-valued correlation, corresponding for example to a temporary in-memory buffer TempTable.
TempTableScanPlan(Value) - Constructor for class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
TempTableScanPlan.Deserializer - Class in com.apple.foundationdb.record.query.plan.plans
Deserializer.
TERTIARY - Static variable in class com.apple.foundationdb.record.provider.common.text.TextCollator.Strength
Respect tertiary differences, which normally means case.
test(Tuple) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.ConditionalUponPathPredicate
 
test(Tuple) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.TruePredicate
 
test(T, T, AliasMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.graph.MatchPredicate
Test for a match.
TEST - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.RebuildIndexReason
 
testInstance(FDB) - Static method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
 
TestLogMessageKeys - Enum in com.apple.foundationdb.record.logging
Common KeyValueLogMessage keys logged by the Record Layer core.
testObject(T, BiPredicate<Object, T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PrimitiveMatchers
Matcher that matches if the object passed in and the object being matched satisfy a predicate.
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", a IndexTypes.TEXT index will add a conflict range for the whole index to keep the commit size down at the expense of more conflicts.
TEXT_CONTAINS_ALL - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
TEXT_CONTAINS_ALL_PREFIXES - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
TEXT_CONTAINS_ALL_WITHIN - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
TEXT_CONTAINS_ANY - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
TEXT_CONTAINS_ANY_PREFIX - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
TEXT_CONTAINS_PHRASE - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
TEXT_CONTAINS_PREFIX - Enum constant in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
TEXT_INDEX_SCAN_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
TEXT_INDEX_SIZE_AMORTIZED - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TEXT_INDEX_UPDATE - Static variable in class com.apple.foundationdb.record.PipelineOperation
 
TEXT_KEY_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TEXT_OMIT_POSITIONS_OPTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
If "true", a IndexTypes.TEXT index will not store position numbers for tokens.
TEXT_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TEXT_TOKEN_MAX_SIZE - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
The maximum size of ngram tokenizer, when using ngram analyzer.
TEXT_TOKEN_MIN_SIZE - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
The minimum size of ngram tokenizer, when using ngram analyzer.
TEXT_TOKENIZER_NAME_OPTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
The name of the TextTokenizer to use with a IndexTypes.TEXT index.
TEXT_TOKENIZER_VERSION_OPTION - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
The version of the TextTokenizer to use with a IndexTypes.TEXT index.
TEXT_VALUE_SIZE - Enum constant in enum 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 for TextCollators.
TextCollatorRegistryJRE - Class in com.apple.foundationdb.record.provider.common.text
A text collator registry using the Java Platform's own Collator implementation.
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 the TextIndexMaintainer to write entries into a BunchedMap.
textIndexDetails(RecordQueryTextIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
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 of TextIndexMaintainers, 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 a TextScan object 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 of TextTokenizer should have its own implementation of this factory interface to provide instances of the tokenizer to a TextTokenizerRegistry.
TextTokenizerRegistry - Interface in com.apple.foundationdb.record.provider.common.text
Registry for TextTokenizers.
TextTokenizerRegistryImpl - Class in com.apple.foundationdb.record.provider.common.text
Default implementation of the TextTokenizerRegistry.
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
 
then(ValueEquivalence) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence
 
then(TranslationMap.TranslationFunction) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap.Builder.When
 
then(TranslationMap.TranslationFunction) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap.Builder.WhenAny
 
ThenEquivalence(ValueEquivalence, ValueEquivalence) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence.ThenEquivalence
 
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
 
THREAD_LOCAL - Static variable in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
The thread local variable.
THREADS_PER_CLIENT_VERSION - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
threadsPerClientVersion - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactoryImpl
Made volatile because multiple FDBDatabaseFactory instances can be created technically, and thus can be racy during init.
throwExceptionOnBlocking() - Method in enum com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
Indicates how to react if the future passed into asyncToSync() has not yet been completed.
ThrowsValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value that throws an exception if it gets executed.
ThrowsValue(Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
ThrowsValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
TIME_ENDED - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TIME_ENDED_MILLIS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TIME_LIMIT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TIME_LIMIT_MILLIS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TIME_LIMIT_REACHED - Enum constant in enum com.apple.foundationdb.record.RecordCursor.NoNextReason
The limit on the amount of time that a scan can take was reached.
TIME_STARTED - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TIME_STARTED_MILLIS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TIME_TO_WAIT_MILLIS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TIME_UNIT - Enum constant in enum 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 - Enum constant in enum 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 - Enum constant in enum 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in TimeWindowLeaderboardDirectoryOperation.
TIME_WINDOW_LEADERBOARD_GET_SUB_DIRECTORY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in TimeWindowLeaderboardSubDirectoryOperation.
TIME_WINDOW_LEADERBOARD_OVERLAPPING_CHANGED - Enum constant in enum 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in TimeWindowLeaderboardSaveSubDirectory.
TIME_WINDOW_LEADERBOARD_TRIM_SCORES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in TimeWindowLeaderboardScoreTrim.
TIME_WINDOW_LEADERBOARD_UPDATE_DIRECTORY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent in TimeWindowLeaderboardWindowUpdate.
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 - Enum constant in enum 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
 
timer - Variable in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
timeReadSampleKey(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordContext
 
timerIncrement(StoreTimer.Count) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
times(CardinalitiesProperty.Cardinalities) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty.Cardinalities
 
times(CardinalitiesProperty.Cardinality) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty.Cardinality
 
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 the TIME_WINDOW_LEADERBOARD index type.
TimeWindowLeaderboardIndexMaintainer(IndexMaintainerState) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowLeaderboardIndexMaintainer
 
TimeWindowLeaderboardIndexMaintainer.TimeWindowRankAndEntry - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
Struct containing both the time window leaderboard entry and the rank.
TimeWindowLeaderboardIndexMaintainer.UpdateState - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
 
TimeWindowLeaderboardIndexMaintainerFactory - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
Factory for the TIME_WINDOW_LEADERBOARD index 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
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
The TIME_WINDOW_RANK record function.
TimeWindowRecordFunction(String, GroupingKeyExpression, String, TimeWindowForFunction) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowRecordFunction
 
TimeWindowScanComparisons - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
TimeWindowScanComparisons(PlanSerializationContext, PTimeWindowScanComparisons) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons
 
TimeWindowScanComparisons(TimeWindowForFunction, ScanComparisons) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons
 
TimeWindowScanComparisons.Deserializer - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
Deserializer.
TimeWindowScanRange - Class in com.apple.foundationdb.record.provider.foundationdb.leaderboard
Extend IndexScanRange to have time window.
TimeWindowScanRange(int, long, TupleRange) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanRange
 
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.MultiDimensionalIndexHelper.Events
 
title() - Method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.RankedSetIndexHelper.Events
 
title() - Method in enum com.apple.foundationdb.record.sorting.SortEvents.Counts
 
title() - Method in enum com.apple.foundationdb.record.sorting.SortEvents.Events
 
TITLE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TO_STRING - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
toAbstractEventWithStateProto() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.AbstractEventWithState
 
toAbstractQueryPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AbstractQueryPredicate
 
toAliasMap(BiMap<Quantifier, Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
Convenience helper to create an alias translation map based on a translation map using quantifiers.
toAndOrPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndOrPredicate
 
toBiMap(Collection<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
Convenience helper to create an alias to quantifier map using a collection of quantifiers.
toBindableProto(Object) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Event
 
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.IndexingPolicy
Create an indexing policy builder from existing object.
toBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
To create a builder for the given config.
toBuilder() - Method in class com.apple.foundationdb.record.provider.foundationdb.properties.RecordLayerPropertyStorage
 
toBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Create a builder for a new alias map using the bindings of this map.
toBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
toBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
toBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Existential
 
toBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach
 
toBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
toBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
toBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap
 
toBuilder() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo
 
toBuilder() - Method in class com.apple.foundationdb.record.query.RecordQuery
 
toBuilder(int) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Create a builder for a new alias map using the bindings of this map.
toByteArray() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Serializes the schema.
toBytes() - Method in class com.apple.foundationdb.record.ByteArrayContinuation
 
toBytes() - Method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor.Continuation
 
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.
toByteString() - Method in class com.apple.foundationdb.record.ByteArrayContinuation
 
toByteString() - Method in class com.apple.foundationdb.record.cursors.RecursiveUnionCursor.Continuation
 
toByteString() - Method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursorContinuation
 
toByteString() - Method in interface com.apple.foundationdb.record.RecordCursorContinuation
Serialize this continuation to a ByteString object.
toByteString() - Method in class com.apple.foundationdb.record.RecordCursorEndContinuation
 
toByteString() - Method in class com.apple.foundationdb.record.RecordCursorStartContinuation
 
toClassWithRealEquals(Object) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons
 
toCoercionBiFunctionProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.CoercionBiFunction
 
toCoercionBiFunctionProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.ArrayCoercionBiFunction
 
toCoercionBiFunctionProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.PrimitiveCoercionBiFunction
 
toComparison() - Method in class com.apple.foundationdb.record.metadata.IndexComparison.NullComparison
 
toComparison() - Method in class com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison
 
toComparison() - Method in class com.apple.foundationdb.record.metadata.IndexComparison
Converts this IndexComparison into an equivalent Comparisons.Comparison.
toComparisonKeyFunctionProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression
 
toComparisonKeyFunctionProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues
 
toComparisonKeyFunctionProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction
 
toComparisonProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
toComparisonProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
 
toComparisonProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
 
toComparisonProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
toComparisonProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
 
toComparisonProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison
 
toComparisonProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
 
toComparisonProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
 
toComparisonProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
toComparisonProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
toComparisonProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
toCopierProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.Copier
 
toCopierProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier
 
toCopierProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldWithValueCopier
 
toCopierProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.MessageCopier
 
toCopyIfPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.ConditionalUponPathPredicate
 
toCopyIfPredicateProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.query.plan.AvailableFields.CopyIfPredicate
 
toCopyIfPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.TruePredicate
 
toDirectionProto(TupleOrdering.Direction) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.OrderedBytesHelpers
 
toEquivalentPlan(PartialMatch, PlanContext, Memoizer, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
Creates a RecordQueryPlan that represents a scan over the materialized candidate data.
toEquivalentPlan(PartialMatch, PlanContext, Memoizer, List<ComparisonRange>, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.AggregateIndexMatchCandidate
 
toEquivalentPlan(PartialMatch, PlanContext, Memoizer, List<ComparisonRange>, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.MatchCandidate
Creates a RecordQueryPlan that represents a scan over the materialized candidate data.
toEquivalentPlan(PartialMatch, PlanContext, Memoizer, List<ComparisonRange>, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
toEquivalentPlan(PartialMatch, PlanContext, Memoizer, List<ComparisonRange>, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
toEquivalentPlan(PartialMatch, PlanContext, Memoizer, List<ComparisonRange>, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
toEventBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.AdjustMatchEvent
 
toEventBuilder() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Event
 
toEventBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExecutingTaskEvent
 
toEventBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreExpressionEvent
 
toEventBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreGroupEvent
 
toEventBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
toEventBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeGroupEvent
 
toEventBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeInputsEvent
 
toEventBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformEvent
 
toEventBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformRuleCallEvent
 
toEventBuilder() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TranslateCorrelationsEvent
 
toEventProto() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Event
 
toExpressionProto(RelationalExpression) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Event
 
toFieldDescriptorMap(List<Descriptors.FieldDescriptor>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
Translates a list of Descriptors.FieldDescriptors to a mapping between field name and the field itself.
toGroupingKeyExpression(List<KeyExpression>) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
 
toGroupingKeyExpression(List<KeyExpression>, KeyExpression) - Static method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
 
toImmutable() - Method in class com.apple.foundationdb.record.MutableRecordStoreState
 
toImmutable() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Stats
 
toImmutable() - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
toImmutable() - Method in class com.apple.foundationdb.record.RecordStoreState
Create an immutable version of this RecordStoreState.
toImmutableIdentityBiMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, BinaryOperator<V>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
toInComparandSourceProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
toIndexAggregateFunction(String) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
Method to create a IndexAggregateFunction that represents the bound version of this function call.
toIndexAggregateFunction(String, GroupingKeyExpression) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
Method to create a IndexAggregateFunction that represents the bound version of this function call.
toIndexAggregateFunction(String, List<KeyExpression>) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
Method to create a IndexAggregateFunction that represents the bound version of this function call.
toIndexScanComparisonsProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
toIndexScanParametersProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
toIndexScanParametersProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScanParameters
 
toIndexScanParametersProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons
 
toIndexScanParametersProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
toInJoinPlan(Quantifier.Physical) - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
toInJoinPlan(Quantifier.Physical) - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
toInJoinPlan(Quantifier.Physical) - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
toInJoinPlan(Quantifier.Physical) - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
toInParameterSourceProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
toInSourceProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
toInSourceProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
toInSourceProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
toInSourceProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
toInSourceProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource
 
toInSourceProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
toInSourceProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource
 
toInSourceSuperProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InSource
 
toInValuesSourceProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
Token(ExplainTokens.TokenKind, int[], int[], int[]) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
Token(ExplainTokens.TokenKind, int, int, int) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
Token(ExplainTokens.TokenKind, int, int, int, int) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.Token
 
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 - Enum constant in enum 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.DimensionsKeyExpression
 
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
 
toLinkedIdentitySet() - Static method in class com.apple.foundationdb.record.query.plan.cascades.LinkedIdentitySet
 
toList() - Method in class com.apple.foundationdb.record.metadata.Key.Evaluated
Converts to a list.
toList(QueryPredicate, QueryPredicate, QueryPredicate...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndOrPredicate
 
toMatchedSortOrder() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
 
toMatchedSortOrder() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
 
toMatchPartitionProto(MatchPartition) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Event
 
toMutable() - Method in class com.apple.foundationdb.record.RecordStoreState
Create a mutable copy of this RecordStoreState.
toNumericAggregationValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue
 
TOO_LARGE_VALUE_MESSAGE_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
 
ToOrderedBytesAscNullsFirstFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue.ToOrderedBytesAscNullsFirstFn
 
ToOrderedBytesAscNullsLastFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue.ToOrderedBytesAscNullsLastFn
 
ToOrderedBytesDescNullsFirstFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue.ToOrderedBytesDescNullsFirstFn
 
ToOrderedBytesDescNullsLastFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue.ToOrderedBytesDescNullsLastFn
 
toOrderedBytesValue(BindingMatcher<V>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
toOrderedBytesValue(BindingMatcher<V>, TupleOrdering.Direction) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
toOrderedBytesValue(CollectionMatcher<? extends Value>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
ToOrderedBytesValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value that produces a binary encoding that is comparable according to certain modes gives by TupleOrdering.Direction.
ToOrderedBytesValue(Value, TupleOrdering.Direction) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
Constructs a new ToOrderedBytesValue instance.
ToOrderedBytesValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
ToOrderedBytesValue.ToOrderedBytesAscNullsFirstFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The TO_ORDERED_BYTES_ASC_NULLS_FIRST function.
ToOrderedBytesValue.ToOrderedBytesAscNullsLastFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The TO_ORDERED_BYTES_ASC_NULLS_LAST function.
ToOrderedBytesValue.ToOrderedBytesDescNullsFirstFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The TO_ORDERED_BYTES_DESC_NULLS_FIRST function.
ToOrderedBytesValue.ToOrderedBytesDescNullsLastFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The TO_ORDERED_BYTES_DESC_NULLS_LAST function.
toOrderingPartMap(Iterable<O>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart
 
toPartialMatchProto(PartialMatch) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Event
 
toPath() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
Convert the resolved path back into a KeySpacePath.
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.
toPathString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.Resolved
 
topBooleanComponents(QueryComponent) - Static method in interface com.apple.foundationdb.record.query.expressions.BooleanComponent
 
toPlan(Quantifier.Physical) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
 
toPlan(Quantifier.Physical) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
toPlan(Quantifier.Physical) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
toPlan(Quantifier.Physical) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
toPlanPartitions(Map<Map<PlanProperty<?>, ?>, ? extends Set<RecordQueryPlan>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.PlanPartition
 
toPlanReferenceProto(RecordQueryPlan) - Method in class com.apple.foundationdb.record.PlanSerializationContext
 
topologicalOrderPermutations(PartiallyOrderedSet<T>) - Static method in class com.apple.foundationdb.record.query.combinatorics.TopologicalSort
Create an EnumeratingIterable based on a partially-ordered set.
topologicalOrderPermutations(Set<T>, ImmutableSetMultimap<T, T>) - Static method in class com.apple.foundationdb.record.query.combinatorics.TopologicalSort
Create an EnumeratingIterable based on a set and a function describing the depends-on relationships between items in the given set.
topologicalOrderPermutations(Set<T>, Function<T, Set<T>>) - Static method in class com.apple.foundationdb.record.query.combinatorics.TopologicalSort
Create an EnumeratingIterable based 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.combinatorics
Utility class to provide helpers related to topological sorts.
toPredicate(Value) - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.AndPredicate
 
toPredicate(Value) - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.ConstantPredicate
 
toPredicate(Value) - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.NotPredicate
 
toPredicate(Value) - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.OrPredicate
 
toPredicate(Value) - Method in class com.apple.foundationdb.record.metadata.IndexPredicate
Converts a POJO into an equivalent QueryPredicate.
toPredicate(Value) - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.ValuePredicate
 
toPrefixRanges() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
toPrintable(Object) - Static method in class com.apple.foundationdb.record.query.expressions.Comparisons
 
toProto() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
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.IndexComparison.NullComparison
 
toProto() - Method in class com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison
 
toProto() - Method in class com.apple.foundationdb.record.metadata.IndexComparison
Converts this IndexComparison into a corresponding protobuf message.
toProto() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.AndPredicate
 
toProto() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.ConstantPredicate
 
toProto() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.NotPredicate
 
toProto() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.OrPredicate
 
toProto() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate
Serializes a POJO into the corresponding protobuf message.
toProto() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.ValuePredicate
 
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.metadata.UnnestedRecordType
Create a protobuf serialization of this record type.
toProto() - Method in interface com.apple.foundationdb.record.ProtoSerializable
 
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.query.plan.cascades.debug.Debugger.AdjustMatchEvent
 
toProto() - Method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Event
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExecutingTaskEvent
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreExpressionEvent
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.ExploreGroupEvent
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.InsertIntoMemoEvent
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeGroupEvent
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.OptimizeInputsEvent
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformEvent
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformRuleCallEvent
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TranslateCorrelationsEvent
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.cascades.TempTable
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
 
toProto() - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
Return a protobuf representation of this configuration object.
toProto() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryPlannerSortConfiguration
 
toProto() - Method in class com.apple.foundationdb.record.RecordMetaData
Serializes the record meta-data to a MetaData proto message.
toProto(boolean) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Java boolean to a Protobuf NullableBool.
toProto(double) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Java double to a Protobuf NullableDouble.
toProto(float) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Java float to a Protobuf NullableFloat.
toProto(int) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Java int to a Protobuf NullableInt32.
toProto(long) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Java long to a Protobuf NullableInt64.
toProto(PlanSerializationContext) - Method in enum com.apple.foundationdb.record.Bindings.Internal
 
toProto(PlanSerializationContext) - Method in enum com.apple.foundationdb.record.IndexFetchMethod
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.IndexScanType
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunction
 
toProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.PlanSerializable
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowForFunction
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
toProto(PlanSerializationContext) - Method in enum com.apple.foundationdb.record.query.expressions.Comparisons.Type
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.ConditionalUponPathPredicate
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.TruePredicate
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.Column
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.FieldAccessTrieNode
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate.UsedIndex
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.CompilableRange
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Physical
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum.EnumValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
 
toProto(PlanSerializationContext) - Method in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
toProto(PlanSerializationContext) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
toProto(PlanSerializationContext) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MaxEverValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MinEverValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.CoercionTrieNode
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.TransformationTrieNode
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Avg
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.BitmapConstructAgg
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Max
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Min
 
toProto(PlanSerializationContext) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Sum
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.ArrayCoercionBiFunction
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue.PrimitiveCoercionBiFunction
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RankValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.BinaryRelOpValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.UnaryRelOpValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
toProto(PlanSerializationContext) - Method in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldWithValueCopier
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.MessageCopier
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
 
toProto(PlanSerializationContext) - Method in enum com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.TupleSource
 
toProto(PlanSerializationContext) - Method in enum com.apple.foundationdb.record.query.plan.planning.BindingFunction
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InComparandSource
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
toProto(PlanSerializationContext) - Method in enum com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
toProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan.ScoreForRank
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySelectorPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortKey
 
toProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
toProto(FDBRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.SortedRecordSerializer
 
toProto(ByteString) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Java ByteString to a Protobuf NullableBytes.
toProto(Descriptors.FileDescriptor[]) - Method in class com.apple.foundationdb.record.RecordMetaData
Serializes the record meta-data to a MetaData proto message.
toProto(Object, Descriptors.Descriptor) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a field's value from a Tuple item to a message.
toProto(String) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Java String to a Protobuf NullableString.
toProto(UUID) - Static method in class com.apple.foundationdb.record.metadata.expressions.TupleFieldsHelper
Convert a Java UUID to a Protobuf UUID.
toProtoValue(Object) - Static method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
 
toProvidedSortOrder() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
 
toProvidedSortOrder() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
 
toProvidedSortOrder(boolean) - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
 
toQueryPredicate(TypeRepository, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
toQueryPredicate(TypeRepository, CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.BooleanValue
Translates the BooleanValue into a QueryPredicate.
toQueryPredicate(TypeRepository, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
toQueryPredicate(TypeRepository, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
toQueryPredicate(TypeRepository, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
toQueryPredicate(TypeRepository, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
toQueryPredicate(TypeRepository, CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue
 
toQueryPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
toQueryPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate
 
toQueryPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
toQueryPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate
 
toQueryPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
toQueryPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
toQueryPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
toQueryPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
toQueryPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
toQueryPredicateProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
toQueryPredicateProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
toRange() - Method in class com.apple.foundationdb.record.TupleRange
Convert into a FoundationDB Range.
toRange(byte[], byte[], EndpointType, EndpointType) - Static method in class com.apple.foundationdb.record.TupleRange
Convert a pair of endpoints into a FoundationDB Range.
toRange(Subspace) - Method in class com.apple.foundationdb.record.TupleRange
Convert into a FoundationDB Range.
toRecord(Descriptors.Descriptor, IndexEntry) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
 
toRecordInternal(Descriptors.Descriptor, IndexEntry) - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord
 
toRecordQueryAbstractModificationPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAbstractDataModificationPlan
 
toRecordQueryFilterPlanBaseProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlanBase
 
toRecordQueryIndexPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
toRecordQueryInJoinPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInJoinPlan
 
toRecordQueryIntersectionPlan(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
toRecordQueryInUnionPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySelectorPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
toRecordQueryPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
toRecordQueryUnionPlanBaseProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlanBase
 
toRecordQueryUnionPlanProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionPlan
 
toReferenceProto(Reference) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Event
 
toRelOpValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue
 
toRequestedSortOrder() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
 
toRequestedSortOrder() - Method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
 
toResidualPredicate() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
toResidualPredicate() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
transforms this Sargable into a conjunction of equality and non-equality predicates.
toResidualPredicate() - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
Create a QueryPredicate that is equivalent to this but which is evaluated as a residual predicate (cannot function as an index search argument).
toResolvedPath(FDBRecordContext) - Method in interface com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePath
Resolves the path into a ResolvedKeySpacePath, 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 a ResolvedKeySpacePath, 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
 
toResultValue(CorrelationIdentifier, Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
toResultValue(CorrelationIdentifier, Type, List<String>) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
toScanComparisons() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
toScanComparisons() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
toString() - Method in class com.apple.foundationdb.record.AsyncLoadingCache
 
toString() - Method in class com.apple.foundationdb.record.Bindings
 
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.DimensionsKeyExpression
 
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.IndexComparison.NullComparison
 
toString() - Method in class com.apple.foundationdb.record.metadata.IndexComparison.SimpleComparison
 
toString() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.AndPredicate
 
toString() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.ConstantPredicate
 
toString() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.NotPredicate
 
toString() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.OrPredicate
 
toString() - Method in class com.apple.foundationdb.record.metadata.IndexPredicate.ValuePredicate
 
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.ObjectPlanHash
 
toString() - Method in class com.apple.foundationdb.record.PipelineOperation
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.clientlog.KeySpaceCountTree
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBIndexedRawRecord
 
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 this FDBRecordVersion.
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.IndexScanComparisons
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanRange
 
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.KeySpaceTreeResolver.Resolved
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedAndRemainder
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceTreeResolver.ResolvedPrefixRoot
 
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.ResolverKeyValue
 
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.ResolverValidator.ValidatedEntry
 
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.TimeWindowLeaderboardIndexMaintainer.TimeWindowRankAndEntry
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowRecordFunction
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanRange
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.And
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.Hypercube
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanBounds.Or
 
toString() - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
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.BoundRecordQuery
 
toString() - Method in class com.apple.foundationdb.record.query.combinatorics.PartiallyOrderedSet
 
toString() - Method in class com.apple.foundationdb.record.query.expressions.AndComponent
 
toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
 
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.OpaqueEqualityComparison
 
toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
toString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
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.QueryKeyExpressionWithOneOfComparison
 
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.RecordTypeComparison
 
toString() - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison
 
toString() - Method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph.Relationship
 
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.cascades.AggregateIndexMatchCandidate
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRule
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.Correlated.BoundEquivalence
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.CorrelationIdentifier
Returns the backing string id.
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.PlannerBindings
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.MatchPartition
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering.Binding
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.Ordering
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.PartialMatch
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AbstractQueryPredicate
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.CompatibleTypeEvolutionPredicate.FieldAccessTrieNode
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.CompilableRange
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.PrimaryScanMatchCandidate
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.ForEach
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.ReferencePrinter
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum.EnumValue
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.TypeRepository
Returns a string representation of the schema.
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractValue
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.ResolvedAccessor
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRule
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.MaxMatchMap
 
toString() - Method in class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
toString() - Method in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
toString() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldCopier
 
toString() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.FieldWithValueCopier
 
toString() - Method in class com.apple.foundationdb.record.query.plan.IndexKeyValueToPartialRecord.MessageCopier
 
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.InComparandSource
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.InParameterSource
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.InValuesSource
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
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.RecordQueryFirstOrDefaultPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
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.RecordQueryInsertPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
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.RecordQueryMapPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
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.RecordQuerySelectorPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnKeyExpression
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan.ComparisonKeyFunction.OnValues
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
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.plans.RecordQueryUpdatePlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.RelativeProbabilityPlanSelector
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInComparandSource
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInParameterSource
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.SortedInValuesSource
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanConstraint
 
toString() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanInfo.QueryPlanInfoKey
 
toString() - Method in class com.apple.foundationdb.record.query.plan.QueryPlanResult
 
toString() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
toString() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortKey
 
toString() - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
toString() - Method in class com.apple.foundationdb.record.query.plan.TextScan
 
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.util.pair.ComparablePair
 
toString() - Method in class com.apple.foundationdb.record.util.pair.ImmutablePair
 
toString() - Method in class com.apple.foundationdb.record.util.pair.NonnullPair
 
toString() - Method in class com.apple.foundationdb.record.util.ProtoUtils.DynamicEnum
 
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 working FDBRecordContext but 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 this KeySpacePath that shows correspondences between original and resolved directory values in accordance with the input Tuple.
toString(Tuple) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpacePathWrapper
 
toStringForDebugging(RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
toStringForDebugging(RecordQueryPlan, int, int) - Static method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
toStringForExternalExplain(RecordQueryPlan) - Static method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
toStringForExternalExplain(RecordQueryPlan, int, int) - Static method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
ToStringToken(int, Object) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.ToStringToken
 
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_MICROS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TOTAL_QUERY_MILLIS - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
TOTAL_RECORDS_SCANNED - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TOTAL_RECORDS_SCANNED_DURING_FAILURES - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TOTAL_RESULT_COUNT - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
TOTAL_SCAN_MILLIS - Enum constant in enum com.apple.foundationdb.record.logging.TestLogMessageKeys
 
TOTAL_TASK_COUNT - Static variable in class com.apple.foundationdb.record.query.plan.QueryPlanInfoKeys
 
totalSize() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
totalSize() - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
totalTimeInNs - Variable in class com.apple.foundationdb.record.query.plan.cascades.debug.Stats
 
toTaskEvent(Debugger.Location) - Method in interface com.apple.foundationdb.record.query.plan.cascades.CascadesPlanner.Task
 
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 corresponding Tuple that can then be serialized into the database.
toTuple() - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolvedKeySpacePath
Converts the resolved path into a Tuple.
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 a KeySpacePath into a Tuple.
toTypeProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
 
toTypeProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
 
toTypeProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
 
toTypeProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
toTypeProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
toTypeProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
toTypeProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive
 
toTypeProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
toTypeProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
 
toTypeProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
toValue(CorrelationIdentifier, Type) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpressionWithValue
 
toValue(CorrelationIdentifier, Type) - Method in class com.apple.foundationdb.record.metadata.expressions.LiteralKeyExpression
 
toValue(CorrelationIdentifier, Type) - Method in class com.apple.foundationdb.record.metadata.expressions.RecordTypeKeyExpression
 
toValue(CorrelationIdentifier, Type) - Method in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
 
toValue(Quantifier) - Method in interface com.apple.foundationdb.record.metadata.expressions.KeyExpressionWithValue
 
toValue(List<? extends Value>) - Method in class com.apple.foundationdb.record.metadata.expressions.CollateFunctionKeyExpression
 
toValue(List<? extends Value>) - Method in class com.apple.foundationdb.record.metadata.expressions.FunctionKeyExpression
This method creates a Value based on this key expression.
toValue(List<? extends Value>) - Method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression
 
toValue(List<? extends Value>) - Method in class com.apple.foundationdb.record.metadata.expressions.OrderFunctionKeyExpression
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.EmptyValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ExistsValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexedValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexEntryObjectValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MaxEverValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MinEverValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LiteralValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Avg
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.BitmapConstructAgg
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Max
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Min
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Sum
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ObjectValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QueriedValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RankValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.BinaryRelOpValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.UnaryRelOpValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ThrowsValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
toValueProto(PlanSerializationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
toValueProto(PlanSerializationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
toValues(Iterable<? extends OrderingPart<?>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.OrderingPart
 
toValueSimplificationRuleCall(AbstractRule<Value, ValueSimplificationRuleCall, Value, ? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRuleCall
 
toValueWithRangesMaybe(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
toValueWithRangesMaybe(EvaluationContext) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
toValueWithRangesMaybe(EvaluationContext) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
toVersionstamp() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Converts this RecordVersion instance to a Versionstamp instance.
toVersionstamp(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Converts this RecordVersion instance to a Versionstamp instance.
TRACE_DIRECTORY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TRACE_FORMAT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TRACE_LOG_GROUP - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
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 - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TRANSACTION_NAME - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
TRANSACTION_TIME - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
Total lifetime of a transaction.
TRANSACTION_TOO_LARGE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Count failed due to transaction_too_large.
TransactionalRunner - Class in com.apple.foundationdb.record.provider.foundationdb.runners
A simple runner that can be used for opening and committing transactions, and making sure they are all closed.
TransactionalRunner(FDBDatabase, FDBRecordContextConfig) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.runners.TransactionalRunner
Creates a new runner for operating against a given database.
TransactionalRunner(FDBDatabase, FDBRecordContextConfig.Builder) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.runners.TransactionalRunner
Creates a runner for operating against a given database, with a mutable FDBRecordContextConfig.Builder.
TransactionListener - Interface in com.apple.foundationdb.record.provider.foundationdb
A class that is notified of events that take place within the scope of a transaction, such as when the transaction is created, committed, or closed.
TRANSFORM - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
 
TransformationTrieNode(Value, Map<Integer, MessageHelpers.TransformationTrieNode>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers.TransformationTrieNode
 
TransformedRecordSerializer<M extends Message> - Class in com.apple.foundationdb.record.provider.common
A RecordSerializer implementation that transforms the bytes produced by another serializer before returning (and likewise performs the reverse transformation before deserializing).
TransformedRecordSerializer(RecordSerializer<M>, boolean, int, boolean, double) - 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 the TransformedRecordSerializer class.
TransformedRecordSerializer.TransformState - Class in com.apple.foundationdb.record.provider.common
 
TransformedRecordSerializerJCE<M extends Message> - Class in com.apple.foundationdb.record.provider.common
An extension of TransformedRecordSerializer to use JCE to encrypt and decrypt records.
TransformedRecordSerializerJCE(RecordSerializer<M>, boolean, int, boolean, double, 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 the TransformedRecordSerializerJCE class.
TransformedRules(Set<ValueSimplificationRule<? extends Value>>, SetMultimap<ValueSimplificationRule<? extends Value>, ValueSimplificationRule<? extends Value>>, Set<ValueComputationRule<A, R, ? extends Value>>, SetMultimap<ValueComputationRule<A, R, ? extends Value>, ValueComputationRule<A, R, ? extends Value>>, LinkedIdentityMap<ValueSimplificationRule<? extends Value>, ValueComputationRule<A, R, ? extends Value>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRuleSet.TransformedRules
 
TransformEvent(Reference, Deque<CascadesPlanner.Task>, Debugger.Location, Reference, Object, CascadesRule<?>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformEvent
 
transformMessage(FDBRecordStoreBase<M>, EvaluationContext, MessageHelpers.TransformationTrieNode, MessageHelpers.CoercionTrieNode, Type, Descriptors.Descriptor, Type, Descriptors.Descriptor, Object) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.MessageHelpers
 
TransformRuleCallEvent(Reference, Deque<CascadesPlanner.Task>, Debugger.Location, Reference, Object, CascadesRule<?>, CascadesRuleCall) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TransformRuleCallEvent
 
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
 
transitiveClosure(PartiallyOrderedSet<T>) - Static method in class com.apple.foundationdb.record.query.combinatorics.TransitiveClosure
Compute the transitive closure of the depends-on map that is passed in.
transitiveClosure(Set<T>, SetMultimap<T, T>) - Static method in class com.apple.foundationdb.record.query.combinatorics.TransitiveClosure
Compute the transitive closure of the depends-on map that is passed in.
TransitiveClosure - Class in com.apple.foundationdb.record.query.combinatorics
Utility class to provide helpers related to the computation of the transitive closure of a partial order.
translate(Quantifier, Quantifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
Convenience helper to create a single ID translation map from the alias of one quantifier to the alias of another quantifier.
TRANSLATE_CORRELATIONS - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
 
translateCorrelations(TranslationMap) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
translateCorrelations(TranslationMap, boolean) - Method in interface com.apple.foundationdb.record.provider.foundationdb.IndexScanParameters
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
translateCorrelations(TranslationMap, boolean) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
translateCorrelations(TranslationMap, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.Reference
 
translateCorrelations(TranslationMap, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
translateCorrelations(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.bitmap.ComposedBitmapIndexQueryPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.DeleteExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.ExplodeExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.FullUnorderedScanExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.GroupByExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.InsertExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalDistinctExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalFilterExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalIntersectionExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalProjectionExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalTypeFilterExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUnionExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalUniqueExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.MatchableSortExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.PrimaryScanExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.RecursiveUnionExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.SelectExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableInsertExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.TempTableScanExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryAggregateIndexPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryComparatorPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryCoveringIndexPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryExplodePlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFlatMapPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryLoadByKeysPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithIndex
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRangePlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryRecursiveUnionPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScanPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQuerySelectorPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTextIndexPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedUnionPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableScanPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
translateCorrelations(TranslationMap, boolean, List<? extends Quantifier>) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
translateCorrelations(Iterable<? extends Quantifier>, TranslationMap, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers
 
translateCorrelations(List<? extends Reference>, TranslationMap, boolean) - Static method in class com.apple.foundationdb.record.query.plan.cascades.References
 
TranslateCorrelationsEvent(RelationalExpression, Debugger.Location) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.TranslateCorrelationsEvent
 
translateKeyExpression(KeyExpression, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
translateLeafPredicate(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
translateLeafPredicate(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ExistsPredicate
 
translateLeafPredicate(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
translateLeafPredicate(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
translateLeafPredicate(TranslationMap, boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
translateLeafPredicate(TranslationMap, boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
translatePredicates(TranslationMap, List<QueryPredicate>, boolean) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
translateQueryValueMaybe(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.MaxMatchMap
Express the MaxMatchMap.queryValue in terms of the MaxMatchMap.candidateValue which is now referred to via the candidateAlias passed in.
translateRange(Function<Comparisons.Comparison, Optional<Comparisons.Comparison>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints.CompilableRange
 
translateRanges(Function<Comparisons.Comparison, Optional<Comparisons.Comparison>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.RangeConstraints
 
translateValue(Value, CorrelationIdentifier, CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.plans.TranslateValueFunction
Translate a value to an equivalent value that can be evaluated prior to the operation that we are trying to push through.
translateValueAndComparisonsMaybe(Function<Value, Optional<Value>>, Function<Comparisons.Comparison, Optional<Comparisons.Comparison>>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValue
Replaces the predicate Value and Value(s) in the Comparison.
translateValueAndComparisonsMaybe(Function<Value, Optional<Value>>, Function<Comparisons.Comparison, Optional<Comparisons.Comparison>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
translateValueAndComparisonsMaybe(Function<Value, Optional<Value>>, Function<Comparisons.Comparison, Optional<Comparisons.Comparison>>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
TranslateValueFunction - Interface in com.apple.foundationdb.record.query.plan.plans
Interface for functions employed by RecordQueryFetchFromPartialRecordPlan that are used to translate a value by conceptually pushing it through that operation.
TranslationMap - Class in com.apple.foundationdb.record.query.plan.cascades.values.translation
Map used to specify translations.
TranslationMap.Builder - Class in com.apple.foundationdb.record.query.plan.cascades.values.translation
Builder class for a translation map.
TranslationMap.Builder.When - Class in com.apple.foundationdb.record.query.plan.cascades.values.translation
Class to provide fluent API, e.g.
TranslationMap.Builder.WhenAny - Class in com.apple.foundationdb.record.query.plan.cascades.values.translation
Class to provide fluent API, e.g.
TranslationMap.TranslationFunction - Interface in com.apple.foundationdb.record.query.plan.cascades.values.translation
Functional interface to specify the translation to take place when a QuantifiedValue is encountered.
Traversal - Class in com.apple.foundationdb.record.query.plan.cascades
Utility class to provide a graph view of a expression reference DAG given by a root expression reference (to a RelationalExpression that allows to perform traversal operations that are normally not possible on instances of Reference such as Traversal.getLeafReferences() and Traversal.getParentRefs(com.apple.foundationdb.record.query.plan.cascades.Reference).
Traversal.ReferencePath - Class in com.apple.foundationdb.record.query.plan.cascades
Case class to hold information about the path from an expression to another expression reference.
TREE_END - Enum constant in enum com.apple.foundationdb.record.EndpointType
 
TREE_START - Enum constant in enum com.apple.foundationdb.record.EndpointType
 
TreeLike<T extends TreeLike<T>> - Interface in com.apple.foundationdb.record.query.plan.cascades
Interface for tree-like structures and helpers for folds and traversals on these tree-like structures of node type TreeLike.
TreeLike.NonnullBiFunction<T,U,R> - Interface in com.apple.foundationdb.record.query.plan.cascades
Functional interface for a bi-function whose result is not nullable.
TreeLike.NonnullFunction<T,R> - Interface in com.apple.foundationdb.record.query.plan.cascades
Functional interface for a function whose result is not nullable.
TrieNode<D,T,N extends TrieNode<D,T,N>> - Interface in com.apple.foundationdb.record.util
Basic trie implementation that stores values at the trie's leaves.
TrieNode.AbstractTrieNode<D,T,N extends TrieNode.AbstractTrieNode<D,T,N>> - Class in com.apple.foundationdb.record.util
Basic trie implementation.
TrieNode.AbstractTrieNodeBuilder<D,T,N extends TrieNode.AbstractTrieNodeBuilder<D,T,N>> - Class in com.apple.foundationdb.record.util
Basic trie builder implementation.
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
 
TRUE - Enum constant in enum com.apple.foundationdb.record.metadata.IndexPredicate.ConstantPredicate.ConstantValue
 
TRUE - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.predicates.Proposition
 
TRUE - Static variable in interface com.apple.foundationdb.record.query.IndexQueryabilityFilter
 
TRUE - Static variable in class com.apple.foundationdb.record.query.plan.cascades.predicates.ConstantPredicate
 
TruePredicate() - Constructor for class com.apple.foundationdb.record.query.plan.AvailableFields.TruePredicate
 
trueWithConstraint(QueryPlanConstraint) - Static method in class com.apple.foundationdb.record.query.plan.cascades.BooleanWithConstraint
Factory method to create a conditional true based on a QueryPlanConstraint that is also passed in.
tryBuild(QueryPlanner, Collection<String>, IndexAggregateFunctionCall, QueryComponent, IndexQueryabilityFilter) - 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.
tryFrom(Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRange
 
tryFrom(Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
tryFromMatchMap(AliasMap, IdentityBiMap<Quantifier, PartialMatch>, MaxMatchMap) - Static method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
tryMerge(AliasMap, IdentityBiMap<Quantifier, PartialMatch>, Map<CorrelationIdentifier, ComparisonRange>, PredicateMultiMap, MaxMatchMap, QueryPlanConstraint) - Static method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
tryMergeParameterBindings(Collection<Map<CorrelationIdentifier, ComparisonRange>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.MatchInfo.RegularMatchInfo
 
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, IndexAggregateFunctionCall, IndexQueryabilityFilter) - 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 call.
tryPushValues(List<TranslateValueFunction>, List<? extends Quantifier>, Iterable<? extends Value>, CorrelationIdentifier) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan
 
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
 
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.
TUPLE - Enum constant in enum com.apple.foundationdb.record.query.plan.planning.BindingFunction
 
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 in Tuples.
TupleRange - Class in com.apple.foundationdb.record
A range within a subspace specified by two Tuple endpoints.
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 with CONTINUATION endpoint type.
tupleToString(Tuple) - Static method in class com.apple.foundationdb.record.TupleRange
 
type - Variable in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
type - Variable in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
Type - Interface in com.apple.foundationdb.record.query.plan.cascades.typing
Provides type information about the output of an expression such as Value in a QGM.
TYPE_FILTER_DEPTH - Static variable in class com.apple.foundationdb.record.query.plan.cascades.properties.RelationalExpressionDepthProperty
 
TYPE_FILTER_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
Type.Any - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Special Type that is undefined.
Type.Any.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Deserializer.
Type.AnyRecord - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Special Type.Record that is undefined.
Type.AnyRecord.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Deserializer.
Type.Array - Class in com.apple.foundationdb.record.query.plan.cascades.typing
A type representing an array of elements sharing the same type.
Type.Array.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Deserializer.
Type.Enum - Class in com.apple.foundationdb.record.query.plan.cascades.typing
An enumeration type.
Type.Enum.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Deserializer.
Type.Enum.EnumValue - Class in com.apple.foundationdb.record.query.plan.cascades.typing
A member value of an enumeration.
Type.Erasable - Interface in com.apple.foundationdb.record.query.plan.cascades.typing
Interface for classes that can be erased, i.e.
Type.None - Class in com.apple.foundationdb.record.query.plan.cascades.typing
The none type is an unresolved type meaning that an entity returning a none type should resolve the type to a regular type as the runtime does not support a none-typed data producer.
Type.None.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Deserializer.
Type.Null - Class in com.apple.foundationdb.record.query.plan.cascades.typing
The null type is an unresolved type meaning that an entity returning a null type should resolve the type to a regular type as the runtime does not support a null-typed data producer.
Type.Null.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Deserializer.
Type.Primitive - Class in com.apple.foundationdb.record.query.plan.cascades.typing
A primitive type.
Type.Primitive.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Deserializer.
Type.Record - Class in com.apple.foundationdb.record.query.plan.cascades.typing
A structured Type that contains a list of Type.Record.Field types.
Type.Record.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Deserializer.
Type.Record.Field - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Represents a field type in a Type.Record type.
Type.Relation - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Represents a relational type.
Type.Relation.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.typing
Deserializer.
Type.TypeCode - Enum in com.apple.foundationdb.record.query.plan.cascades.typing
All supported Types.
typeCodeFromPrimitive(Object) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Returns an equivalent Type of a primitive object.
typed(Class<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcher
 
Typed - Interface in com.apple.foundationdb.record.query.plan.cascades.typing
Provides Type information about result set.
TypedMatcher<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A TypedMatcher matches a data structure that is at least of a certain type.
TypedMatcher(Class<T>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcher
 
TypedMatcherWithExtractAndDownstream<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A TypedMatcher that also extracts an object from the current object and attempts to match that object with a downstream matcher.
TypedMatcherWithExtractAndDownstream(Class<T>, Extractor<? super T, ?>, BindingMatcher<?>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcherWithExtractAndDownstream
 
typedMatcherWithPredicate(Class<T>, Predicate<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcherWithPredicate
 
TypedMatcherWithPredicate<T> - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
A TypeMatcherWithPredicate extends TypedMatcher in a way that it still only matches objects that are at least of a certain type but that can be rejected by applying a given predicate to the object that is attempted ot be matched.
TypedMatcherWithPredicate(Class<T>, Predicate<T>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcherWithPredicate
 
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
 
typedWithDownstream(Class<T>, Extractor<? super T, ?>, BindingMatcher<?>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.TypedMatcherWithExtractAndDownstream
 
typeFilter(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
typeFilter(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
TypeFilterCountProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
A property that determines the sum, over all elements of a PlannerExpression tree, 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.cascades.properties.TypeFilterCountProperty
 
TypeFilterExpression - Interface in com.apple.foundationdb.record.query.plan.cascades.expressions
A relational planner expression that represents a type filter.
typeFilterPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
typeFilterPlan(CollectionMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
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.InvertedFunctionComparison
 
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.OpaqueEqualityComparison
 
typelessString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
typelessString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
typelessString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
typelessString() - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
typelessString() - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
typeOf(Object) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
 
TypeRepository - Class in com.apple.foundationdb.record.query.plan.cascades.typing
A utility class that enables mapping of a structured Type into a dynamically-generated equivalent Protobuf message descriptor.
TypeRepository.Builder - Class in com.apple.foundationdb.record.query.plan.cascades.typing
A builder that builds a TypeRepository object.

U

UdfFunction - Class in com.apple.foundationdb.record.query.plan.cascades.values
This represents a user-defined function that can be subclassed to extend the planner with extra functionality.
UdfFunction() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.UdfFunction
 
UdfValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
This represents a user-defined Value that can be subclassed to provide a custom implementation.
UdfValue(Iterable<? extends Value>, Type) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.UdfValue
 
UNABLE_TO_TRANSLATE - Static variable in interface com.apple.foundationdb.record.query.plan.plans.TranslateValueFunction
 
unableToTranslate() - Static method in interface com.apple.foundationdb.record.query.plan.plans.TranslateValueFunction
Shorthand for a function that never translates any value successfully.
unapply(RecordQueryPlannerConfiguration, T) - Method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.Extractor
 
unapply(RecordQueryPlannerConfiguration, T) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.UnapplyWithConfiguration
Unapplies this function to the given argument.
unapply(T) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.Unapply
Unapplies this function to the given argument.
Unapply<T,U> - Interface in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Interface for the unapply function used in a variety of matchers.
unapplyMaybe(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComparisonCompensation.NestedInvertableComparisonCompensation
 
unapplyMaybe(Value) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.simplification.ComparisonCompensation
Unapply the compensation.
UnapplyWithConfiguration<T,U> - Interface in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Interface for the unapply function (also using a RecordQueryPlannerConfiguration used in a variety of matchers.
UNARY_MINUS_BITWISE_NOT - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 
unaryFunction(String, String, UnaryOperator<Long>) - Static method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression.Builder
Variant of LongArithmethicFunctionKeyExpression.Builder.unaryFunction(String, UnaryOperator) that supports using an alternate name for the BuiltInFunction used by the planner.
unaryFunction(String, UnaryOperator<Long>) - Static method in class com.apple.foundationdb.record.metadata.expressions.LongArithmethicFunctionKeyExpression.Builder
Create a new builder of a unary function.
unblockIndexBuilds(String) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer
Unblock partly built indexes, allowing continuation.
unbound() - Static method in class com.apple.foundationdb.record.query.ParameterRelationshipGraph
Returns a specific instance that must be considered as a null element.
unbounded() - Static method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
unboundRootClass() - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
 
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
uncheckedOpenAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore.Builder
 
uncheckedOpenAsync() - Method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.BaseBuilder
Opens a FDBRecordStore instance without calling FDBRecordStore.checkVersion(UserVersionChecker, StoreExistenceCheck).
uncheckedOpenAsync() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBTypedRecordStore.Builder
 
UNCLOSED_WARNING - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
unclosedWarning - Variable in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabaseFactory
 
uncommittedComparisonRangesSize() - Method in class com.apple.foundationdb.record.query.plan.cascades.ComparisonRanges
 
underlying - Variable in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
underlying - Variable in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingReadTransaction
 
UnexpectedReadableException(boolean, String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.IndexingBase.UnexpectedReadableException
 
UngettableReferenceException(String) - Constructor for exception com.apple.foundationdb.record.query.plan.cascades.Reference.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
A RecordType expression 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
A Version expression 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 by FDBRecordStores if they are used before they have been properly initialized.
union(Compensation) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation
Union this compensation with another one passed in.
union(Compensation) - Method in interface com.apple.foundationdb.record.query.plan.cascades.Compensation.WithSelectCompensation
Specific implementation of union-ing two compensations both of type Compensation.WithSelectCompensation.
union(List<Quantifier.Physical>, List<OrderingPart.ProvidedOrderingPart>, boolean, boolean) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
Union(SetMultimap<Value, Ordering.Binding>, PartiallyOrderedSet<Value>, boolean) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.Ordering.Union
 
UNION - Static variable in class com.apple.foundationdb.record.query.plan.cascades.Ordering
Union merge operator to be used to obtain the resulting order of a distinct ordered union operation, or an in-union operation.
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.cascades.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.
unionOnExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unionOnExpression(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unionOnExpressionPlan(BindingMatcher<? extends RecordQueryPlan>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unionOnExpressionPlan(Collection<? extends BindingMatcher<? extends RecordQueryPlan>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unionOnValue(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unionOnValue(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unionOnValuesPlan(BindingMatcher<? extends RecordQueryPlan>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unionOnValuesPlan(Collection<? extends BindingMatcher<? extends RecordQueryPlan>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unionSources() - Method in class com.apple.foundationdb.record.query.plan.planning.InExtractor
 
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 throws RecordIndexUniquenessViolation on attempts to store duplicate values.
UNIQUE_OPTIONS - Static variable in class com.apple.foundationdb.record.metadata.IndexOptions
Options to set to enable IndexOptions.UNIQUE_OPTION.
UNIQUE_TOKENS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
uniqueID() - Static method in class com.apple.foundationdb.record.query.plan.cascades.CorrelationIdentifier
Create a new correlation identifier.
uniqueID() - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier
 
uniqueID(Class<?>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.CorrelationIdentifier
Create a new correlation identifier.
uniqueID(Class<?>, String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.CorrelationIdentifier
Create a new correlation identifier.
uniqueName(String) - Static method in class com.apple.foundationdb.record.util.ProtoUtils
Generates a JVM-wide unique correlation name with a prefix.
uniquenessViolationKey(Tuple, Tuple) - Static method in interface com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase
Return the key portion of entry, which should be the key with the index value as a tuple.
uniqueSingletonID(UUID, String) - Static method in class com.apple.foundationdb.record.query.plan.cascades.CorrelationIdentifier
Create a new correlation identifier.
uniqueTypeName() - Static method in class com.apple.foundationdb.record.util.ProtoUtils
Generates a JVM-wide unique type name.
UNKNOWN - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.predicates.Proposition
 
UNKNOWN - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
UNKNOWN - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
UNKNOWN_FIELDS - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
UNKNOWN_MAX_CARDINALITY - Static variable in interface com.apple.foundationdb.record.query.plan.plans.QueryPlan
unknownCardinalities() - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty.Cardinalities
 
unknownCardinality() - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty.Cardinality
 
unknownMaxCardinality() - Static method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty.Cardinalities
 
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.IndexingCommon
Constant indicating that there should be no limit to some usually limited operation.
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_TIME - Static variable in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationConfig
 
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.
UnmatchedFieldsCountProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
A property for counting the total number of KeyExpression columns (i.e., field-like KeyExpressions such as FieldKeyExpression and RecordTypeKeyExpression) that are not matched with at least one Comparisons.Comparison in a planner expression tree.
UnmatchedFieldsCountProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.UnmatchedFieldsCountProperty
 
unnamedOf(Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
Constructs a new field that has no name and no protobuf field index.
unnamedOf(V) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Column
 
UnnestedRecordType - Class in com.apple.foundationdb.record.metadata
A synthetic record type representing an unnesting of some kind of repeated, nested structure.
UnnestedRecordType(RecordMetaData, Descriptors.Descriptor, KeyExpression, Object, List<Index>, List<Index>, List<UnnestedRecordType.NestedConstituent>) - Constructor for class com.apple.foundationdb.record.metadata.UnnestedRecordType
 
UnnestedRecordType.NestedConstituent - Class in com.apple.foundationdb.record.metadata
A SyntheticRecordType.Constituent representing an element in an unnested record.
UnnestedRecordTypeBuilder - Class in com.apple.foundationdb.record.metadata
Builder for creating UnnestedRecordTypes.
UnnestedRecordTypeBuilder(RecordMetaDataProto.UnnestedRecordType, RecordMetaDataBuilder) - Constructor for class com.apple.foundationdb.record.metadata.UnnestedRecordTypeBuilder
 
UnnestedRecordTypeBuilder(String, Object, RecordMetaDataBuilder) - Constructor for class com.apple.foundationdb.record.metadata.UnnestedRecordTypeBuilder
Internal constructor for creating UnnestedRecordTypeBuilders.
UnnestedRecordTypeBuilder.NestedConstituent - Class in com.apple.foundationdb.record.metadata
UNORDERED_DISTINCT_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
UNORDERED_PRIMARY_KEY_DISTINCT_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
UNORDERED_UNION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
unorderedPrimaryKeyDistinct(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unorderedPrimaryKeyDistinct(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unorderedPrimaryKeyDistinctPlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
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
 
unorderedUnion(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unorderedUnion(CollectionMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
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
 
unorderedUnionPlan(BindingMatcher<? extends RecordQueryPlan>...) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
unorderedUnionPlan(Collection<? extends BindingMatcher<? extends RecordQueryPlan>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
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.
unpackRemoteFetchRecord(MappedKeyValue) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
 
UNROLL_SINGLE_RECORD_DELETES - Static variable in class com.apple.foundationdb.record.FDBRecordStoreProperties
Whether single record deletes should unroll range deletes into multiple single key deletes.
unsorted(Quantifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.expressions.LogicalSortExpression
 
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
 
UNSUPPORTED - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
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
 
UnsupportedMethodException - Exception in com.apple.foundationdb.record.provider.foundationdb
Exception thrown when a call is made for an API that is unsupported by the current APIVersion.
UnsupportedMethodException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.UnsupportedMethodException
 
UnsupportedMethodException(String, Throwable) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.UnsupportedMethodException
 
UnsupportedMethodException(Throwable) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.UnsupportedMethodException
 
unsupportedRecordFunction(IndexRecordFunction<T>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
 
UnsupportedRemoteFetchIndexException - Exception in com.apple.foundationdb.record.provider.foundationdb
Exception thrown when remote fetch is attempted on an index that does not support remote fetch.
UnsupportedRemoteFetchIndexException(String, Object...) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.UnsupportedRemoteFetchIndexException
 
UnsupportedRemoteFetchIndexException(String, Throwable) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.UnsupportedRemoteFetchIndexException
 
UnsupportedRemoteFetchIndexException(Throwable) - Constructor for exception com.apple.foundationdb.record.provider.foundationdb.UnsupportedRemoteFetchIndexException
 
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.
UNTRACKED - Static variable in class com.apple.foundationdb.record.cursors.CursorLimitManager
 
untrackOpenContext(FDBRecordContext) - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase
 
untransformed() - Method in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
 
unwrap(Equivalence.Wrapper<T>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
unwrapContinuation(byte[]) - Method in interface com.apple.foundationdb.record.RecordCursor.ContinuationConvertor
Extract a continuation to resume a new cursor.
unwrapIfArray(Object, Type) - Static method in class com.apple.foundationdb.record.query.plan.cascades.NullableArrayTypeUtils
If the value is a nullable array, unwrap the value wrapper.
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.
UPDATE - Static variable in class com.apple.foundationdb.record.PipelineOperation
 
UPDATE_TRANSFORM_AMBIGUOUS - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
 
updateExpression(BindingMatcher<? extends Quantifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RelationalExpressionMatchers
 
UpdateExpression - Class in com.apple.foundationdb.record.query.plan.cascades.expressions
A logical version of RecordQueryUpdatePlan.
UpdateExpression(Quantifier.ForEach, String, Type.Record, Map<FieldValue.FieldPath, Value>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.expressions.UpdateExpression
 
updateIndex(Class<?>, IntUnaryOperator) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
 
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.MultidimensionalIndexMaintainer
 
updateIndexKeys(FDBIndexableRecord<M>, boolean, List<IndexEntry>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.PermutedMinMaxIndexMaintainer
 
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 provided key and (within the same transaction) increment the version of the resolver state (see LocatableResolver.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
 
updatePlan(BindingMatcher<? extends RecordQueryPlan>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.RecordQueryPlanMatchers
 
updatePlan(Quantifier.Physical, String, Type.Record, Map<FieldValue.FieldPath, Value>, Value) - Static method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
Factory method to create a RecordQueryUpdatePlan.
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
 
updateWhileWriteOnly(FDBIndexableRecord<M>, FDBIndexableRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.NoOpIndexMaintainer
 
updateWhileWriteOnly(FDBIndexableRecord<M>, FDBIndexableRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
 
updateWhileWriteOnly(FDBIndexableRecord<M>, FDBIndexableRecord<M>) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexMaintainer
Update the associated index for a changed record while the index is in IndexState.WRITE_ONLY mode.
USE_INDEX_RECORD_BY_PREDICATE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Events
The amount of time spent at index predicates when an entry is skipped by the IndexMaintenanceFilter.
USE_REMOTE_FETCH - Enum constant in enum com.apple.foundationdb.record.IndexFetchMethod
 
USE_REMOTE_FETCH_WITH_FALLBACK - Enum constant in enum com.apple.foundationdb.record.IndexFetchMethod
 
UsedIndex(String, int) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.DatabaseObjectDependenciesPredicate.UsedIndex
 
UsedTypesProperty - Class in com.apple.foundationdb.record.query.plan.cascades.properties
A property that computes the set of complex (dynamic) types that is used by the graph passed in.
UsedTypesProperty() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.properties.UsedTypesProperty
 
useLegacyScrubber(boolean) - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.ScrubbingPolicy.Builder
Deprecated, for removal: This API element is subject to removal in a future version.
because allowing legacy code is temporary. After gaining confidence in the new code, the old code (and this function) will be deleted.
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.
UsesValueEquivalence<T extends UsesValueEquivalence<T>> - Interface in com.apple.foundationdb.record.query.plan.cascades
Tag interface to provide a common base for all classes implementing a semantic equals using a ValueEquivalence.
usingMatchedOrderingParts() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.OrderingValueComputationRuleSet
 
usingMatchedOrderingParts(OrderingPart.MatchedSortOrder) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.OrderingValueComputationRuleSet
 
usingProvidedOrderingParts() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.OrderingValueComputationRuleSet
 
usingProvidedOrderingParts(OrderingPart.ProvidedSortOrder) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.OrderingValueComputationRuleSet
 
usingRequestedOrderingParts() - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.OrderingValueComputationRuleSet
 
usingRequestedOrderingParts(OrderingPart.RequestedSortOrder) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.OrderingValueComputationRuleSet
 
uuid - Variable in class com.apple.foundationdb.record.provider.common.StoreTimer
 
UUID - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory.KeyType
 

V

vacuumReadableIndexesBuildData() - Method in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
validate() - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
 
validate() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexScrubber.Builder
 
validate(MetaDataValidator) - Method in class com.apple.foundationdb.record.metadata.IndexValidator
 
validate(FDBStoreTimer, LocatableResolver, ExecuteProperties.Builder, int, boolean, Consumer<ResolverValidator.ValidatedEntry>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator
Exhaustively validate entries in a LocatableResolver's mappings, ensuing that all entries in the mapping have corresponding and correct entries in the reverse mapping.
validate(LocatableResolver, FDBRecordContext, byte[], boolean, ScanProperties) - Static method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator
Validate entries in a LocatableResolver's mappings.
validate(LocatableResolver, FDBRecordContext, byte[], int, boolean, ScanProperties) - Static method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator
Validate entries in a LocatableResolver's mappings.
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.DimensionsKeyExpression
 
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.QueryKeyExpressionWithOneOfComparison
 
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.query.expressions.OrComponent
 
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.InvertedFunctionComparison
 
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.OpaqueEqualityComparison
 
validate(Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
validate(Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
validate(Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
validate(Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
validate(Descriptors.FieldDescriptor, boolean) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
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.
validateCall(List<Type>) - Method in class com.apple.foundationdb.record.query.plan.cascades.BuiltInFunction
Checks whether the provided list of argument types matches the list of function's parameter types.
validateCall(List<Type>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue.CollateFunction
 
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
 
ValidatedEntry(ResolverValidator.ValidationResult, ResolverKeyValue) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator.ValidatedEntry
 
ValidatedEntry(ResolverValidator.ValidationResult, ResolverKeyValue, String) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.keyspace.ResolverValidator.ValidatedEntry
 
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.
validateLimits() - Method in class com.apple.foundationdb.record.provider.foundationdb.OnlineIndexOperationBaseBuilder
 
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
 
validateObject(T) - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
 
validateOrphanEntries(byte[], ScanProperties) - Method in class com.apple.foundationdb.record.provider.foundationdb.indexes.StandardIndexMaintainer
Validate entries in the index.
validateOrThrowEx(boolean, String) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
validatePrimaryKeyForRecordType(KeyExpression, RecordType) - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
 
validateRecordType(RecordType) - Method in class com.apple.foundationdb.record.metadata.MetaDataValidator
 
validateRepeatedField(Descriptors.Descriptor) - Method in class com.apple.foundationdb.record.query.expressions.OneOfThemWithComparison
 
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.
validateSameMetadataOrThrow(FDBRecordStore) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingBase
 
validateSerialization(RecordMetaData, RecordType, M, byte[], StoreTimer) - Method in interface com.apple.foundationdb.record.provider.common.RecordSerializer
Validation method that will attempt to deserialize a record and validate it matches the original format.
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
 
VALIDATION_RESULT - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
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 type T.
Value - Interface in com.apple.foundationdb.record.query.plan.cascades.values
A scalar value type.
VALUE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
VALUE - Enum constant in enum 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_COMPUTATION_OPERATOR - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
VALUE_KEY - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
VALUE_SIZE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
VALUE_SIZE_LIMIT - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordStore
 
Value.IndexOnlyValue - Interface in com.apple.foundationdb.record.query.plan.cascades.values
A scalar value type that can only fetched from an index, that is the value cannot be fetched from the base record nor can it be computed "on-the-fly".
Value.InvertableValue<V extends Value> - Interface in com.apple.foundationdb.record.query.plan.cascades.values
A scalar Value that can be inverted, i.e.
Value.NondeterministicValue - Interface in com.apple.foundationdb.record.query.plan.cascades.values
Tag interface for marking a Value that is non-deterministic, i.e.
Value.NonEvaluableValue - Interface in com.apple.foundationdb.record.query.plan.cascades.values
A scalar Value that cannot be evaluated.
Value.RangeMatchableValue - Interface in com.apple.foundationdb.record.query.plan.cascades.values
A marker interface for Values that can be used in the context of range construction, it must be evaluable without being bound to an FDBRecordStoreBase.
ValueComparison(Comparisons.Type, Value) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
ValueComparison(Comparisons.Type, Value, ParameterRelationshipGraph) - Constructor for class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
ValueCompensation - Interface in com.apple.foundationdb.record.query.plan.cascades.values.simplification
Functional interface to perform compensation for partially matched Value-trees.
ValueComputationRule<A,R,T extends Value> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
Intermediate class that fixes the type of the PlannerRuleCall.
ValueComputationRule(BindingMatcher<T>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRule
 
ValueComputationRule.OnMatchComputationFunction<A,R> - Interface in com.apple.foundationdb.record.query.plan.cascades.values.simplification
Functional interface whose apply method is invoked after using the simplification's results.
ValueComputationRuleCall<ARGUMENT,RESULT> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule call implementation for the computation of a result while traversing Value trees.
ValueComputationRuleCall(AbstractRule<NonnullPair<Value, RESULT>, ValueComputationRuleCall<ARGUMENT, RESULT>, Value, ? extends Value>, Value, Value, ARGUMENT, PlannerBindings, AliasMap, Set<CorrelationIdentifier>, Function<Value, NonnullPair<Value, RESULT>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRuleCall
 
ValueComputationRuleSet<A,R> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A set of rules for use by a planner that supports quickly finding rules that could match a given planner expression.
ValueComputationRuleSet(Set<? extends AbstractValueRule<NonnullPair<Value, R>, ValueComputationRuleCall<A, R>, ? extends Value>>, SetMultimap<? extends AbstractValueRule<NonnullPair<Value, R>, ValueComputationRuleCall<A, R>, ? extends Value>, ? extends AbstractValueRule<NonnullPair<Value, R>, ValueComputationRuleCall<A, R>, ? extends Value>>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRuleSet
 
ValueComputationRuleSet.TransformedRules<A,R> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
Holder class to easily transform simplification rules and their dependencies into computation rules and their dependencies.
ValueEquivalence - Class in com.apple.foundationdb.record.query.plan.cascades
An interface (together with a set of specific final classes) that captures axiomatic (defined) equivalence between Values.
ValueEquivalence() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence
 
ValueEquivalence.AliasMapBackedValueEquivalence - Class in com.apple.foundationdb.record.query.plan.cascades
Equivalence that is being backed by an AliasMap.
ValueEquivalence.ConstantValueEquivalence - Class in com.apple.foundationdb.record.query.plan.cascades
Value equivalence implementation that relates bound constant references between ConstantObjectValues to LiteralValues.
ValueEquivalence.ThenEquivalence - Class in com.apple.foundationdb.record.query.plan.cascades
Helper equivalence to compose to equivalences.
ValueEquivalence.ValueMap - Class in com.apple.foundationdb.record.query.plan.cascades
Value equivalence based on a map of values.
ValueEquivalence.ValueMap.Builder - Class in com.apple.foundationdb.record.query.plan.cascades
Builder.
ValueIndexExpansionVisitor - Class in com.apple.foundationdb.record.query.plan.cascades
Class to expand value index access into a candidate graph.
ValueIndexExpansionVisitor(Index, Collection<RecordType>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ValueIndexExpansionVisitor
 
ValueIndexLikeMatchCandidate - Interface in com.apple.foundationdb.record.query.plan.cascades
Trait to implement some default logic for MatchCandidates that are defined over value index-like data structures such as PrimaryScanMatchCandidate and ValueIndexScanMatchCandidate.
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 for ValueIndexMaintainer indexes.
ValueIndexMaintainerFactory() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexMaintainerFactory
 
valueIndexOverScanNeeded(String) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlannerConfiguration
 
ValueIndexScanMatchCandidate - Class in com.apple.foundationdb.record.query.plan.cascades
Case class to represent a match candidate that is backed by an index.
ValueIndexScanMatchCandidate(Index, Collection<RecordType>, Traversal, List<CorrelationIdentifier>, Type, CorrelationIdentifier, List<Value>, List<Value>, KeyExpression, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.ValueIndexScanMatchCandidate
 
ValueIndexScrubbingToolsDangling - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
Index Scrubbing Toolbox for a Value index maintainer.
ValueIndexScrubbingToolsDangling() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexScrubbingToolsDangling
 
ValueIndexScrubbingToolsMissing - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
Index Scrubbing Toolbox for a Value index maintainer.
ValueIndexScrubbingToolsMissing() - Constructor for class com.apple.foundationdb.record.provider.foundationdb.indexes.ValueIndexScrubbingToolsMissing
 
valueMapBuilder() - Static method in class com.apple.foundationdb.record.query.plan.cascades.ValueEquivalence
 
ValueMatchers - Class in com.apple.foundationdb.record.query.plan.cascades.matching.structure
Matchers for descendants of Value.
valueObjectToProto(Object) - Static method in class com.apple.foundationdb.record.query.plan.serialization.PlanSerialization
Helper method to serialize plan fragments that are essentially values of the underlying data model.
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.aggregate.PrimitiveAccumulatorOperation
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.IndexFetchMethod
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.IndexComparison.SimpleComparison.ComparisonType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.metadata.IndexPredicate.ConstantPredicate.ConstantValue
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.PlanHashable.PlanHashKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.PlanHashable.PlanHashMode
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.APIVersion
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.FDBRecordStore.StateCacheabilityOnOpen
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.IndexDeferredMaintenanceControl.LastStep
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.MultiDimensionalIndexHelper.Events
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.indexes.PermutedMinMaxIndexMaintainer.Type
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.IndexScrubbingTools.ScrubbingType
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.keyspace.ResolverValidator.ValidationResult
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.IndexingPolicy.DesiredAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.provider.foundationdb.OnlineIndexer.IndexingPolicy.TakeoverTypes
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.ParameterRelationshipGraph.RelationshipType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.ComparisonRange.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Shorthand
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.Ordering.OrderPreservingKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.MatchedSortOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.ProvidedSortOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.OrderingPart.RequestedSortOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping.MappingKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.predicates.Proposition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering.Distinctness
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.SemanticException.ErrorCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.LogicalOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue.PhysicalOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.values.CountValue.PhysicalOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.PhysicalOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.PhysicalOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.ComparisonFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue.PhysicalOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
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.planning.BindingFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords
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.QueryToKeyMatcher.MatchType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.QueryHashable.QueryHashKind
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.
valueOf(String) - Static method in enum com.apple.foundationdb.record.sorting.MemoryScratchpad.RecordCountInMemoryLimitMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.sorting.SortEvents.Counts
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.apple.foundationdb.record.sorting.SortEvents.Events
Returns the enum constant of this type with the specified name.
valuePredicate(BindingMatcher<V>, Comparisons.Comparison) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QueryPredicateMatchers
 
valuePredicate(BindingMatcher<V>, BindingMatcher<C>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.QueryPredicateMatchers
 
ValuePredicate - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
A predicate consisting of a Value and a Comparisons.Comparison.
ValuePredicate(Value, Comparisons.Comparison) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
ValuePredicate(RecordMetaDataProto.ValuePredicate) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.ValuePredicate
 
ValuePredicate(List<String>, IndexComparison) - Constructor for class com.apple.foundationdb.record.metadata.IndexPredicate.ValuePredicate
 
ValuePredicate.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.predicates
Deserializer.
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.aggregate.PrimitiveAccumulatorOperation
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.IndexFetchMethod
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.IndexComparison.SimpleComparison.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.metadata.IndexPredicate.ConstantPredicate.ConstantValue
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.PlanHashable.PlanHashKind
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.PlanHashable.PlanHashMode
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.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.APIVersion
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.FDBRecordStore.StateCacheabilityOnOpen
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.IndexDeferredMaintenanceControl.LastStep
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.MultiDimensionalIndexHelper.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.indexes.PermutedMinMaxIndexMaintainer.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.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.IndexScrubbingTools.ScrubbingType
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.keyspace.ResolverValidator.ValidationResult
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.IndexingPolicy.DesiredAction
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.IndexingPolicy.TakeoverTypes
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.ParameterRelationshipGraph.RelationshipType
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.cascades.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.plan.cascades.debug.Debugger.Location
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.cascades.debug.Debugger.Shorthand
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
values() - Static method in enum com.apple.foundationdb.record.query.plan.cascades.Ordering.OrderPreservingKind
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.cascades.OrderingPart.MatchedSortOrder
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.cascades.OrderingPart.ProvidedSortOrder
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.cascades.OrderingPart.RequestedSortOrder
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.cascades.PredicateMultiMap.PredicateMapping.MappingKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap
 
values() - Static method in enum com.apple.foundationdb.record.query.plan.cascades.predicates.Proposition
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.cascades.RequestedOrdering.Distinctness
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.cascades.SemanticException.ErrorCode
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.cascades.typing.Type.TypeCode
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.cascades.values.ArithmeticValue.LogicalOperator
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.cascades.values.ArithmeticValue.PhysicalOperator
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.cascades.values.CountValue.PhysicalOperator
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.cascades.values.IndexOnlyAggregateValue.PhysicalOperator
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.cascades.values.NumericAggregationValue.PhysicalOperator
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.cascades.values.VariadicFunctionValue.ComparisonFunction
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.cascades.values.VariadicFunctionValue.PhysicalOperator
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.explain.ExplainTokens.TokenKind
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.explain.ExplainTokensWithPrecedence.Precedence
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.explain.PrettyExplainFormatter.Color
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.planning.BindingFunction
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.planning.BooleanPredicateNormalizer.Mode
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.plans.RecordQueryFetchFromPartialRecordPlan.FetchIndexRecords
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.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.QueryHashable.QueryHashKind
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() - Static method in enum com.apple.foundationdb.record.sorting.MemoryScratchpad.RecordCountInMemoryLimitMode
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.sorting.SortEvents.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.sorting.SortEvents.Events
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNode
 
values() - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNodeBuilder
 
values() - Method in interface com.apple.foundationdb.record.util.TrieNode
 
Values - Class in com.apple.foundationdb.record.query.plan.cascades.values
Helper class for dealing with Values.
Values() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.Values
 
VALUES_DATA - Static variable in class com.apple.foundationdb.record.query.plan.cascades.explain.NodeInfo
 
ValueSimplificationRule<TYPE extends Value> - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
Intermediate class that fixes the base type of the AbstractRuleCall to be Value.
ValueSimplificationRule(BindingMatcher<TYPE>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueSimplificationRule
 
ValueSimplificationRuleCall - Class in com.apple.foundationdb.record.query.plan.cascades.values.simplification
A rule call implementation for the simplification of Value trees.
ValueSimplificationRuleCall(AbstractRule<Value, ValueSimplificationRuleCall, Value, ? extends Value>, Value, Value, PlannerBindings, AliasMap, Set<CorrelationIdentifier>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueSimplificationRuleCall
 
valuesSeen - Variable in class com.apple.foundationdb.record.cursors.AsyncIteratorCursor
 
ValueWithChild - Interface in com.apple.foundationdb.record.query.plan.cascades.values
A scalar value type that has children.
VariadicFunctionValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A Value that applies an arithmetic operation on its child expressions.
VariadicFunctionValue(VariadicFunctionValue.PhysicalOperator, List<Value>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
Constructs a new instance of VariadicFunctionValue.
VariadicFunctionValue.CoalesceFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The coalesce function.
VariadicFunctionValue.ComparisonFunction - Enum in com.apple.foundationdb.record.query.plan.cascades.values
Logical operator.
VariadicFunctionValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
VariadicFunctionValue.GreatestFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The greatest function.
VariadicFunctionValue.LeastFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The least function.
VariadicFunctionValue.PhysicalOperator - Enum in com.apple.foundationdb.record.query.plan.cascades.values
Physical operators.
VC0 - Enum constant in enum com.apple.foundationdb.record.PlanHashable.PlanHashMode
 
VC1 - Enum constant in enum com.apple.foundationdb.record.PlanHashable.PlanHashMode
Changes contained are: ConstantObjectValue hashes without index .
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 - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
VERSION - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.typing.Type.TypeCode
 
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 like IndexTypes.VALUE, but that allows one of the components to be VersionKeyExpression.
VERSION_LENGTH - Static variable in class com.apple.foundationdb.record.provider.foundationdb.FDBRecordVersion
Length of the underlying byte array representation of an FDBRecordVersion.
VERSION_PROTO - Static variable in class com.apple.foundationdb.record.metadata.expressions.VersionKeyExpression
 
versionColumns() - Method in class com.apple.foundationdb.record.metadata.expressions.DimensionsKeyExpression
 
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
 
VersionFn() - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue.VersionFn
 
VersionIndexMaintainer - Class in com.apple.foundationdb.record.provider.foundationdb.indexes
Implementation of IndexMaintainer for 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 for VersionIndexMaintainer indexes.
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 serialized FDBRecordVersion should be contained within the key.
versionValue() - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ValueMatchers
 
VersionValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value representing a version stamp derived from a quantifier.
VersionValue(Value) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
VersionValue.Deserializer - Class in com.apple.foundationdb.record.query.plan.cascades.values
Deserializer.
VersionValue.VersionFn - Class in com.apple.foundationdb.record.query.plan.cascades.values
The and function.
visit(RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visit(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visit(RecordQueryPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitAggregateIndexPlan(RecordQueryAggregateIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitAggregateIndexPlan(RecordQueryAggregateIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitAggregateIndexPlan(RecordQueryAggregateIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitAggregateIndexPlan(RecordQueryAggregateIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitAggregateIndexPlan(RecordQueryAggregateIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitAggregateIndexPlan(RecordQueryAggregateIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitAggregateIndexPlan(RecordQueryAggregateIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitAggregateIndexPlan(RecordQueryAggregateIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitAliasDefinition(ExplainTokens.AliasDefinitionToken, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
visitAliasDefinition(ExplainTokens.AliasDefinitionToken, CharSequence) - Method in class com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter
 
visitAliasReference(ExplainTokens.AliasReferenceToken, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
visitAliasReference(ExplainTokens.AliasReferenceToken, CharSequence) - Method in class com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter
 
visitBracketLike(ExplainTokens.BracketLikeToken, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
visitBracketLike(ExplainTokens.BracketLikeToken, CharSequence) - Method in class com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter
 
visitCommaLike(ExplainTokens.CommaLikeToken, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
visitComparatorPlan(RecordQueryComparatorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitComparatorPlan(RecordQueryComparatorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitComparatorPlan(RecordQueryComparatorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitComparatorPlan(RecordQueryComparatorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitComparatorPlan(RecordQueryComparatorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitComparatorPlan(RecordQueryComparatorPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitComparatorPlan(RecordQueryComparatorPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitComparatorPlan(RecordQueryComparatorPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitComposedBitmapIndexQueryPlan(ComposedBitmapIndexQueryPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitComposedBitmapIndexQueryPlan(ComposedBitmapIndexQueryPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitComposedBitmapIndexQueryPlan(ComposedBitmapIndexQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitComposedBitmapIndexQueryPlan(ComposedBitmapIndexQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitComposedBitmapIndexQueryPlan(ComposedBitmapIndexQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitComposedBitmapIndexQueryPlan(ComposedBitmapIndexQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitComposedBitmapIndexQueryPlan(ComposedBitmapIndexQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitComposedBitmapIndexQueryPlan(ComposedBitmapIndexQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitComposedBitmapIndexQueryPlan(ComposedBitmapIndexQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitComposedBitmapIndexQueryPlan(ComposedBitmapIndexQueryPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitComposedBitmapIndexQueryPlan(ComposedBitmapIndexQueryPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitCoveringIndexPlan(RecordQueryCoveringIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitCoveringIndexPlan(RecordQueryCoveringIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitCoveringIndexPlan(RecordQueryCoveringIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitCoveringIndexPlan(RecordQueryCoveringIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitCoveringIndexPlan(RecordQueryCoveringIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitCoveringIndexPlan(RecordQueryCoveringIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitCoveringIndexPlan(RecordQueryCoveringIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitCoveringIndexPlan(RecordQueryCoveringIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitDamPlan(RecordQueryDamPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitDamPlan(RecordQueryDamPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitDamPlan(RecordQueryDamPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitDamPlan(RecordQueryDamPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitDamPlan(RecordQueryDamPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitDamPlan(RecordQueryDamPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitDamPlan(RecordQueryDamPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitDamPlan(RecordQueryDamPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitDefault(KeyExpression) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
visitDefault(RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.ExpressionProperty
 
visitDefault(RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitDefault(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitDefault(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitDefault(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitDefault(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitDefault(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitDefault(RecordQueryPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitDefault(RecordQueryPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitDefaultOnEmptyPlan(RecordQueryDefaultOnEmptyPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitDefaultOnEmptyPlan(RecordQueryDefaultOnEmptyPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitDefaultOnEmptyPlan(RecordQueryDefaultOnEmptyPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitDefaultOnEmptyPlan(RecordQueryDefaultOnEmptyPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitDefaultOnEmptyPlan(RecordQueryDefaultOnEmptyPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitDefaultOnEmptyPlan(RecordQueryDefaultOnEmptyPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitDefaultOnEmptyPlan(RecordQueryDefaultOnEmptyPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitDefaultOnEmptyPlan(RecordQueryDefaultOnEmptyPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitDeleteExpression(DeleteExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitDeleteExpression(DeleteExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitDeleteExpression(DeleteExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitDeletePlan(RecordQueryDeletePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitDeletePlan(RecordQueryDeletePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitDeletePlan(RecordQueryDeletePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitDeletePlan(RecordQueryDeletePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitDeletePlan(RecordQueryDeletePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitDeletePlan(RecordQueryDeletePlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitDeletePlan(RecordQueryDeletePlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitDeletePlan(RecordQueryDeletePlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
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.
visitError(ExplainTokens.Token, CharSequence) - Method in class com.apple.foundationdb.record.query.plan.explain.DefaultExplainFormatter
 
visitError(ExplainTokens.Token, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
visitError(ExplainTokens.Token, CharSequence) - Method in class com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter
 
visitExplodeExpression(ExplodeExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitExplodeExpression(ExplodeExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitExplodeExpression(ExplodeExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitExplodePlan(RecordQueryExplodePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitExplodePlan(RecordQueryExplodePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitExplodePlan(RecordQueryExplodePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitExplodePlan(RecordQueryExplodePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitExplodePlan(RecordQueryExplodePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitExplodePlan(RecordQueryExplodePlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitExplodePlan(RecordQueryExplodePlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitExplodePlan(RecordQueryExplodePlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitExpression(EmptyKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
 
visitExpression(EmptyKeyExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.KeyExpressionVisitor
Specific method that is called on EmptyKeyExpressions.
visitExpression(EmptyKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
visitExpression(EmptyKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
visitExpression(FieldKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
 
visitExpression(FieldKeyExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.KeyExpressionVisitor
Specific method that is called on FieldKeyExpressions.
visitExpression(FieldKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
visitExpression(FieldKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
visitExpression(FunctionKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
 
visitExpression(FunctionKeyExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.KeyExpressionVisitor
Specific method that is called on FunctionKeyExpressions.
visitExpression(FunctionKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
visitExpression(FunctionKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
visitExpression(KeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
Specific implementation of the fall-back visitation method.
visitExpression(KeyExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.KeyExpressionVisitor
Default method that is called on unknown subclasses of KeyExpression.
visitExpression(KeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
Specific implementation of the fall-back visitation method.
visitExpression(KeyExpression) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
Specific implementation of the fall-back visitation method.
visitExpression(KeyExpressionWithValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
 
visitExpression(KeyExpressionWithValue) - Method in interface com.apple.foundationdb.record.query.plan.cascades.KeyExpressionVisitor
Specific method that is called on KeyExpressionWithValues.
visitExpression(KeyExpressionWithValue) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
visitExpression(KeyExpressionWithValue) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
visitExpression(KeyWithValueExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
 
visitExpression(KeyWithValueExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.KeyExpressionVisitor
Specific method that is called on KeyWithValueExpressions.
visitExpression(KeyWithValueExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
visitExpression(KeyWithValueExpression) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
visitExpression(ListKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
 
visitExpression(ListKeyExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.KeyExpressionVisitor
Specific method that is called on ListKeyExpressions.
visitExpression(ListKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
visitExpression(ListKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
visitExpression(NestingKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
 
visitExpression(NestingKeyExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.KeyExpressionVisitor
Specific method that is called on NestingKeyExpressions.
visitExpression(NestingKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
visitExpression(NestingKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
visitExpression(ThenKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor
 
visitExpression(ThenKeyExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.KeyExpressionVisitor
Specific method that is called on ThenKeyExpressions.
visitExpression(ThenKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor
 
visitExpression(ThenKeyExpression) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor
 
visitFetchFromPartialRecordPlan(RecordQueryFetchFromPartialRecordPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitFetchFromPartialRecordPlan(RecordQueryFetchFromPartialRecordPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitFetchFromPartialRecordPlan(RecordQueryFetchFromPartialRecordPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitFetchFromPartialRecordPlan(RecordQueryFetchFromPartialRecordPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitFetchFromPartialRecordPlan(RecordQueryFetchFromPartialRecordPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitFetchFromPartialRecordPlan(RecordQueryFetchFromPartialRecordPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitFetchFromPartialRecordPlan(RecordQueryFetchFromPartialRecordPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitFetchFromPartialRecordPlan(RecordQueryFetchFromPartialRecordPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitFilterPlan(RecordQueryFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitFilterPlan(RecordQueryFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitFilterPlan(RecordQueryFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitFilterPlan(RecordQueryFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitFilterPlan(RecordQueryFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitFilterPlan(RecordQueryFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitFilterPlan(RecordQueryFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitFilterPlan(RecordQueryFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitFirstOrDefaultPlan(RecordQueryFirstOrDefaultPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitFirstOrDefaultPlan(RecordQueryFirstOrDefaultPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitFirstOrDefaultPlan(RecordQueryFirstOrDefaultPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitFirstOrDefaultPlan(RecordQueryFirstOrDefaultPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitFirstOrDefaultPlan(RecordQueryFirstOrDefaultPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitFirstOrDefaultPlan(RecordQueryFirstOrDefaultPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitFirstOrDefaultPlan(RecordQueryFirstOrDefaultPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitFirstOrDefaultPlan(RecordQueryFirstOrDefaultPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitFlatMapPlan(RecordQueryFlatMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitFlatMapPlan(RecordQueryFlatMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitFlatMapPlan(RecordQueryFlatMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitFlatMapPlan(RecordQueryFlatMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitFlatMapPlan(RecordQueryFlatMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitFlatMapPlan(RecordQueryFlatMapPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitFlatMapPlan(RecordQueryFlatMapPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitFlatMapPlan(RecordQueryFlatMapPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitFullUnorderedScanExpression(FullUnorderedScanExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitFullUnorderedScanExpression(FullUnorderedScanExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitFullUnorderedScanExpression(FullUnorderedScanExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitGroupByExpression(GroupByExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitGroupByExpression(GroupByExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitGroupByExpression(GroupByExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitIdentifier(ExplainTokens.IdentifierToken, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
visitIdentifier(ExplainTokens.IdentifierToken, CharSequence) - Method in class com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter
 
visitInComparandJoinPlan(RecordQueryInComparandJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitInComparandJoinPlan(RecordQueryInComparandJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitInComparandJoinPlan(RecordQueryInComparandJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitInComparandJoinPlan(RecordQueryInComparandJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitInComparandJoinPlan(RecordQueryInComparandJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitInComparandJoinPlan(RecordQueryInComparandJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitInComparandJoinPlan(RecordQueryInComparandJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitInComparandJoinPlan(RecordQueryInComparandJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitIndexPlan(RecordQueryIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitIndexPlan(RecordQueryIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitIndexPlan(RecordQueryIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitIndexPlan(RecordQueryIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitIndexPlan(RecordQueryIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitIndexPlan(RecordQueryIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitIndexPlan(RecordQueryIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitIndexPlan(RecordQueryIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitInJoinPlan(RecordQueryInJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitInJoinPlan(RecordQueryInJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitInJoinPlan(RecordQueryInJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitInJoinPlan(RecordQueryInJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitInJoinPlan(RecordQueryInJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitInParameterJoinPlan(RecordQueryInParameterJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitInParameterJoinPlan(RecordQueryInParameterJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitInParameterJoinPlan(RecordQueryInParameterJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitInParameterJoinPlan(RecordQueryInParameterJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitInParameterJoinPlan(RecordQueryInParameterJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitInParameterJoinPlan(RecordQueryInParameterJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitInParameterJoinPlan(RecordQueryInParameterJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitInParameterJoinPlan(RecordQueryInParameterJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitInsertExpression(InsertExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitInsertExpression(InsertExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitInsertExpression(InsertExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitInsertPlan(RecordQueryInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitInsertPlan(RecordQueryInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitInsertPlan(RecordQueryInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitInsertPlan(RecordQueryInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitInsertPlan(RecordQueryInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitInsertPlan(RecordQueryInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitInsertPlan(RecordQueryInsertPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitInsertPlan(RecordQueryInsertPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitInUnionOnKeyExpressionPlan(RecordQueryInUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitInUnionOnKeyExpressionPlan(RecordQueryInUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitInUnionOnKeyExpressionPlan(RecordQueryInUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitInUnionOnKeyExpressionPlan(RecordQueryInUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitInUnionOnKeyExpressionPlan(RecordQueryInUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitInUnionOnKeyExpressionPlan(RecordQueryInUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitInUnionOnKeyExpressionPlan(RecordQueryInUnionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitInUnionOnKeyExpressionPlan(RecordQueryInUnionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitInUnionOnValuesPlan(RecordQueryInUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitInUnionOnValuesPlan(RecordQueryInUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitInUnionOnValuesPlan(RecordQueryInUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitInUnionOnValuesPlan(RecordQueryInUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitInUnionOnValuesPlan(RecordQueryInUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitInUnionOnValuesPlan(RecordQueryInUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitInUnionOnValuesPlan(RecordQueryInUnionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitInUnionOnValuesPlan(RecordQueryInUnionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitInValuesJoinPlan(RecordQueryInValuesJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitInValuesJoinPlan(RecordQueryInValuesJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitInValuesJoinPlan(RecordQueryInValuesJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitInValuesJoinPlan(RecordQueryInValuesJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitInValuesJoinPlan(RecordQueryInValuesJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitInValuesJoinPlan(RecordQueryInValuesJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitInValuesJoinPlan(RecordQueryInValuesJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitInValuesJoinPlan(RecordQueryInValuesJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitKeyword(ExplainTokens.KeywordToken, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
visitKeyword(ExplainTokens.KeywordToken, CharSequence) - Method in class com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter
 
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.
visitLineBreakOrSpace(ExplainTokens.LineBreakOrSpaceToken, CharSequence) - Method in class com.apple.foundationdb.record.query.plan.explain.DefaultExplainFormatter
 
visitLineBreakOrSpace(ExplainTokens.LineBreakOrSpaceToken, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
visitLineBreakOrSpace(ExplainTokens.LineBreakOrSpaceToken, CharSequence) - Method in class com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter
 
visitLoadByKeysPlan(RecordQueryLoadByKeysPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitLoadByKeysPlan(RecordQueryLoadByKeysPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitLoadByKeysPlan(RecordQueryLoadByKeysPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitLoadByKeysPlan(RecordQueryLoadByKeysPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitLoadByKeysPlan(RecordQueryLoadByKeysPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitLoadByKeysPlan(RecordQueryLoadByKeysPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitLoadByKeysPlan(RecordQueryLoadByKeysPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitLoadByKeysPlan(RecordQueryLoadByKeysPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitLogicalDistinctExpression(LogicalDistinctExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitLogicalDistinctExpression(LogicalDistinctExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitLogicalDistinctExpression(LogicalDistinctExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitLogicalFilterExpression(LogicalFilterExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitLogicalFilterExpression(LogicalFilterExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitLogicalFilterExpression(LogicalFilterExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitLogicalIntersectionExpression(LogicalIntersectionExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitLogicalIntersectionExpression(LogicalIntersectionExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitLogicalIntersectionExpression(LogicalIntersectionExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitLogicalProjectionExpression(LogicalProjectionExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitLogicalProjectionExpression(LogicalProjectionExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitLogicalProjectionExpression(LogicalProjectionExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitLogicalSortExpression(LogicalSortExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitLogicalSortExpression(LogicalSortExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitLogicalSortExpression(LogicalSortExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitLogicalTypeFilterExpression(LogicalTypeFilterExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitLogicalTypeFilterExpression(LogicalTypeFilterExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitLogicalTypeFilterExpression(LogicalTypeFilterExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitLogicalUnionExpression(LogicalUnionExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitLogicalUnionExpression(LogicalUnionExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitLogicalUnionExpression(LogicalUnionExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitLogicalUniqueExpression(LogicalUniqueExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitLogicalUniqueExpression(LogicalUniqueExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitLogicalUniqueExpression(LogicalUniqueExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitMapPlan(RecordQueryMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitMapPlan(RecordQueryMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitMapPlan(RecordQueryMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitMapPlan(RecordQueryMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitMapPlan(RecordQueryMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitMapPlan(RecordQueryMapPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitMapPlan(RecordQueryMapPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitMapPlan(RecordQueryMapPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitMatchableSortExpression(MatchableSortExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitMatchableSortExpression(MatchableSortExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitMatchableSortExpression(MatchableSortExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitNested(ExplainTokens.NestedToken, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
visitOptionalWhitespace(ExplainTokens.OptionalWhitespaceToken, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
visitor(PullUp, CorrelationIdentifier) - Static method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.PullUp
 
visitPredicatesFilterPlan(RecordQueryPredicatesFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitPredicatesFilterPlan(RecordQueryPredicatesFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitPredicatesFilterPlan(RecordQueryPredicatesFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitPredicatesFilterPlan(RecordQueryPredicatesFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitPredicatesFilterPlan(RecordQueryPredicatesFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitPredicatesFilterPlan(RecordQueryPredicatesFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitPredicatesFilterPlan(RecordQueryPredicatesFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitPredicatesFilterPlan(RecordQueryPredicatesFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitPrimaryScanExpression(PrimaryScanExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitPrimaryScanExpression(PrimaryScanExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitPrimaryScanExpression(PrimaryScanExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitQuantifiers(RelationalExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.ExpressionProperty
 
visitRangePlan(RecordQueryRangePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitRangePlan(RecordQueryRangePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitRangePlan(RecordQueryRangePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitRangePlan(RecordQueryRangePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitRangePlan(RecordQueryRangePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitRangePlan(RecordQueryRangePlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitRangePlan(RecordQueryRangePlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitRangePlan(RecordQueryRangePlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitRecordQueryAggregateIndexPlan(RecordQueryAggregateIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryAggregateIndexPlan(RecordQueryAggregateIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryAggregateIndexPlan(RecordQueryAggregateIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryComparatorPlan(RecordQueryComparatorPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryComparatorPlan(RecordQueryComparatorPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryComparatorPlan(RecordQueryComparatorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryCoveringIndexPlan(RecordQueryCoveringIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryCoveringIndexPlan(RecordQueryCoveringIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryCoveringIndexPlan(RecordQueryCoveringIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryDamPlan(RecordQueryDamPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryDamPlan(RecordQueryDamPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryDamPlan(RecordQueryDamPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryDefaultOnEmptyPlan(RecordQueryDefaultOnEmptyPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryDefaultOnEmptyPlan(RecordQueryDefaultOnEmptyPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryDefaultOnEmptyPlan(RecordQueryDefaultOnEmptyPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryDeletePlan(RecordQueryDeletePlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryDeletePlan(RecordQueryDeletePlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryDeletePlan(RecordQueryDeletePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryExplodePlan(RecordQueryExplodePlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryExplodePlan(RecordQueryExplodePlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryExplodePlan(RecordQueryExplodePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryFetchFromPartialRecordPlan(RecordQueryFetchFromPartialRecordPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryFetchFromPartialRecordPlan(RecordQueryFetchFromPartialRecordPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryFetchFromPartialRecordPlan(RecordQueryFetchFromPartialRecordPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryFilterPlan(RecordQueryFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryFilterPlan(RecordQueryFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryFilterPlan(RecordQueryFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryFirstOrDefaultPlan(RecordQueryFirstOrDefaultPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryFirstOrDefaultPlan(RecordQueryFirstOrDefaultPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryFirstOrDefaultPlan(RecordQueryFirstOrDefaultPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryFlatMapPlan(RecordQueryFlatMapPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryFlatMapPlan(RecordQueryFlatMapPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryFlatMapPlan(RecordQueryFlatMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryInComparandJoinPlan(RecordQueryInComparandJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryInComparandJoinPlan(RecordQueryInComparandJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryInComparandJoinPlan(RecordQueryInComparandJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryIndexPlan(RecordQueryIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryIndexPlan(RecordQueryIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryIndexPlan(RecordQueryIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryInParameterJoinPlan(RecordQueryInParameterJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryInParameterJoinPlan(RecordQueryInParameterJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryInParameterJoinPlan(RecordQueryInParameterJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryInsertPlan(RecordQueryInsertPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryInsertPlan(RecordQueryInsertPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryInsertPlan(RecordQueryInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryIntersectionOnKeyExpressionPlan(RecordQueryIntersectionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.ComparisonsProperty
 
visitRecordQueryIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryIntersectionOnValuesPlan(RecordQueryIntersectionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.ComparisonsProperty
 
visitRecordQueryInUnionOnKeyExpressionPlan(RecordQueryInUnionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryInUnionOnKeyExpressionPlan(RecordQueryInUnionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryInUnionOnKeyExpressionPlan(RecordQueryInUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryInUnionOnValuesPlan(RecordQueryInUnionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryInUnionOnValuesPlan(RecordQueryInUnionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryInUnionOnValuesPlan(RecordQueryInUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryInUnionPlan(RecordQueryInUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryInValuesJoinPlan(RecordQueryInValuesJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryInValuesJoinPlan(RecordQueryInValuesJoinPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryInValuesJoinPlan(RecordQueryInValuesJoinPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryLoadByKeysPlan(RecordQueryLoadByKeysPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryLoadByKeysPlan(RecordQueryLoadByKeysPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryLoadByKeysPlan(RecordQueryLoadByKeysPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryMapPlan(RecordQueryMapPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryMapPlan(RecordQueryMapPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryMapPlan(RecordQueryMapPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryPredicatesFilterPlan(RecordQueryPredicatesFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryPredicatesFilterPlan(RecordQueryPredicatesFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryPredicatesFilterPlan(RecordQueryPredicatesFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryRangePlan(RecordQueryRangePlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryRangePlan(RecordQueryRangePlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryRangePlan(RecordQueryRangePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryRecursiveUnionPlan(RecordQueryRecursiveUnionPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryRecursiveUnionPlan(RecordQueryRecursiveUnionPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryRecursiveUnionPlan(RecordQueryRecursiveUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryScanPlan(RecordQueryScanPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryScanPlan(RecordQueryScanPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryScanPlan(RecordQueryScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.ComparisonsProperty
 
visitRecordQuerySelectorPlan(RecordQuerySelectorPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQuerySelectorPlan(RecordQuerySelectorPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQuerySelectorPlan(RecordQuerySelectorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQuerySortPlan(RecordQuerySortPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQuerySortPlan(RecordQuerySortPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQuerySortPlan(RecordQuerySortPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryStreamingAggregationPlan(RecordQueryStreamingAggregationPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryStreamingAggregationPlan(RecordQueryStreamingAggregationPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryStreamingAggregationPlan(RecordQueryStreamingAggregationPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryTextIndexPlan(RecordQueryTextIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryTextIndexPlan(RecordQueryTextIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryTextIndexPlan(RecordQueryTextIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryTextIndexPlan(RecordQueryTextIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.ComparisonsProperty
 
visitRecordQueryTypeFilterPlan(RecordQueryTypeFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryTypeFilterPlan(RecordQueryTypeFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryTypeFilterPlan(RecordQueryTypeFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryUnionOnKeyExpressionPlan(RecordQueryUnionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryUnionOnKeyExpressionPlan(RecordQueryUnionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryUnionOnKeyExpressionPlan(RecordQueryUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.NormalizedResidualPredicateProperty
 
visitRecordQueryUnorderedDistinctPlan(RecordQueryUnorderedDistinctPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryUnorderedDistinctPlan(RecordQueryUnorderedDistinctPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryUnorderedDistinctPlan(RecordQueryUnorderedDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryUnorderedPrimaryKeyDistinctPlan(RecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryUnorderedPrimaryKeyDistinctPlan(RecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryUnorderedPrimaryKeyDistinctPlan(RecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryUnorderedUnionPlan(RecordQueryUnorderedUnionPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryUnorderedUnionPlan(RecordQueryUnorderedUnionPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryUnorderedUnionPlan(RecordQueryUnorderedUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecordQueryUpdatePlan(RecordQueryUpdatePlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecordQueryUpdatePlan(RecordQueryUpdatePlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecordQueryUpdatePlan(RecordQueryUpdatePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecursiveUnionExpression(RecursiveUnionExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitRecursiveUnionExpression(RecursiveUnionExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitRecursiveUnionExpression(RecursiveUnionExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitRecursiveUnionPlan(RecordQueryRecursiveUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitRecursiveUnionPlan(RecordQueryRecursiveUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitRecursiveUnionPlan(RecordQueryRecursiveUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitRecursiveUnionPlan(RecordQueryRecursiveUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitRecursiveUnionPlan(RecordQueryRecursiveUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitRecursiveUnionPlan(RecordQueryRecursiveUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitRecursiveUnionPlan(RecordQueryRecursiveUnionPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitRecursiveUnionPlan(RecordQueryRecursiveUnionPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitScanPlan(RecordQueryScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitScanPlan(RecordQueryScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitScanPlan(RecordQueryScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitScanPlan(RecordQueryScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitScanPlan(RecordQueryScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitScanPlan(RecordQueryScanPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitScanPlan(RecordQueryScanPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitScanPlan(RecordQueryScanPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitScoreForRankPlan(RecordQueryScoreForRankPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitSelectExpression(SelectExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitSelectExpression(SelectExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitSelectExpression(SelectExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitSelectorPlan(RecordQuerySelectorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitSelectorPlan(RecordQuerySelectorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitSelectorPlan(RecordQuerySelectorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitSelectorPlan(RecordQuerySelectorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitSelectorPlan(RecordQuerySelectorPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitSelectorPlan(RecordQuerySelectorPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitSelectorPlan(RecordQuerySelectorPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitSelectorPlan(RecordQuerySelectorPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitSortPlan(RecordQuerySortPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitSortPlan(RecordQuerySortPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitSortPlan(RecordQuerySortPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitSortPlan(RecordQuerySortPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitSortPlan(RecordQuerySortPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitSortPlan(RecordQuerySortPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitSortPlan(RecordQuerySortPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitSortPlan(RecordQuerySortPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitStreamingAggregationPlan(RecordQueryStreamingAggregationPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitStreamingAggregationPlan(RecordQueryStreamingAggregationPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitStreamingAggregationPlan(RecordQueryStreamingAggregationPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitStreamingAggregationPlan(RecordQueryStreamingAggregationPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitStreamingAggregationPlan(RecordQueryStreamingAggregationPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitStreamingAggregationPlan(RecordQueryStreamingAggregationPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitStreamingAggregationPlan(RecordQueryStreamingAggregationPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitStreamingAggregationPlan(RecordQueryStreamingAggregationPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitTempTableInsertExpression(TempTableInsertExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitTempTableInsertExpression(TempTableInsertExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitTempTableInsertExpression(TempTableInsertExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitTempTableInsertPlan(TempTableInsertPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitTempTableInsertPlan(TempTableInsertPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitTempTableInsertPlan(TempTableInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitTempTableInsertPlan(TempTableInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitTempTableInsertPlan(TempTableInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitTempTableInsertPlan(TempTableInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitTempTableInsertPlan(TempTableInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitTempTableInsertPlan(TempTableInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitTempTableInsertPlan(TempTableInsertPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitTempTableInsertPlan(TempTableInsertPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitTempTableInsertPlan(TempTableInsertPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitTempTableScanExpression(TempTableScanExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitTempTableScanExpression(TempTableScanExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitTempTableScanExpression(TempTableScanExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitTempTableScanPlan(TempTableScanPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitTempTableScanPlan(TempTableScanPlan) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitTempTableScanPlan(TempTableScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitTempTableScanPlan(TempTableScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitTempTableScanPlan(TempTableScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitTempTableScanPlan(TempTableScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitTempTableScanPlan(TempTableScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitTempTableScanPlan(TempTableScanPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitTempTableScanPlan(TempTableScanPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitTempTableScanPlan(TempTableScanPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitTempTableScanPlan(TempTableScanPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitTextIndexPlan(RecordQueryTextIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitTextIndexPlan(RecordQueryTextIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitTextIndexPlan(RecordQueryTextIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitTextIndexPlan(RecordQueryTextIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitTextIndexPlan(RecordQueryTextIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitTextIndexPlan(RecordQueryTextIndexPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitTextIndexPlan(RecordQueryTextIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitTextIndexPlan(RecordQueryTextIndexPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitToString(ExplainTokens.ToStringToken, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
visitToString(ExplainTokens.ToStringToken, CharSequence) - Method in class com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter
 
visitTypeFilterPlan(RecordQueryTypeFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitTypeFilterPlan(RecordQueryTypeFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitTypeFilterPlan(RecordQueryTypeFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitTypeFilterPlan(RecordQueryTypeFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitTypeFilterPlan(RecordQueryTypeFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitTypeFilterPlan(RecordQueryTypeFilterPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitTypeFilterPlan(RecordQueryTypeFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitTypeFilterPlan(RecordQueryTypeFilterPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitUnionOnKeyExpressionPlan(RecordQueryUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitUnionOnKeyExpressionPlan(RecordQueryUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitUnionOnKeyExpressionPlan(RecordQueryUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitUnionOnKeyExpressionPlan(RecordQueryUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitUnionOnKeyExpressionPlan(RecordQueryUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitUnionOnKeyExpressionPlan(RecordQueryUnionOnKeyExpressionPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitUnionOnKeyExpressionPlan(RecordQueryUnionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitUnionOnKeyExpressionPlan(RecordQueryUnionOnKeyExpressionPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitUnionOnValuesPlan(RecordQueryUnionOnValuesPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitUnorderedDistinctPlan(RecordQueryUnorderedDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitUnorderedDistinctPlan(RecordQueryUnorderedDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitUnorderedDistinctPlan(RecordQueryUnorderedDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitUnorderedDistinctPlan(RecordQueryUnorderedDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitUnorderedDistinctPlan(RecordQueryUnorderedDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitUnorderedDistinctPlan(RecordQueryUnorderedDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitUnorderedDistinctPlan(RecordQueryUnorderedDistinctPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitUnorderedDistinctPlan(RecordQueryUnorderedDistinctPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitUnorderedPrimaryKeyDistinctPlan(RecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitUnorderedPrimaryKeyDistinctPlan(RecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitUnorderedPrimaryKeyDistinctPlan(RecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitUnorderedPrimaryKeyDistinctPlan(RecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitUnorderedPrimaryKeyDistinctPlan(RecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitUnorderedPrimaryKeyDistinctPlan(RecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitUnorderedPrimaryKeyDistinctPlan(RecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitUnorderedPrimaryKeyDistinctPlan(RecordQueryUnorderedPrimaryKeyDistinctPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitUnorderedUnionPlan(RecordQueryUnorderedUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitUnorderedUnionPlan(RecordQueryUnorderedUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitUnorderedUnionPlan(RecordQueryUnorderedUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitUnorderedUnionPlan(RecordQueryUnorderedUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitUnorderedUnionPlan(RecordQueryUnorderedUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitUnorderedUnionPlan(RecordQueryUnorderedUnionPlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitUnorderedUnionPlan(RecordQueryUnorderedUnionPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitUnorderedUnionPlan(RecordQueryUnorderedUnionPlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitUpdateExpression(UpdateExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitor
 
visitUpdateExpression(UpdateExpression) - Method in interface com.apple.foundationdb.record.query.plan.cascades.expressions.RelationalExpressionVisitorWithDefaults
 
visitUpdateExpression(UpdateExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.CardinalitiesProperty
 
visitUpdatePlan(RecordQueryUpdatePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DerivationsProperty.DerivationsVisitor
 
visitUpdatePlan(RecordQueryUpdatePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.DistinctRecordsProperty.DistinctRecordsVisitor
 
visitUpdatePlan(RecordQueryUpdatePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.OrderingProperty.OrderingVisitor
 
visitUpdatePlan(RecordQueryUpdatePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.PrimaryKeyProperty.PrimaryKeyVisitor
 
visitUpdatePlan(RecordQueryUpdatePlan) - Method in class com.apple.foundationdb.record.query.plan.cascades.properties.StoredRecordProperty.StoredRecordVisitor
 
visitUpdatePlan(RecordQueryUpdatePlan) - Method in class com.apple.foundationdb.record.query.plan.explain.ExplainPlanVisitor
 
visitUpdatePlan(RecordQueryUpdatePlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitor
 
visitUpdatePlan(RecordQueryUpdatePlan) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanVisitorWithDefaults
 
visitWhitespace(ExplainTokens.WhitespaceToken, CharSequence) - Method in interface com.apple.foundationdb.record.query.plan.explain.ExplainFormatter
 
VL0 - Enum constant in enum com.apple.foundationdb.record.PlanHashable.PlanHashMode
 

W

WAIT_ADD_INDEX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for adding an index.
WAIT_ADVANCE_CURSOR - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for a synchronous RecordCursor.getNext().
WAIT_APPROXIMATE_TRANSACTION_SIZE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait to compute the approximate transaction size.
WAIT_BUILD_ENDPOINTS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for OnlineIndexer to build endpoints.
WAIT_CHECK_ONGOING_ONLINE_INDEX_BUILD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for OnlineIndexer to checking ongoing online index builds.
WAIT_CHECK_SYNC_SESSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for checking a synchronized session.
WAIT_CHECK_VERSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for check version on a record store.
WAIT_COLLECT_STATISTICS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for statistics to be collected.
WAIT_COMMIT - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for a transaction to commit.
WAIT_DELETE_RECORD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for deleting a record.
WAIT_DIRECTORY_RESOLVE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for resolving directory layer entries.
WAIT_DROP_INDEX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for dropping an index.
WAIT_EDIT_HEADER_USER_FIELD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for editing a header user field.
WAIT_ENABLE_SPLIT_LONG_RECORDS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for enabling splitting long records.
WAIT_END_SYNC_SESSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for ending a synchronized session.
WAIT_ERROR_CHECK - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
A fake wait for a future already known to be completed.
WAIT_ESTIMATE_SIZE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait to estimate the size of a key range.
WAIT_EXECUTE_QUERY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for query execution to complete.
WAIT_GET_BOUNDARY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for getting boundaries.
WAIT_GET_INDEX_BUILD_STATE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for getting index build state.
WAIT_GET_READ_VERSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for explicit call to FDBRecordContext.getReadVersionAsync().
WAIT_INDEX_OPERATION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for an IndexOperation to complete.
WAIT_INDEX_TYPESTAMP_OPERATION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for indexing type stamp operation.
WAIT_INIT_SYNC_SESSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for initializing a synchronized session.
WAIT_KEYSPACE_CLEAR - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for clearing a KeySpace.
WAIT_KEYSPACE_LIST - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for listing a KeySpace.
WAIT_KEYSPACE_PATH_RESOLVE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for resolving the path for a KeySpace.
WAIT_KEYSPACE_SCAN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for scanning a KeySpace to see whether it has data.
WAIT_LOAD_LUCENE_PARTITION_METADATA - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
wait to load partition metadata for one or more grouping key.
WAIT_LOAD_META_DATA - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for loading meta-data from a FDBMetaDataStore.
WAIT_LOAD_RECORD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for loading a record.
WAIT_LOAD_RECORD_STORE_STATE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for loading RecordStoreState.
WAIT_LOAD_RECORD_VERSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for loading a record's version.
WAIT_LOAD_SYSTEM_KEY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait to read a key from the FDB system keyspace.
WAIT_LOCATABLE_RESOLVER_COMPUTE_DIGEST - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for a ResolverMappingDigest to be computed.
WAIT_LOCATABLE_RESOLVER_MAPPING_COPY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for ResolverMappingReplicator to copy a directory layer.
WAIT_META_DATA_VERSION_STAMP - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait to load the the cluster's meta-data version stamp.
WAIT_MUTATE_METADATA - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for meta-data mutation.
WAIT_ONLINE_BUILD_INDEX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for OnlineIndexer to complete building an index.
WAIT_ONLINE_MERGE_INDEX - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for OnlineIndexer to complete ongoing online index merge(s).
WAIT_PERFORM_NO_OP - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for performing a no-op operation.
WAIT_RECORD_EXISTS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait to check if a record exists.
WAIT_RETRY_DELAY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
WAIT_REVERSE_DIRECTORY_LOCATE - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for finding reverse directory location.
WAIT_REVERSE_DIRECTORY_LOOKUP - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for a reverse directory lookup.
WAIT_REVERSE_DIRECTORY_SCAN - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for a reverse directory scan.
WAIT_SAVE_META_DATA - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for saving meta-data to a FDBMetaDataStore.
WAIT_SAVE_RECORD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for saving a record.
WAIT_SCAN_INDEX_RECORDS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for a indexed record scan.
WAIT_SCAN_RECORDS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for a record scan without an index.
WAIT_SET_STATE_CACHEABILITY - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for setting the store state cacheability.
WAIT_STOP_ONLINE_INDEX_BUILD - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for OnlineIndexer to stop ongoing online index builds.
WAIT_UPDATE_RECORDS_DESCRIPTOR - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for updating records descriptor.
WAIT_UPDATE_STORE_RECORD_VERSIONS - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for updating if record versions should be stored.
WAIT_VALIDATE_RESOLVER - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait to perform validation of resolver reverse directory mapping.
WAIT_VERSION_STAMP - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Waits
Wait for the updated version stamp from a committed transaction.
waitTimeMilliseconds() - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexingThrottle
 
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 - Enum constant in enum com.apple.foundationdb.record.CursorStreamingMode
The client will load all records immediately, such as with RecordCursor.asList().
WARN_COMPLETE_EXCEPTION_BLOCKING - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
When asyncToSync() 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 - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.BlockingInAsyncDetection
When asyncToSync() 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.
wasBlocked() - Method in exception com.apple.foundationdb.record.provider.foundationdb.IndexingBase.PartlyBuiltException
 
watch(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.InstrumentedTransaction
 
watch(byte[]) - Method in class com.apple.foundationdb.record.provider.foundationdb.KeyCheckingTransaction
 
WeakReadSemantics(long, long, boolean) - Constructor for class com.apple.foundationdb.record.provider.foundationdb.FDBDatabase.WeakReadSemantics
 
when(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap.Builder
 
When(CorrelationIdentifier) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap.Builder.When
 
whenAll(List<S>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
 
whenAny(Iterable<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap.Builder
 
whenAny(List<S>) - Static method in class com.apple.foundationdb.record.provider.foundationdb.cursors.MergeCursor
 
WhenAny(Iterable<CorrelationIdentifier>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.translation.TranslationMap.Builder.WhenAny
 
where(BindingMatcher<? super T>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
Combinator to constrain the current matcher with the downstream matcher passed in.
where(BindingMatcher<? super T>...) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
Combinator to constrain the current matcher with the downstream matchers passed in.
where(Collection<? extends BindingMatcher<? super T>>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.matching.structure.BindingMatcher
Combinator to constrain the current matcher with the downstream matchers passed in.
where(Predicate<PlanPartition>, BindingMatcher<? extends Iterable<? extends PlanPartition>>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.structure.ReferenceMatchers
 
WHITE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
WHITESPACE - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokens.TokenKind
 
WhitespaceToken(int) - Constructor for class com.apple.foundationdb.record.query.plan.explain.ExplainTokens.WhitespaceToken
 
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
 
WIDENED_TUPLE_RANGE - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 
WindowedIndexExpansionVisitor - Class in com.apple.foundationdb.record.query.plan.cascades
Class to expand a by-rank index access into a candidate graph.
WindowedIndexExpansionVisitor(Index, Collection<RecordType>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexExpansionVisitor
 
WindowedIndexScanMatchCandidate - Class in com.apple.foundationdb.record.query.plan.cascades
Case class to represent a match candidate that is backed by a windowed index such as a rank index.
WindowedIndexScanMatchCandidate(Index, Collection<RecordType>, Traversal, Type, CorrelationIdentifier, List<CorrelationIdentifier>, CorrelationIdentifier, CorrelationIdentifier, List<CorrelationIdentifier>, List<Value>, KeyExpression, KeyExpression) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.WindowedIndexScanMatchCandidate
 
WindowedValue - Class in com.apple.foundationdb.record.query.plan.cascades.values
A value merges the input messages given to it into an output message.
WindowedValue(PlanSerializationContext, PWindowedValue) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
WindowedValue(Iterable<? extends Value>, Iterable<? extends Value>) - Constructor for class com.apple.foundationdb.record.query.plan.cascades.values.WindowedValue
 
with(ComparisonRanges, List<QueryComponent>, List<QueryComponent>, Set<Comparisons.Comparison>, int, boolean, boolean, boolean, Set<RankComparisons.RankComparison>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredMatch
 
with(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue
 
with(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConstantObjectValue
 
with(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NullValue
 
with(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedObjectValue
 
with(Type) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.QuantifiedRecordValue
 
with(Type) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
 
with(RecordQueryPlan, List<QueryComponent>, List<QueryComponent>, Set<Comparisons.Comparison>, int, boolean, boolean, boolean, Set<RankComparisons.RankComparison>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredPlan
 
with(Function<ExecuteProperties, ExecuteProperties>) - Method in class com.apple.foundationdb.record.ScanProperties
Change execute properties.
with(T, List<QueryComponent>, List<QueryComponent>, Set<Comparisons.Comparison>, int, boolean, boolean, boolean, Set<RankComparisons.RankComparison>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
WITH_VERSION - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBRecordStoreBase.VersionstampSaveBehavior
Always save the record with a version.
withAdditionalCondition(QueryComponent) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
 
withAdditionalIndexFilters(List<QueryComponent>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
withAlias(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.Quantifier.Builder
 
WithAlias - Interface in com.apple.foundationdb.record.query.plan.cascades.predicates
Trait for providing alias information.
withAliasMap(AliasMap) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BoundMatch
Factory method to create a bound match with no match result.
withAliasMapAndMatchResult(AliasMap, R) - Static method in class com.apple.foundationdb.record.query.plan.cascades.matching.graph.BoundMatch
Factory method to create a bound match with a proper match result.
withAtomicity(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
withAtomicity(boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.LeafQueryPredicate
 
withAtomicity(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
withAtomicity(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
withAtomicity(boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicate
 
withBase(Quantifier.ForEach) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
withBaseAlias(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor.ScalarVisitorState
 
withBaseQuantifier(Quantifier.ForEach) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
WithBaseQuantifierMatchCandidate - Interface in com.apple.foundationdb.record.query.plan.cascades
Trait to implement some default logic for MatchCandidates that are defined using a base quantifier, that is, match candidates that are not true join indexes.
withBinding(Bindings.Internal, CorrelationIdentifier, Object) - Method in class com.apple.foundationdb.record.EvaluationContext
Create a new EvaluationContext with an additional binding.
withBinding(String, Object) - Method in class com.apple.foundationdb.record.EvaluationContext
Create a new EvaluationContext with an additional binding.
withChild(QueryPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.NotPredicate
 
withChild(QueryPredicate) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicateWithChild
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDefaultOnEmptyPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryDeletePlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFetchFromPartialRecordPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFilterPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryFirstOrDefaultPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInComparandJoinPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInParameterJoinPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInsertPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInValuesJoinPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryMapPlan
 
withChild(Reference) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQueryPlanWithChild
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryPredicatesFilterPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryScoreForRankPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryStreamingAggregationPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryTypeFilterPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedDistinctPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnorderedPrimaryKeyDistinctPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUpdatePlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.plans.TempTableInsertPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQueryDamPlan
 
withChild(Reference) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortPlan
 
withChildren(Iterable<? extends QueryPredicate>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.AndPredicate
 
withChildren(Iterable<? extends QueryPredicate>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.LeafQueryPredicate
 
withChildren(Iterable<? extends QueryPredicate>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.OrPredicate
 
withChildren(Iterable<? extends QueryPredicate>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.predicates.QueryPredicateWithChild
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AbstractArrayConstructorValue.LightArrayConstructorValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.AndOrValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ArithmeticValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CollateValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ConditionSelectorValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.CountValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.DerivedValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FirstOrDefaultValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.InOpValue
 
withChildren(Iterable<? extends Value>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.LeafValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.LikeOperatorValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PatternForLikeValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PickValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RankValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordConstructorValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RecordTypeValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.BinaryRelOpValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.RelOpValue.UnaryRelOpValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.UdfValue
 
withChildren(Iterable<? extends Value>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.ValueWithChild
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VariadicFunctionValue
 
withChildren(Iterable<? extends Value>) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.VersionValue
 
withChildren(Iterable<? extends N>) - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNode
 
withChildren(Iterable<? extends N>) - Method in class com.apple.foundationdb.record.util.TrieNode.AbstractTrieNodeBuilder
 
withChildren(Iterable<? extends T>) - Method in interface com.apple.foundationdb.record.query.plan.cascades.TreeLike
Recreate the current treelike object with a new list of children.
withChildrenReferences(List<? extends Reference>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnKeyExpressionPlan
 
withChildrenReferences(List<? extends Reference>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIntersectionOnValuesPlan
 
withChildrenReferences(List<? extends Reference>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnKeyExpressionPlan
 
withChildrenReferences(List<? extends Reference>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryInUnionOnValuesPlan
 
withChildrenReferences(List<? extends Reference>) - Method in interface com.apple.foundationdb.record.query.plan.plans.RecordQuerySetPlan
Method to create a new set-based plan operator that mirrors the attributes of this except its children which are replaced with new children.
withChildrenReferences(List<? extends Reference>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnKeyExpressionPlan
 
withChildrenReferences(List<? extends Reference>) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryUnionOnValuesPlan
 
withChildrenReferences(List<? extends Reference>) - 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.Comparison) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
 
withComparison(Comparisons.Comparison) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.Value
Method to create a QueryPredicate that is based on this value and a Comparisons.Comparison that is passed in by the caller.
withComparison(Comparisons.Type, Object) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
 
withComparisons(ScanComparisons, List<ScanComparisons>, ScanComparisons) - Method in class com.apple.foundationdb.record.provider.foundationdb.MultidimensionalIndexScanComparisons
 
withComparisons(List<Comparisons.Comparison>, Set<Comparisons.Comparison>) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons.Builder
 
withComparisons(List<Comparisons.Comparison>, Set<Comparisons.Comparison>) - Method in class com.apple.foundationdb.record.query.plan.ScanComparisons
 
withComputed(Object) - Method in class com.apple.foundationdb.record.query.plan.plans.QueryResult
 
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.ScoredInfo
 
withCurrentOrdinal(int) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
withDebugger(Consumer<Debugger>) - Static method in interface com.apple.foundationdb.record.query.plan.cascades.debug.Debugger
Invoke the Consumer on the currently set debugger.
withDistinctness(RequestedOrdering.Distinctness) - Method in class com.apple.foundationdb.record.query.plan.cascades.RequestedOrdering
 
withExtraRanges(Set<RangeConstraints>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
withFieldNamePrefix(List<String>) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
withFieldNamePrefix(List<String>) - Method in class com.apple.foundationdb.record.query.plan.cascades.ScalarTranslationVisitor.ScalarVisitorState
 
withFiltersAndSargedComparisons(List<QueryComponent>, List<QueryComponent>, Set<Comparisons.Comparison>, boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
withFunction(RecordFunction<T>) - Method in class com.apple.foundationdb.record.query.expressions.QueryRecordFunction
 
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.
withIndexFilters(List<QueryComponent>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
withIndexScanParameters(IndexScanParameters) - Method in class com.apple.foundationdb.record.query.plan.plans.RecordQueryIndexPlan
 
withInfo(T) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
withInvertibleFunction(String) - Method in class com.apple.foundationdb.record.query.plan.AvailableFields.FieldData
 
withIsInternalExpansion(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
withLimit(int) - Static method in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
Obtain a normalizer with the given size limit.
withLimit(BooleanPredicateNormalizer.Mode, int) - Static method in class com.apple.foundationdb.record.query.plan.planning.BooleanPredicateNormalizer
Obtain a normalizer with the given size limit.
withMajor(Class<P>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.AbsorptionRule
 
withMajor(Class<P>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.DeMorgansTheoremRule
 
withName(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record.Field
Returns a new field with a new name.
withName(String) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
withNestedOrdinal(int) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor.State
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FromOrderedBytesValue
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MaxEverValue
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.IndexOnlyAggregateValue.MinEverValue
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NotValue
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Avg
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.BitmapConstructAgg
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Max
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Min
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.NumericAggregationValue.Sum
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.OfTypeValue
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.PromoteValue
 
withNewChild(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.ToOrderedBytesValue
 
withNewChild(Value) - Method in interface com.apple.foundationdb.record.query.plan.cascades.values.ValueWithChild
 
withNewExpressions(List<KeyExpression>, KeyExpression) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
 
withNewGroupingKeyExpression(GroupingKeyExpression) - Method in class com.apple.foundationdb.record.metadata.IndexAggregateFunctionCall
 
withNextValue(T, RecordCursorContinuation) - Static method in class com.apple.foundationdb.record.RecordCursorResult
Create a new RecordCursorResult that has a value, using the given value and continuation.
withNullability(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Any
 
withNullability(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.AnyRecord
 
withNullability(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Array
 
withNullability(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Enum
 
withNullability(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.None
 
withNullability(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Null
 
withNullability(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Primitive
 
withNullability(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Record
 
withNullability(boolean) - Method in class com.apple.foundationdb.record.query.plan.cascades.typing.Type.Relation
 
withNullability(boolean) - Method in interface com.apple.foundationdb.record.query.plan.cascades.typing.Type
Create a new type based on the current one that indicates nullability based on the isNullable parameter passed in.
withOrdinal(int, int) - Method in class com.apple.foundationdb.record.query.plan.ExpressionToTuplePathVisitor.State
 
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.QueryKeyExpressionWithOneOfComparison
 
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 new RecordCursorResult that 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 a RecordCursorResult to 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
 
withParameterRelationshipMap(ParameterRelationshipGraph) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
withParameterRelationshipMap(ParameterRelationshipGraph) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
 
withParameterRelationshipMap(ParameterRelationshipGraph) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
withParameterRelationshipMap(ParameterRelationshipGraph) - Method in interface com.apple.foundationdb.record.query.expressions.ComponentWithChildren
 
withParameterRelationshipMap(ParameterRelationshipGraph) - Method in interface com.apple.foundationdb.record.query.expressions.ComponentWithComparison
 
withParameterRelationshipMap(ParameterRelationshipGraph) - Method in interface com.apple.foundationdb.record.query.expressions.ComponentWithSingleChild
 
withParameterRelationshipMap(ParameterRelationshipGraph) - Method in interface com.apple.foundationdb.record.query.expressions.QueryComponent
 
withPredicate(QueryPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.GraphExpansion
 
WithPrimaryKeyMatchCandidate - Interface in com.apple.foundationdb.record.query.plan.cascades
Interface to represent a candidate that uses a primary key to identify a record.
withRanges(Set<RangeConstraints>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
withRanges(Set<RangeConstraints>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
withResidualFilterAndSargedComparisons(List<QueryComponent>, Set<Comparisons.Comparison>, boolean) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
withRoot(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Quantifiers.AliasResolver
 
withRoot(Reference) - Static method in class com.apple.foundationdb.record.query.plan.cascades.Traversal
Construct a traversal object using the rootRef reference passed in.
withSargedComparisons(Set<Comparisons.Comparison>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
withScanComparisons(ScanComparisons) - Method in class com.apple.foundationdb.record.provider.foundationdb.IndexScanComparisons
 
withScanComparisons(ScanComparisons) - Method in class com.apple.foundationdb.record.provider.foundationdb.leaderboard.TimeWindowScanComparisons
 
withScore(int) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
withSplitPointForValues(int) - Method in class com.apple.foundationdb.record.query.plan.cascades.KeyExpressionExpansionVisitor.VisitorState
 
withSubspace(Subspace) - Static method in class com.apple.foundationdb.record.provider.foundationdb.KeyValueCursor.Builder
 
withSuffix(FieldValue.FieldPath) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.FieldValue.FieldPath
 
withSuffix(FieldValue.FieldPath) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.FieldValueCompensation
 
withTranslatedCorrelation(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
 
withTranslatedCorrelation(CorrelationIdentifier) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparisonBase
 
withTranslatedQueryPredicate(QueryPredicate) - Method in class com.apple.foundationdb.record.query.plan.cascades.PredicateMultiMap.PredicateMapping
 
withType(Comparisons.Type) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
withType(Comparisons.Type) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
 
withType(Comparisons.Type) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ListComparison
 
withType(Comparisons.Type) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
withType(Comparisons.Type) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.NullComparison
 
withType(Comparisons.Type) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.OpaqueEqualityComparison
 
withType(Comparisons.Type) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ParameterComparison
 
withType(Comparisons.Type) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparison
 
withType(Comparisons.Type) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.TextComparison
 
withType(Comparisons.Type) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
withType(Comparisons.Type) - Method in class com.apple.foundationdb.record.query.expressions.RecordTypeKeyComparison.RecordTypeComparison
 
withUnsatisfiedFilters(List<QueryComponent>) - Method in class com.apple.foundationdb.record.query.plan.RecordQueryPlanner.ScoredInfo
 
withUpdatedLimit(int) - Method in class com.apple.foundationdb.record.query.plan.planning.BooleanNormalizer
 
withValue(Value) - Method in interface com.apple.foundationdb.record.query.expressions.Comparisons.Comparison
 
withValue(Value) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.InvertedFunctionComparison
 
withValue(Value) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.MultiColumnComparison
 
withValue(Value) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.SimpleComparisonBase
 
withValue(Value) - Method in class com.apple.foundationdb.record.query.expressions.Comparisons.ValueComparison
 
withValue(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
withValue(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
withValue(Value) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.ValuePredicate
 
withValue(Value) - Method in interface com.apple.foundationdb.record.query.plan.cascades.WithValue
 
WithValue<T extends WithValue<T>> - Interface in com.apple.foundationdb.record.query.plan.cascades
Trait for classes containing a Value.
withValueAndRanges(Value, Set<RangeConstraints>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.Placeholder
 
withValueAndRanges(Value, Set<RangeConstraints>) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.PredicateWithValueAndRanges
 
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 this RecordStoreState, but with additional IndexState.WRITE_ONLY indexes.
wrap(byte[]) - Static method in class com.google.protobuf.ZeroCopyByteString
 
wrap(byte[], int, int) - Static method in class com.google.protobuf.ZeroCopyByteString
 
wrap(KeySpacePath) - Method in class com.apple.foundationdb.record.provider.foundationdb.keyspace.KeySpaceDirectory
If a wrapper was installed for this directory, the provided path will be wrapped by the wrapper and returned, otherwise the original path is 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
 
wrap(T) - Static method in class com.apple.foundationdb.record.query.plan.cascades.IdentityBiMap
 
wrapContinuation(RecordCursorContinuation) - Method in interface com.apple.foundationdb.record.RecordCursor.ContinuationConvertor
Transform a continuation that came from an existing cursor.
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(FDBRecord<M>, CodedOutputStream) - Method in class com.apple.foundationdb.record.provider.foundationdb.SortedRecordSerializer
 
WRITE_ONLY - Enum constant in enum 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
Utility method to be used to specify that new indexes should be IndexState.WRITE_ONLY if an index is not on new record types and there are too many records to build in-line.
writeOnlyMap(List<String>) - Method in class com.apple.foundationdb.record.RecordStoreState
 
WRITES - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBStoreTimer.Counts
Total number of write operations.
writeSortKeyAndRecord(Tuple, FDBRecord<M>, CodedOutputStream) - Method in class com.apple.foundationdb.record.provider.foundationdb.SortedRecordSerializer
 
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 a ByteBuffer.
writeValidationRatio - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer.Builder
 
writeValidationRatio - Variable in class com.apple.foundationdb.record.provider.common.TransformedRecordSerializer
 
writeValue(FDBQueriedRecord<M>, CodedOutputStream) - Method in class com.apple.foundationdb.record.query.plan.sorting.RecordQuerySortAdapter
 
writeValue(V, CodedOutputStream) - Method in interface com.apple.foundationdb.record.sorting.FileSortAdapter
Write the value to a Protobuf stream.
WROTE_INDEX - Enum constant in enum com.apple.foundationdb.record.logging.LogMessageKeys
 

X

XML - Enum constant in enum com.apple.foundationdb.record.provider.foundationdb.FDBTraceFormat
Format the trace logs as XML.
XOR - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.ExplainTokensWithPrecedence.Precedence
 

Y

YELLOW - Enum constant in enum com.apple.foundationdb.record.query.plan.explain.PrettyExplainFormatter.Color
 
YIELD - Enum constant in enum com.apple.foundationdb.record.query.plan.cascades.debug.Debugger.Location
 
yieldAndReExplore(RESULT) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
yieldExpression(RelationalExpression) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
yieldExpression(Reference) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
yieldExpression(Set<? extends RelationalExpression>) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
 
yieldExpression(R) - Method in interface com.apple.foundationdb.record.query.plan.cascades.PlannerRuleCall
Notify the planner's data structures that a new result contained in result has been produced by the rule.
yieldExpression(RESULT) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.AbstractRuleCall
 
yieldPartialMatch(AliasMap, MatchCandidate, RelationalExpression, Reference, MatchInfo) - Method in class com.apple.foundationdb.record.query.plan.cascades.CascadesRuleCall
Notify the planner's data structures that a new partial match has been produced by the rule.
yieldPredicate(QueryPredicate, RESULT) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateComputationRuleCall
 
yieldPredicateAndReExplore(QueryPredicate, RESULT) - Method in class com.apple.foundationdb.record.query.plan.cascades.predicates.simplification.QueryPredicateComputationRuleCall
 
yieldValue(Value, RESULT) - Method in class com.apple.foundationdb.record.query.plan.cascades.values.simplification.ValueComputationRuleCall
 

Z

ZeroCopyByteString - Class in com.google.protobuf
Use this as a way to use existing byte arrays when converting to ByteString for protobuf conversion.
ZeroCopyByteString() - Constructor for class com.google.protobuf.ZeroCopyByteString
 
zip(List<CorrelationIdentifier>, List<CorrelationIdentifier>) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap.Builder
Method to update the builder to additionally contain the zip of two parallel lists of aliases.
zip(List<CorrelationIdentifier>, List<CorrelationIdentifier>) - Static method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap
Factory method to create an alias map based on a zip of two parallel lists of aliases.
zip(List<CorrelationIdentifier>, List<CorrelationIdentifier>, int) - Method in class com.apple.foundationdb.record.query.plan.cascades.AliasMap.Builder
Method to update the builder to additionally contain the zip of two parallel lists of aliases.
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 and Interfaces|All Packages|Constant Field Values|Serialized Form