Index

A B C D E F G H I J K L M N O P Q R S T U V W Y 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

AbstractMemorylessAggregationOperator<Domain,AggregateResult> - Class in tools.refinery.interpreter.matchers.psystem.aggregations
An aggregation operator that does not store interim results beyond the final aggregated value.
AbstractMemorylessAggregationOperator() - Constructor for class tools.refinery.interpreter.matchers.psystem.aggregations.AbstractMemorylessAggregationOperator
 
AbstractQueryMetaContext - Class in tools.refinery.interpreter.matchers.context
Common abstract class for implementers of IQueryMetaContext
AbstractQueryMetaContext() - Constructor for class tools.refinery.interpreter.matchers.context.AbstractQueryMetaContext
 
AbstractQueryRuntimeContext - Class in tools.refinery.interpreter.matchers.context
This class is intended to be extended by implementors.
AbstractQueryRuntimeContext() - Constructor for class tools.refinery.interpreter.matchers.context.AbstractQueryRuntimeContext
 
AbstractRewriterTraceSource - Class in tools.refinery.interpreter.matchers.psystem.rewriters
 
AbstractRewriterTraceSource() - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.AbstractRewriterTraceSource
 
AbstractTransitiveClosure - Class in tools.refinery.interpreter.matchers.psystem.basicenumerables
 
AbstractTransitiveClosure(PBody, Tuple, PQuery) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicenumerables.AbstractTransitiveClosure
 
AbstractTuple - Class in tools.refinery.interpreter.matchers.tuple
Common implementation methods for immutable and volatile tuples.
AbstractTuple() - Constructor for class tools.refinery.interpreter.matchers.tuple.AbstractTuple
 
Accuracy - Enum Class in tools.refinery.interpreter.matchers.util
The degree of accuracy of a cardinality estimate
actualParametersTuple - Variable in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternCallBasedDeferred
 
add(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
add(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
add(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
add(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Adds a tuple occurrence to the memory.
add(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
add(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
add(Tuple, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
add(Tuple, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
add(Tuple, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Adds a tuple occurrence to the memory with the given signature.
add(Tuple, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
add(Tuple, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
addAll(Collection<? extends Long>) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
addAnnotation(PAnnotation) - Method in interface tools.refinery.interpreter.matchers.psystem.InitializablePQuery
Adds an annotation to the specification.
addAnnotation(PAnnotation) - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
addAttribute(String, Object) - Method in class tools.refinery.interpreter.matchers.psystem.annotations.PAnnotation
Adds an attribute to the annotation
addBaseIndexChangeListener(InterpreterBaseIndexChangeListener) - Method in interface tools.refinery.interpreter.api.scope.IBaseIndex
Adds a coarse-grained listener that will be invoked after the NavigationHelper index or the underlying model is changed.
addDynamicSurrogateQueryForFeature(IInputKey, PQuery) - Method in class tools.refinery.interpreter.matchers.context.surrogate.SurrogateQueryRegistry
 
addDynamicSurrogateQueryForFeature(IInputKey, IProvider<PQuery>) - Method in class tools.refinery.interpreter.matchers.context.surrogate.SurrogateQueryRegistry
 
addError(PProblem) - Method in interface tools.refinery.interpreter.matchers.psystem.InitializablePQuery
Adds a detected error.
addError(PProblem) - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
addFoldingState(Tuple, TimelyMemory.FoldingState, Timestamp) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
Registers the given folding state for the specified timestamp and tuple.
addIndexingErrorListener(IIndexingErrorListener) - Method in interface tools.refinery.interpreter.api.scope.IBaseIndex
Adds a listener for internal errors in the index.
addInstanceObserver(IInstanceObserver, Object) - Method in interface tools.refinery.interpreter.api.scope.IBaseIndex
Register a lightweight observer that is notified if any edge starting at the given Object changes.
addInternal(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
addInternal(Object, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
addInternal(Tuple, Object) - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
addLifecycleListener(InterpreterEngineLifecycleListener) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Add an engine lifecycle listener to this engine instance.
addLifecycleListener(InterpreterEngineLifecycleListener) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
addListener(Listener) - Method in class tools.refinery.interpreter.internal.engine.ListenerContainer
 
addMatchUpdateListener(InterpreterMatcher<Match>, IMatchUpdateListener<? super Match>, boolean) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Registers low-level callbacks for match appearance and disappearance on this pattern matcher.
addMatchUpdateListener(InterpreterMatcher<Match>, IMatchUpdateListener<? super Match>, boolean) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
addModelUpdateListener(InterpreterModelUpdateListener) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Add an model update event listener to this engine instance (that fires its callbacks according to its notification level).
addModelUpdateListener(InterpreterModelUpdateListener) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
addOne(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
addOne(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
addOne(T) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsDeltaBag
 
addOne(T) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsMultiset
 
addOne(T) - Method in interface tools.refinery.interpreter.matchers.util.IMemory
Adds one value occurrence to the memory.
addOne(Value) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
addPair(Key, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Adds key-value pair to the lookup structure, or fails if not possible.
addPair(Key, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
addPairInternal(Key, Value, boolean) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
addPairOrNop(Key, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Adds key-value pair to the lookup structure.
addPairOrNop(Key, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
addPairPositiveMultiplicity(Key, Value, int) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Updates multiplicity of key-value pair by a positive amount.
addPairPositiveMultiplicity(Key, Value, int) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
addPositive(Long, int) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
addPositive(T, int) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsMultiset
 
addPositive(T, int) - Method in interface tools.refinery.interpreter.matchers.util.IMultiset
Adds the given number of occurrences to the memory.
addSigned(Long, int) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
addSigned(Long, int) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
addSigned(T, int) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsDeltaBag
 
addSigned(T, int) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsMultiset
 
addSigned(T, int) - Method in interface tools.refinery.interpreter.matchers.util.IMemory
Adds the given number of occurrences to the memory.
addSigned(Value, int) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
addToBucket(Bucket, Value, boolean) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
Increases the multiplicity of the value in the bucket.
addToBucket(MarkedMemory.MarkedMultiset<Value>, Value, boolean) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToMultisetsAbstract
 
addToBucket(MarkedMemory.MarkedSet<Value>, Value, boolean) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToSetsAbstract
 
addTrace(PTraceable, PTraceable) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.AbstractRewriterTraceSource
Mark the given derivative to be originated from the given original constraint.
addTrace(PTraceable, PTraceable) - Method in interface tools.refinery.interpreter.matchers.psystem.rewriters.IRewriterTraceCollector
Mark the given derivative to be originated from the given original constraint.
addTrace(PTraceable, PTraceable) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.MappingTraceCollector
 
addTrace(PTraceable, PTraceable) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.NopTraceCollector
 
addUpdateListener(IUpdateable, Object, boolean) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Internal method that registers low-level callbacks for match appearance and disappearance.
addUpdateListener(IInputKey, Tuple, IQueryRuntimeContextListener) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Subscribes for updates in the extensional relation identified by the input key, optionally seeded with the given tuple.
addWithTimestamp(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Adds a tuple occurrence to the memory with the given timestamp.
addWithTimestamp(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
addWithTimestamp(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
addWithTimestamp(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
addWithTimestamp(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
addWithTimestamp(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Adds a tuple occurrence to the memory with the given signature and timestamp.
addWithTimestamp(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
addWithTimestamp(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
addWithTimestamp(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
addWithTimestamp(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
AdvancedInterpreterEngine - Class in tools.refinery.interpreter.api
Advanced interface to a Refinery Interpreter incremental evaluation engine.
AdvancedInterpreterEngine() - Constructor for class tools.refinery.interpreter.api.AdvancedInterpreterEngine
 
aggregatedColumn - Variable in class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
aggregateStream(Stream<Domain>) - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IMultisetAggregationOperator
Calculates the aggregate results from a given stream of values; all values are considered as inserted
aggregateStream(Stream<Double>) - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleAverageOperator
 
aggregateStream(Stream<Double>) - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleSumOperator
 
aggregateStream(Stream<Integer>) - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerAverageOperator
 
aggregateStream(Stream<Integer>) - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerSumOperator
 
aggregateStream(Stream<Long>) - Method in class tools.refinery.interpreter.matchers.aggregators.LongAverageOperator
 
aggregateStream(Stream<Long>) - Method in class tools.refinery.interpreter.matchers.aggregators.LongSumOperator
 
aggregateStream(Stream<T>) - Method in class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator
 
AggregatorConstraint - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
The PSystem representation of an aggregation.
AggregatorConstraint(BoundAggregator, PBody, Tuple, PQuery, PVariable, int) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
AggregatorType - Annotation Interface in tools.refinery.interpreter.matchers.psystem.aggregations
The aggregator type annotation describes the type constraints for the selected aggregator.
AllowAllFilter() - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.IConstraintFilter.AllowAllFilter
 
ancestor - Variable in class tools.refinery.interpreter.matchers.tuple.BaseLeftInheritanceTuple
This object contains the same elements as the ancestor on the first inheritedIndex positions
And(IFlattenCallPredicate...) - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.IFlattenCallPredicate.And
 
append(TupleMask, TupleMask) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance that selects whatever is selected by left, and appends whatever is selected by right.
appendWithCancellation(Signed<Timestamp>) - Method in class tools.refinery.interpreter.matchers.util.timeline.Diff
 
apply(IProvider<PQuery>) - Method in class tools.refinery.interpreter.matchers.util.IProvider.ProvidedValueFunction
 
APPROXIMATION - Enum constant in enum class tools.refinery.interpreter.matchers.util.Accuracy
 
areAllVariablesDetermined(SubPlan, Collection<PVariable>, QueryAnalyzer, boolean) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.BuildHelper
 
areUpdatesDelayed() - Method in interface tools.refinery.interpreter.matchers.context.IQueryBackendContext
 
areVariablesDetermined(SubPlan, Collection<PVariable>, Collection<PVariable>, QueryAnalyzer, boolean) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.BuildHelper
 
arrayToMatch(Object[]) - Method in class tools.refinery.interpreter.api.GenericPatternMatcher
 
arrayToMatch(Object[]) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
Converts the array representation of a pattern match to an immutable Match object.
arrayToMatchMutable(Object[]) - Method in class tools.refinery.interpreter.api.GenericPatternMatcher
 
arrayToMatchMutable(Object[]) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
Converts the array representation of a pattern match to a mutable Match object.
asChangeSequence() - Method in class tools.refinery.interpreter.matchers.util.timeline.CompactTimeline
 
asChangeSequence() - Method in class tools.refinery.interpreter.matchers.util.timeline.SingletonTimeline
 
asChangeSequence() - Method in class tools.refinery.interpreter.matchers.util.timeline.Timeline
 
asMap() - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
For compatibility with legacy code relying on element-to-integer maps.
asMap() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
asSign() - Method in enum class tools.refinery.interpreter.matchers.util.Direction
 
asSingleton(Bucket) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
Checks whether the bucket is a singleton, i.e.
asSingleton(MarkedMemory.MarkedMultiset<Value>) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToMultisetsAbstract
 
asSingleton(MarkedMemory.MarkedSet<Value>) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToSetsAbstract
 
asStream() - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
 
atLeastAsPreciseAs(Accuracy) - Method in enum class tools.refinery.interpreter.matchers.util.Accuracy
Partial order comparison.
avg - Class in tools.refinery.interpreter.matchers.aggregators
This aggregator calculates the average of the values of a selected aggregate parameter of a called pattern.
avg() - Constructor for class tools.refinery.interpreter.matchers.aggregators.avg
 

B

backend - Variable in class tools.refinery.interpreter.internal.apiimpl.QueryResultWrapper
 
BaseFlatTuple - Class in tools.refinery.interpreter.matchers.tuple
Base class for all flat tuple implementations.
BaseFlatTuple() - Constructor for class tools.refinery.interpreter.matchers.tuple.BaseFlatTuple
 
BaseGeneratedPatternGroup - Class in tools.refinery.interpreter.api.impl
 
BaseGeneratedPatternGroup() - Constructor for class tools.refinery.interpreter.api.impl.BaseGeneratedPatternGroup
 
BaseInputKeyWrapper<Wrapped> - Class in tools.refinery.interpreter.matchers.context.common
An input key that is identified by a single wrapped object and the class of the wrapper.
BaseInputKeyWrapper(Wrapped) - Constructor for class tools.refinery.interpreter.matchers.context.common.BaseInputKeyWrapper
 
BaseLeftInheritanceTuple - Class in tools.refinery.interpreter.matchers.tuple
Common functionality of left inheritance tuple implementations.
BaseLeftInheritanceTuple(Tuple) - Constructor for class tools.refinery.interpreter.matchers.tuple.BaseLeftInheritanceTuple
 
BaseMatcher<Match> - Class in tools.refinery.interpreter.api.impl
Base implementation of ViatraQueryMatcher.
BaseMatcher(IQuerySpecification<? extends BaseMatcher<Match>>) - Constructor for class tools.refinery.interpreter.api.impl.BaseMatcher
 
BasePatternMatch - Class in tools.refinery.interpreter.api.impl
Base implementation of IPatternMatch.
BasePatternMatch() - Constructor for class tools.refinery.interpreter.api.impl.BasePatternMatch
 
BasePConstraint - Class in tools.refinery.interpreter.matchers.psystem
 
BasePConstraint(PBody, Set<PVariable>) - Constructor for class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
BasePQuery - Class in tools.refinery.interpreter.matchers.psystem.queries
Default implementation of PQuery.
BasePQuery(PVisibility) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
BaseQueryGroup - Class in tools.refinery.interpreter.api.impl
Base implementation of IQueryGroup.
BaseQueryGroup() - Constructor for class tools.refinery.interpreter.api.impl.BaseQueryGroup
 
BaseQuerySpecification<Matcher> - Class in tools.refinery.interpreter.api.impl
Base implementation of IQuerySpecification.
BaseQuerySpecification(PQuery) - Constructor for class tools.refinery.interpreter.api.impl.BaseQuerySpecification
Instantiates query specification for the given internal query representation.
BaseTypeSafeConstraint - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
 
BaseTypeSafeConstraint(PBody, Set<PVariable>, PVariable) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.BaseTypeSafeConstraint
 
BECAME_POSITIVE - Enum constant in enum class tools.refinery.interpreter.matchers.util.TimelyMemory.SignChange
 
BECAME_ZERO - Enum constant in enum class tools.refinery.interpreter.matchers.util.TimelyMemory.SignChange
 
BEST_LOWER_BOUND - Enum constant in enum class tools.refinery.interpreter.matchers.util.Accuracy
 
BEST_UPPER_BOUND - Enum constant in enum class tools.refinery.interpreter.matchers.util.Accuracy
 
binaryEdgeTypePlan(Tuple, Object) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
BinaryReflexiveTransitiveClosure - Class in tools.refinery.interpreter.matchers.psystem.basicenumerables
For a binary base pattern over an enumerable universe type, computes the reflexive transitive closure (base)*
BinaryReflexiveTransitiveClosure(PBody, Tuple, PQuery, IInputKey) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicenumerables.BinaryReflexiveTransitiveClosure
 
BinaryTransitiveClosure - Class in tools.refinery.interpreter.matchers.psystem.basicenumerables
For a binary base pattern, computes the irreflexive transitive closure (base)+
BinaryTransitiveClosure(PBody, Tuple, PQuery) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicenumerables.BinaryTransitiveClosure
 
bind(String, String[]) - Static method in exception class tools.refinery.interpreter.matchers.planning.QueryProcessingException
Binding the '{n}' (n = 1..N) strings to contextual conditions in 'context'
body - Variable in class tools.refinery.interpreter.matchers.planning.SubPlanFactory
 
body - Variable in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
The created body
BoundAggregator - Class in tools.refinery.interpreter.matchers.psystem.aggregations
Augments an aggregator operator with type bindings for the type of values being aggregated and the aggregate result.
BoundAggregator(IMultisetAggregationOperator<?, ?, ?>, Class<?>, Class<?>) - Constructor for class tools.refinery.interpreter.matchers.psystem.aggregations.BoundAggregator
 
build() - Method in class tools.refinery.interpreter.api.InterpreterEngineOptions.Builder
 
buildBetaNode(SubPlan, SubPlan, TupleMask, TupleMask, TupleMask, boolean) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
buildConnection(SubPlan, Collector) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
buildCountCheckBetaNode(SubPlan, SubPlan, TupleMask, TupleMask, int) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
buildCounterBetaNode(SubPlan, SubPlan, TupleMask, TupleMask, TupleMask, Object) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
buildEqualityChecker(SubPlan, int[]) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
Builder() - Constructor for class tools.refinery.interpreter.api.InterpreterEngineOptions.Builder
 
Builder(InterpreterEngineOptions) - Constructor for class tools.refinery.interpreter.api.InterpreterEngineOptions.Builder
 
buildFunctionEvaluator(IExpressionEvaluator, Map<String, Integer>, SubPlan, Object) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
BuildHelper - Class in tools.refinery.interpreter.matchers.planning.helpers
 
buildInjectivityChecker(SubPlan, int, int[]) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
buildPredicateChecker(IExpressionEvaluator, Map<String, Integer>, SubPlan) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
buildStartingPlan(Object[], Object[]) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
buildTransitiveClosure(SubPlan) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
buildTrimmer(SubPlan, TupleMask, boolean) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 

C

cachedHash - Variable in class tools.refinery.interpreter.matchers.tuple.Tuple
Caches precalculated hash value
calculateRequiredCapability(PQuery, QueryEvaluationHint) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackendFactory
Calculate the required capabilities, which are needed to execute the given pattern
calculateSimpleName(String) - Static method in class tools.refinery.interpreter.matchers.psystem.queries.PQueries
Calculates the simple name related from a given qualified name by finding the part after the last '.' character.
canBeSubstitute(IMatcherCapability) - Method in interface tools.refinery.interpreter.matchers.backend.IMatcherCapability
Returns true if matchers of this capability can be used as a substitute for a matcher implementing the given capability
CancellationToken - Interface in tools.refinery.interpreter
 
canLeadOutOfScope(IInputKey) - Method in class tools.refinery.interpreter.matchers.context.AbstractQueryMetaContext
 
canLeadOutOfScope(IInputKey) - Method in interface tools.refinery.interpreter.matchers.context.IQueryMetaContext
Tells whether the given IInputKey is an edge and may lead out of scope.
cartesianProduct(List<? extends Set<? extends A>>) - Static method in class tools.refinery.interpreter.matchers.util.Sets
 
changeOccured(InterpreterModelUpdateListener.ChangeLevel) - Method in enum class tools.refinery.interpreter.api.InterpreterModelUpdateListener.ChangeLevel
 
checkArgument(boolean) - Static method in class tools.refinery.interpreter.matchers.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String) - Static method in class tools.refinery.interpreter.matchers.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, String, Object...) - Static method in class tools.refinery.interpreter.matchers.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkArgument(boolean, Supplier<String>) - Static method in class tools.refinery.interpreter.matchers.util.Preconditions
Ensures the truth of an expression involving one or more parameters to the calling method.
checkCancelled() - Method in interface tools.refinery.interpreter.CancellationToken
 
checkConsistency(SubPlan) - Method in class tools.refinery.interpreter.matchers.planning.operations.PApply
 
checkConsistency(SubPlan) - Method in class tools.refinery.interpreter.matchers.planning.operations.POperation
Checks whether this constraint can be properly applied at the given SubPlan.
checkConsistency(SubPlan) - Method in class tools.refinery.interpreter.matchers.planning.operations.PProject
 
checkElementIndex(int, int) - Static method in class tools.refinery.interpreter.matchers.util.Preconditions
Ensures that an index is appropriate for a list or array of given size.
checkElementIndex(int, int, String, Object...) - Static method in class tools.refinery.interpreter.matchers.util.Preconditions
Ensures that an index is appropriate for a list or array of given size.
checkElementIndex(int, int, Supplier<String>) - Static method in class tools.refinery.interpreter.matchers.util.Preconditions
Ensures that an index is appropriate for a list or array of given size.
checkMutability() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
checkMutability() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQuery
Before a modification operation is executed, a mutability check is performed (via the PQuery.getStatus() implementation, and in case of problems an IllegalStateException is thrown.
checkSanity() - Method in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
checkSanity() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExportedParameter
 
checkSanity() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternCallBasedDeferred
 
checkSanity() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.BinaryReflexiveTransitiveClosure
 
checkSanity() - Method in interface tools.refinery.interpreter.matchers.psystem.PConstraint
 
checkState(boolean) - Static method in class tools.refinery.interpreter.matchers.util.Preconditions
Ensures the truth of an expression involving one or more fields of a class.
checkState(boolean, String) - Static method in class tools.refinery.interpreter.matchers.util.Preconditions
Ensures the truth of an expression involving one or more fields of a class.
checkState(boolean, String, Object...) - Static method in class tools.refinery.interpreter.matchers.util.Preconditions
Ensures the truth of an expression involving one or more fields of a class.
checkState(boolean, Supplier<String>) - Static method in class tools.refinery.interpreter.matchers.util.Preconditions
Ensures the truth of an expression involving one or more fields of a class.
checkTypeSafety(SubPlan, IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.BaseTypeSafeConstraint
Checks whether all type restrictions are already enforced on affected variables.
clear() - Method in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
clear() - Method in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
clear() - Method in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
clear() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
clear() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
clear() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
clear() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
clear() - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
clear() - Method in interface tools.refinery.interpreter.matchers.util.Clearable
Clear all partial matchings stored in memory
clear() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
clear() - Method in interface tools.refinery.interpreter.matchers.util.IMemory
Empties out the memory.
clear() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Empties out the lookup structure.
clear() - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
clear() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
Clearable - Interface in tools.refinery.interpreter.matchers.util
 
clearAllOf(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
clearAllOf(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
clearAllOf(T) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
clearAllOf(T) - Method in interface tools.refinery.interpreter.matchers.util.IMemory
Removes all occurrences of the given value from the memory.
clearAllOf(Value) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
clone(Accumulator) - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IMultisetAggregationOperator
Clones the given accumulator (with all its internal contents).
clone(AggregateResult) - Method in class tools.refinery.interpreter.matchers.psystem.aggregations.AbstractMemorylessAggregationOperator
 
clone(SortedMap<T, Integer>) - Method in class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator
 
clone(AverageAccumulator<Double>) - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleAverageOperator
 
clone(AverageAccumulator<Integer>) - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerAverageOperator
 
clone(AverageAccumulator<Long>) - Method in class tools.refinery.interpreter.matchers.aggregators.LongAverageOperator
 
closureOf(Collection<A>, Map<Set<A>, Set<A>>) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.FunctionalDependencyHelper
Get the closure of the specified attribute set relative to the specified functional dependencies.
coalesceTraversals(Callable<V>) - Method in interface tools.refinery.interpreter.api.scope.IBaseIndex
The given callback will be executed, and all model traversals and index registrations will be delayed until the execution is done.
coalesceTraversals(Callable<V>) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
The given callable will be executed, and all model traversals will be delayed until the execution is done.
CollectionsFactory - Class in tools.refinery.interpreter.matchers.util
Factory class used as an accessor to Collections implementations.
CollectionsFactory() - Constructor for class tools.refinery.interpreter.matchers.util.CollectionsFactory
 
CollectionsFactory.ICollectionsFramework - Interface in tools.refinery.interpreter.matchers.util
Interface abstracting over a collections technology that provides custom collection implementations.
CollectionsFactory.MemoryType - Enum Class in tools.refinery.interpreter.matchers.util
The type of IMemory
columnToTuples - Variable in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
combine(AggregateResult, Accumulator) - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IMultisetAggregationOperator
Combines the given aggregate result and accumulator into a single aggregate result.
combine(Tuple, Tuple, boolean, boolean) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Combines two substitutions.
combine(Tuple, Tuple, boolean, boolean) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask0
 
CommonQueryHintOptions - Class in tools.refinery.interpreter.matchers.backend
Query evaluation hints applicable to any engine
CompactTimeline<Timestamp> - Class in tools.refinery.interpreter.matchers.util.timeline
A compact timeline may cosist of an arbitrary amount of moments.
COMPARE_BY_MONOTONOUS_ID - Static variable in interface tools.refinery.interpreter.matchers.psystem.PConstraint
A comparator that orders constraints by their monotonous identifiers.
computeDiffsEager(Direction, TimelyMemory.CumulativeCounter, TimelyMemory.SignChange, Timestamp, Diff<Timestamp>) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
Utility method that computes the timeline diffs in case of eager memories.
computeDiffsLazy(Direction, int, int, Timestamp, Timestamp, Diff<Timestamp>) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
Utility method that computes the timeline diffs in case of lazy memories.
Connectivity - Enum Class in tools.refinery.interpreter.matchers.psystem.basicenumerables
 
ConstantValue - Class in tools.refinery.interpreter.matchers.psystem.basicenumerables
 
ConstantValue(PBody, PVariable, Object) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicenumerables.ConstantValue
 
ConstraintRemovalReason - Enum Class in tools.refinery.interpreter.matchers.psystem.rewriters
Common reasons for removing constraint through rewriters
constructLinearSequence(int) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
An array containing the first
invalid reference
size
nonnegative integers in order
contains(Domain, Accumulator) - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IMultisetAggregationOperator
 
contains(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
containsAll(Collection<?>) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
containsKey(Object) - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
containsKey(ITuple) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
containsNonZero(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
containsNonZero(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
containsNonZero(T) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
containsNonZero(T) - Method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
containsNonZero(T) - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
 
containsNonZero(T) - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
containsNonZero(Value) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
containsNonZero(Value) - Method in class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
containsNonZeroUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
containsNonZeroUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
containsNonZeroUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
containsNonZeroUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
containsNonZeroUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
containsNonZeroUnsafe(Object) - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
 
containsNonZeroUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
containsNonZeroUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
containsTuple(IInputKey, ITuple) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Simpler form of IQueryRuntimeContext.enumerateTuples(IInputKey, TupleMask, Tuple) in the case where all values of the tuples are bound by the seed.
containsValue(Object) - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
copyAggregatorConstraint(AggregatorConstraint) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyBinaryReflexiveTransitiveClosureConstraint(BinaryReflexiveTransitiveClosure) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyBinaryTransitiveClosureConstraint(BinaryTransitiveClosure) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyConstantValueConstraint(ConstantValue) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyConstraint(PConstraint) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyEqualityConstraint(Equality) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyExportedParameterConstraint(ExportedParameter) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyExpressionEvaluationConstraint(ExpressionEvaluation) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyInequalityConstraint(Inequality) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyLeftJoinConstraint(LeftJoinConstraint) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyNegativePatternCallConstraint(NegativePatternCall) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyOptions(InterpreterEngineOptions) - Static method in class tools.refinery.interpreter.api.InterpreterEngineOptions
Initializes an option builder with settings from an existing configuration.
copyPatternMatchCounterConstraint(PatternMatchCounter) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyPositivePatternCallConstraint(PositivePatternCall) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyRelationEvaluationConstraint(RelationEvaluation) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyRepresentativeElectionConstraint(RepresentativeElectionConstraint) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyTypeConstraint(TypeConstraint) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyTypeFilterConstraint(TypeFilterConstraint) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
copyVariable(PVariable, String) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
count - Class in tools.refinery.interpreter.matchers.aggregators
An aggregator to count the number of matches a pattern has.
count() - Constructor for class tools.refinery.interpreter.matchers.aggregators.count
 
counters - Variable in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
countKeys() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
 
countKeys() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
countMatches() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
countMatches() - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns the number of all pattern matches.
countMatches(Object[]) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Returns the number of all matches of the pattern that conform to the given fixed values of some parameters.
countMatches(Match) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
countMatches(Match) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns the number of all matches of the pattern that conform to the given fixed values of some parameters.
countMatches(TupleMask, ITuple) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Returns the number of all matches of the pattern that conform to the given fixed values of some parameters.
countTuples(IInputKey, TupleMask, ITuple) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Returns the number of tuples in the extensional relation identified by the input key seeded with the given mask and tuple.
create(IQueryBackendContext) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackendFactory
Creates a new IQueryBackend instance tied to the given context elements.
create(TupleMask, CollectionsFactory.MemoryType, Object) - Static method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Creates a new memory for the given owner that indexes tuples according to the given mask.
create(TupleMask, CollectionsFactory.MemoryType, Object, boolean) - Static method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Creates a new memory for the given owner that indexes tuples according to the given mask.
create(TupleMask, CollectionsFactory.MemoryType, Object, boolean, boolean) - Static method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Creates a new memory for the given owner that indexes tuples according to the given mask.
createConstraintFor(PBody) - Method in class tools.refinery.interpreter.matchers.psystem.TypeJudgement
Creates this judgement as a direct type constraint in the given PBody under construction.
createDeltaBag() - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates a new empty delta bag.
createDeltaBag() - Method in interface tools.refinery.interpreter.matchers.util.CollectionsFactory.ICollectionsFramework
 
createDeltaBag() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsFactory
 
createDeltaBucket(Value, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
createDeltaBucket(Value, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToMultisetsAbstract
 
createDeltaBucket(Value, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToSetsAbstract
 
createEmpty() - Static method in class tools.refinery.interpreter.matchers.util.timeline.Timelines
 
createEngineContext(InterpreterEngine, IIndexingErrorListener, Logger) - Method in class tools.refinery.interpreter.internal.apiimpl.EngineContextFactory
 
createFrom(List<Timestamp>) - Static method in class tools.refinery.interpreter.matchers.util.timeline.Timelines
 
createFrom(Timestamp) - Static method in class tools.refinery.interpreter.matchers.util.timeline.Timelines
 
createFrom(Diff<Timestamp>) - Static method in class tools.refinery.interpreter.matchers.util.timeline.Timelines
 
createMap() - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates a new empty map.
createMap() - Method in interface tools.refinery.interpreter.matchers.util.CollectionsFactory.ICollectionsFramework
 
createMap() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsFactory
 
createMap(Map<K, V>) - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates a new map with the given initial contents.
createMap(Map<K, V>) - Method in interface tools.refinery.interpreter.matchers.util.CollectionsFactory.ICollectionsFramework
 
createMap(Map<K, V>) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsFactory
 
createMarkedMultiset() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToMultisetsAbstract
 
createMarkedSet() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToSetsAbstract
 
createMemory(Class<? super T>, CollectionsFactory.MemoryType) - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates a memory storing values.
createMemory(Class<? super T>, CollectionsFactory.MemoryType) - Method in interface tools.refinery.interpreter.matchers.util.CollectionsFactory.ICollectionsFramework
 
createMemory(Class<? super T>, CollectionsFactory.MemoryType) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsFactory
 
createMultiLookup(Class<? super K>, CollectionsFactory.MemoryType, Class<? super V>) - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates a size-optimized multimap from keys to sets of values.
createMultiLookup(Class<? super K>, CollectionsFactory.MemoryType, Class<? super V>) - Method in interface tools.refinery.interpreter.matchers.util.CollectionsFactory.ICollectionsFramework
 
createMultiLookup(Class<? super K>, CollectionsFactory.MemoryType, Class<? super V>) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsFactory
 
createMultiset() - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates a new empty multiset.
createMultiset() - Method in interface tools.refinery.interpreter.matchers.util.CollectionsFactory.ICollectionsFramework
 
createMultiset() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsFactory
 
createNeutral() - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleAverageOperator
 
createNeutral() - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleSumOperator
 
createNeutral() - Method in class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator
 
createNeutral() - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerAverageOperator
 
createNeutral() - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerSumOperator
 
createNeutral() - Method in class tools.refinery.interpreter.matchers.aggregators.LongAverageOperator
 
createNeutral() - Method in class tools.refinery.interpreter.matchers.aggregators.LongSumOperator
 
createNeutral() - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IMultisetAggregationOperator
 
createObserverList() - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates a new list that is optimized for registering observers / callbacks.
createObserverList() - Method in interface tools.refinery.interpreter.matchers.util.CollectionsFactory.ICollectionsFramework
 
createObserverList() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsFactory
 
createSet() - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates a new empty set.
createSet() - Method in interface tools.refinery.interpreter.matchers.util.CollectionsFactory.ICollectionsFramework
 
createSet() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsFactory
 
createSet(Collection<E>) - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates a new set with the given initial contents.
createSet(Collection<E>) - Method in interface tools.refinery.interpreter.matchers.util.CollectionsFactory.ICollectionsFramework
 
createSet(Collection<E>) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsFactory
 
createSingletonBucket(Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
createSingletonBucket(Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToMultisetsAbstract
 
createSingletonBucket(Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToSetsAbstract
 
createSubPlan(POperation, SubPlan...) - Method in class tools.refinery.interpreter.matchers.planning.SubPlanFactory
 
createTreeMap() - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates a new tree map.
createTreeMap() - Method in interface tools.refinery.interpreter.matchers.util.CollectionsFactory.ICollectionsFramework
 
createTreeMap() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsFactory
 
createUnmanagedEngine(QueryScope) - Static method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Creates a new unmanaged Refinery Interpreter engine to evaluate queries over a given scope specified by an QueryScope.
createUnmanagedEngine(QueryScope, InterpreterEngineOptions) - Static method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Creates a new unmanaged Refinery Intepreter engine to evaluate queries over a given scope specified by an QueryScope.
createVariableName(PVariable, PQuery) - Method in interface tools.refinery.interpreter.matchers.psystem.rewriters.IVariableRenamer
Creates a variable name based on a given variable and a given query.
createVariableName(PVariable, PQuery) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.IVariableRenamer.HierarchicalName
 
createVariableName(PVariable, PQuery) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.IVariableRenamer.SameName
 
cumulative - Variable in class tools.refinery.interpreter.matchers.util.TimelyMemory.CumulativeCounter
 
CumulativeCounter(int, int) - Constructor for class tools.refinery.interpreter.matchers.util.TimelyMemory.CumulativeCounter
 

D

DEFAULT_CACHING - Enum constant in enum class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint.BackendRequirement
The current hint specifies that the default caching backend of the engine should be used
DEFAULT_SEARCH - Enum constant in enum class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint.BackendRequirement
The current hint specifies that the default search backend of the engine should be used
DefaultFlattenCallPredicate - Class in tools.refinery.interpreter.matchers.psystem.rewriters
 
DefaultFlattenCallPredicate() - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.DefaultFlattenCallPredicate
 
defaultInstantiate(InterpreterEngine) - Method in class tools.refinery.interpreter.api.GenericQuerySpecification
Derived classes should use this implementation of BaseQuerySpecification.instantiate(InterpreterEngine) if they use GenericPatternMatcher proper.
DefaultMaskedTupleMemory<Timestamp> - Class in tools.refinery.interpreter.matchers.memories
 
DefaultMaskedTupleMemory(TupleMask, CollectionsFactory.MemoryType, Object) - Constructor for class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
defaultValue - Variable in class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
DeferredPConstraint - Class in tools.refinery.interpreter.matchers.psystem
Any constraint that can only be checked on certain SubPlans (e.g.
DeferredPConstraint(PBody, Set<PVariable>) - Constructor for class tools.refinery.interpreter.matchers.psystem.DeferredPConstraint
 
defineOptions() - Static method in class tools.refinery.interpreter.api.InterpreterEngineOptions
Initializes an option builder with no previously set options.
delayUpdatePropagation(Callable<V>) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
The given callable will be executed, and all update propagation in stateful query backends will be delayed until the execution is done.
delayUpdatePropagation(Callable<V>) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
delete() - Method in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
delete() - Method in interface tools.refinery.interpreter.matchers.psystem.PConstraint
 
DELETE - Enum constant in enum class tools.refinery.interpreter.matchers.util.Direction
 
deleteSet(V) - Method in class tools.refinery.interpreter.matchers.algorithms.UnionFind
Delete the set whose root is the given node.
derivativeRemoved(PConstraint, IDerivativeModificationReason) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.AbstractRewriterTraceSource
Indicate that the given derivative is removed from the resulting query, thus its trace information should be removed also.
derivativeRemoved(PTraceable, IDerivativeModificationReason) - Method in interface tools.refinery.interpreter.matchers.psystem.rewriters.IRewriterTraceCollector
Indicate that the given derivative is removed from the resulting query, thus its trace information should be removed also.
derivativeRemoved(PTraceable, IDerivativeModificationReason) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.MappingTraceCollector
 
derivativeRemoved(PTraceable, IDerivativeModificationReason) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.NopTraceCollector
 
diff - Variable in class tools.refinery.interpreter.matchers.util.TimelyMemory.CumulativeCounter
 
diff - Variable in class tools.refinery.interpreter.matchers.util.TimelyMemory.FoldingState
 
Diff<Timestamp> - Class in tools.refinery.interpreter.matchers.util.timeline
The description of a delta that specifies how a Timeline changes.
Diff() - Constructor for class tools.refinery.interpreter.matchers.util.timeline.Diff
 
difference(Set<A>, Set<A>) - Static method in class tools.refinery.interpreter.matchers.util.Sets
 
directContainmentPlan(Tuple) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
directGeneralizationPlan(Tuple) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
directInstantiationPlan(Tuple) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
Direction - Enum Class in tools.refinery.interpreter.matchers.util
Indicates whether a propagated update event signals the insertion or deletion of an element
directlyReferencedQueriesFunction() - Static method in class tools.refinery.interpreter.matchers.psystem.queries.PQueries
Enumerates referred queries (without duplicates) for the given body
directlyRequiredTypesOfDisjunction(PDisjunction, boolean) - Static method in class tools.refinery.interpreter.matchers.psystem.queries.PQueries
Enumerates directly referred extensional relations (without duplicates) for the given formulation of a query.
directlyRequiredTypesOfQuery(PQuery, boolean) - Static method in class tools.refinery.interpreter.matchers.psystem.queries.PQueries
Enumerates directly referred extensional relations (without duplicates) in the canonical form of the given query
displace(int, int, int) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance that moves an element from one index to other, shifting the others if neccessary.
dispose() - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Completely disconnects and dismantles the engine.
dispose() - Method in interface tools.refinery.interpreter.api.scope.IEngineContext
Disposes this context object.
dispose() - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
dispose() - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackend
Disposes the query backend.
distinctKeys() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
 
distinctKeys() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
distinctKeysStream() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
 
distinctKeysStream() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
distinctValues() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
distinctValues() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
distinctValues() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
distinctValues() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
distinctValues() - Method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
distinctValues() - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
The set of distinct values
distinctValues() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Iterates once over each distinct value.
distinctValues() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
distinctValues() - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
distinctValues() - Method in class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
distinctValuesStream() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Iterates once over each distinct value.
distinctValuesStream() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
doCalcHash() - Method in class tools.refinery.interpreter.matchers.tuple.AbstractTuple
 
doDoReplaceVariables(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
doDoReplaceVariables(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
doDoReplaceVariables(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.NegativePatternCall
 
doDoReplaceVariables(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternCallBasedDeferred
 
doDoReplaceVariables(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternMatchCounter
 
doFoldingStep(Tuple, TimelyMemory.FoldingState, Timestamp) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
doGetContainedBodies() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
Creates and returns the bodies of the query.
doReplaceVariable(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
doReplaceVariable(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.BaseTypeSafeConstraint
 
doReplaceVariable(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Equality
 
doReplaceVariable(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExportedParameter
 
doReplaceVariable(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Inequality
 
doReplaceVariable(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternCallBasedDeferred
 
doReplaceVariable(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.TypeFilterConstraint
 
doReplaceVariable(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.TypeConstraint
 
doReplaceVariable(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.EnumerablePConstraint
 
DoubleAverageOperator - Class in tools.refinery.interpreter.matchers.aggregators
 
DoubleSumOperator - Class in tools.refinery.interpreter.matchers.aggregators
Incrementally computes the sum of java.lang.Double values
DUPLICATE - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.rewriters.ConstraintRemovalReason
 
DUPLICATE - Enum constant in enum class tools.refinery.interpreter.matchers.util.IMultiLookup.ChangeGranularity
Duplicate key-value pair inserted or deleted.
duplicatesAllowed() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
duplicatesAllowed() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToMultisetsAbstract
 
duplicatesAllowed() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToSetsAbstract
 

E

EclipseCollectionsBagMemory<T> - Class in tools.refinery.interpreter.matchers.util
Eclipse Collections-based multiset for tuples.
EclipseCollectionsBagMemory() - Constructor for class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
EclipseCollectionsDeltaBag<T> - Class in tools.refinery.interpreter.matchers.util
 
EclipseCollectionsDeltaBag() - Constructor for class tools.refinery.interpreter.matchers.util.EclipseCollectionsDeltaBag
 
EclipseCollectionsFactory - Class in tools.refinery.interpreter.matchers.util
 
EclipseCollectionsFactory() - Constructor for class tools.refinery.interpreter.matchers.util.EclipseCollectionsFactory
 
EclipseCollectionsLongMultiset - Class in tools.refinery.interpreter.matchers.util
 
EclipseCollectionsLongMultiset() - Constructor for class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
EclipseCollectionsLongSetMemory - Class in tools.refinery.interpreter.matchers.util
 
EclipseCollectionsLongSetMemory() - Constructor for class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
EclipseCollectionsLongSetMemory.SetWrapper - Class in tools.refinery.interpreter.matchers.util
Helper that presents a primitive collection as a Set view
EclipseCollectionsMultiset<T> - Class in tools.refinery.interpreter.matchers.util
 
EclipseCollectionsMultiset() - Constructor for class tools.refinery.interpreter.matchers.util.EclipseCollectionsMultiset
 
EclipseCollectionsSetMemory<Value> - Class in tools.refinery.interpreter.matchers.util
 
EclipseCollectionsSetMemory() - Constructor for class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
elements - Variable in class tools.refinery.interpreter.matchers.util.timeline.CompactTimeline
 
eliminateTrailingProjections(SubPlan) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.BuildHelper
Skips the last few steps, if any, that are projections, so that a custom projection can be added instead.
eliminateWeak() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Inequality
Eliminates a weak inequality constraint if it can be ignored when who is the same as withWhom, or if any if them is undeducible.
EMBEDDED - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.queries.PVisibility
A query that is only used inside a single caller query and is not visible outside its container query.
empty(int) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance of the given size that does not emit output.
EMPTY_DIFF - Variable in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
EMPTY_RELATION - Static variable in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
EMPTY_RELATION - Static variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
EMPTY_TUPLE - Static variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
emptyArray() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
EmptyMemory<T> - Class in tools.refinery.interpreter.matchers.util
A singleton immutable empty memory.
emptyMultiset(Object) - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates an empty multiset; the key parameter is used to allow using this as a method reference as a Function, e.g.
emptySet(Object) - Static method in class tools.refinery.interpreter.matchers.util.CollectionsFactory
Instantiates an empty set; the key parameter is used to allow using this as a method reference as a Function, e.g.
engine - Variable in class tools.refinery.interpreter.api.impl.BaseMatcher
 
engineBecameTainted(String, Throwable) - Method in interface tools.refinery.interpreter.api.InterpreterEngineLifecycleListener
Called after the engine has become tainted due to a fatal error
engineBecameTainted(String, Throwable) - Method in class tools.refinery.interpreter.internal.engine.LifecycleProvider
 
EngineContextFactory - Class in tools.refinery.interpreter.internal.apiimpl
Internal interface for a Scope to reveal model contents to the engine.
EngineContextFactory() - Constructor for class tools.refinery.interpreter.internal.apiimpl.EngineContextFactory
 
engineDisposed() - Method in interface tools.refinery.interpreter.api.InterpreterEngineLifecycleListener
Called after the engine has been disposed
engineDisposed() - Method in class tools.refinery.interpreter.internal.engine.LifecycleProvider
 
engineInitialized(AdvancedInterpreterEngine) - Method in interface tools.refinery.interpreter.api.InterpreterEngineInitializationListener
Called when a managed engine is initialized in the EngineManager.
engineWiped() - Method in interface tools.refinery.interpreter.api.InterpreterEngineLifecycleListener
Called after the engine has been wiped
engineWiped() - Method in class tools.refinery.interpreter.internal.engine.LifecycleProvider
 
ensureIndexed(IInputKey, IndexingService) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
If the given (enumerable) input key is not yet indexed, the model will be traversed (after the end of the outermost coalescing block, see IQueryRuntimeContext.coalesceTraversals(Callable)) so that the index can be built.
ensureInitialized() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
ensureInitialized() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQuery
If the query definition is uninitialized, initializes it.
ensureInitializedInternal() - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
ensureWildcardIndexing(IndexingService) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Starts wildcard indexing for the given service.
entriesWithMultiplicities() - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
 
entriesWithMultiplicities() - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
entrySet() - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
EnumerablePConstraint - Class in tools.refinery.interpreter.matchers.psystem
A constraint for which all satisfying tuples of variable values can be enumerated at any point during run-time.
EnumerablePConstraint(PBody, Tuple) - Constructor for class tools.refinery.interpreter.matchers.psystem.EnumerablePConstraint
 
enumerateTuples(IInputKey, TupleMask, ITuple) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Returns the tuples in the extensional relation identified by the input key, optionally seeded with the given tuple.
enumerateValues(IInputKey, TupleMask, ITuple) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Simpler form of IQueryRuntimeContext.enumerateTuples(IInputKey, TupleMask, Tuple) in the case where all values of the tuples are bound by the seed except for one.
Equality - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
 
Equality(PBody, PVariable, PVariable) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.Equality
 
equals(Object) - Method in class tools.refinery.interpreter.api.GenericPatternMatch
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.context.common.BaseInputKeyWrapper
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.context.InputKeyImplication
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.planning.operations.PApply
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.planning.operations.PEnumerate
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.planning.operations.PJoin
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.planning.operations.PProject
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.planning.operations.PStart
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.psystem.queries.PParameter
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.psystem.TypeJudgement
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.tuple.Tuple
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.tuple.VolatileTuple
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.util.Signed
 
equals(Object) - Method in class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
equals(IMemoryView<T>, Object) - Static method in interface tools.refinery.interpreter.matchers.util.IMemoryView
Provides semantic equality comparison.
equals(IMultiLookup<Key, Value>, Object) - Static method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Provides semantic equality comparison.
error(String, Throwable) - Method in interface tools.refinery.interpreter.api.scope.IIndexingErrorListener
 
ERROR - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.queries.PQuery.PQueryStatus
The query definition was not successfully initialized because of an error
estimateAverageBucketSize(IInputKey, TupleMask, Accuracy) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Gives an estimate of the average size of different groups the tuples of the given relation are projected into by the given mask (e.g.
estimateAverageBucketSize(TupleMask, Accuracy) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Gives an estimate of the average size of different groups the matches are projected into by the given mask (e.g.
estimateAverageBucketSize(TupleMask, Accuracy, BiFunction<TupleMask, Accuracy, Optional<Long>>) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.StatisticsHelper
 
estimateCardinality(IInputKey, TupleMask, Accuracy) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Gives an estimate of the number of different groups the tuples of the given relation are projected into by the given mask (e.g.
estimateCardinality(TupleMask, Accuracy) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Gives an estimate of the number of different groups the matches are projected into by the given mask (e.g.
evaluateExpression(IValueProvider) - Method in interface tools.refinery.interpreter.matchers.psystem.IExpressionEvaluator
The expression evaluator code
evaluateRelation(List<Set<Tuple>>) - Method in interface tools.refinery.interpreter.matchers.psystem.IRelationEvaluator
The relation evaluator code.
EXACT_COUNT - Enum constant in enum class tools.refinery.interpreter.matchers.util.Accuracy
 
executeAfterTraversal(Runnable) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Execute the given runnable after traversal.
ExportedParameter - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
 
ExportedParameter(PBody, PVariable, PParameter) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExportedParameter
 
ExportedParameterFilter() - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.IConstraintFilter.ExportedParameterFilter
 
ExpressionEvaluation - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
 
ExpressionEvaluation(PBody, IExpressionEvaluator, PVariable) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExpressionEvaluation
 
ExpressionEvaluation(PBody, IExpressionEvaluator, PVariable, boolean) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExpressionEvaluation
 
extractMappedVariables(EnumerablePConstraint) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
For positive pattern calls
ExtremumOperator<T> - Class in tools.refinery.interpreter.matchers.aggregators
Incrementally computes the minimum or maximum of java.lang.Comparable values, using the default comparison
ExtremumOperator.Extreme - Enum Class in tools.refinery.interpreter.matchers.aggregators
 

F

fatal(String, Throwable) - Method in interface tools.refinery.interpreter.api.scope.IIndexingErrorListener
 
filter(PConstraint) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.IConstraintFilter.AllowAllFilter
 
filter(PConstraint) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.IConstraintFilter.ExportedParameterFilter
 
filter(PConstraint) - Method in interface tools.refinery.interpreter.matchers.psystem.rewriters.IConstraintFilter
Returns true, if the given constraint should be filtered (thus should not be copied)
finalCheck(PBody, SubPlan, IQueryMetaContext) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.BuildHelper
Verifies whether all constraints are enforced and exported parameters are present.
find(V) - Method in class tools.refinery.interpreter.matchers.algorithms.UnionFind
Find method with path compression.
FlatTuple - Class in tools.refinery.interpreter.matchers.tuple
Default Tuple implementation, with statically unknown arity.
FlatTuple(Object...) - Constructor for class tools.refinery.interpreter.matchers.tuple.FlatTuple
Creates a FlatTuple instance, fills it with the given array.
FlatTuple0 - Class in tools.refinery.interpreter.matchers.tuple
Flat tuple with statically known arity of 0.
FlatTuple1 - Class in tools.refinery.interpreter.matchers.tuple
Flat tuple with statically known arity of 1.
FlatTuple1(Object) - Constructor for class tools.refinery.interpreter.matchers.tuple.FlatTuple1
 
FlatTuple2 - Class in tools.refinery.interpreter.matchers.tuple
Flat tuple with statically known arity of 2.
FlatTuple2(Object, Object) - Constructor for class tools.refinery.interpreter.matchers.tuple.FlatTuple2
 
FlatTuple3 - Class in tools.refinery.interpreter.matchers.tuple
Flat tuple with statically known arity of 3.
FlatTuple3(Object, Object, Object) - Constructor for class tools.refinery.interpreter.matchers.tuple.FlatTuple3
 
FlatTuple4 - Class in tools.refinery.interpreter.matchers.tuple
Flat tuple with statically known arity of 4.
FlatTuple4(Object, Object, Object, Object) - Constructor for class tools.refinery.interpreter.matchers.tuple.FlatTuple4
 
flatTupleOf(Object...) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a flat tuple consisting of the given elements.
flushChanges() - Method in class tools.refinery.interpreter.api.InterpreterEngine
 
flushChanges() - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
flushUpdates() - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackend
Propagates all pending updates in this query backend.
foldingState - Variable in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
FoldingState(int) - Constructor for class tools.refinery.interpreter.matchers.util.TimelyMemory.FoldingState
 
foldingStates - Variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
foldingStates - Variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
forceGetInstanceClass() - Method in class tools.refinery.interpreter.matchers.context.common.JavaTransitiveInstancesKey
 
forceGetWrapperInstanceClass() - Method in class tools.refinery.interpreter.matchers.context.common.JavaTransitiveInstancesKey
 
forEachEntryWithMultiplicities(BiConsumer<Long, Integer>) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
forEachEntryWithMultiplicities(BiConsumer<T, Integer>) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
forEachEntryWithMultiplicities(BiConsumer<T, Integer>) - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
Process contained values with their multiplicities
forEachEntryWithMultiplicities(BiConsumer<T, Integer>) - Method in interface tools.refinery.interpreter.matchers.util.ISetMemory
 
forEachEntryWithMultiplicities(BiConsumer<T, Integer>) - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
forEachMatch(Consumer<? super Match>) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
forEachMatch(Consumer<? super Match>) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Executes the given processor on each match of the pattern.
forEachMatch(Match, Consumer<? super Match>) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
forEachMatch(Match, Consumer<? super Match>) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Executes the given processor on each match of the pattern that conforms to the given fixed values of some parameters.
forEachValue(BiConsumer<String, Object>) - Method in class tools.refinery.interpreter.matchers.psystem.annotations.PAnnotation
Executes a consumer over all attributes.
forOneArbitraryMatch(Consumer<? super Match>) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
forOneArbitraryMatch(Consumer<? super Match>) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Executes the given processor on an arbitrarily chosen match of the pattern.
forOneArbitraryMatch(Match, Consumer<? super Match>) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
forOneArbitraryMatch(Match, Consumer<? super Match>) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Executes the given processor on an arbitrarily chosen match of the pattern that conforms to the given fixed values of some parameters.
from(InterpreterEngine) - Static method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Provides access to a given existing engine through the advanced interface.
fromKeepIndicators(boolean[]) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance that selects positions where keep is true
fromMap(Map<T, Integer>) - Static method in interface tools.refinery.interpreter.matchers.util.IMemoryView
For compatibility with legacy code relying on element-to-integer maps.
fromNonNullIndices(ITuple) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance that selects non-null positions of a given tuple
fromSelectedIndices(int, int[]) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance that selects given positions.
fromSelectedIndices(int, Collection<Integer>) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance that selects given positions.
fromSelectedIndicesInternal(int[], int, int[], Boolean) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance that selects given positions.
fromSelectedMonotonicIndicesInternal(int[], int) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance that selects given positions in monotonically increasing order.
FULL_BACKEND_ADHESION - Static variable in interface tools.refinery.interpreter.matchers.backend.ICallDelegationStrategy
Options known for callee are used to override caller options, except the backend selection.
FunctionalDependencyHelper - Class in tools.refinery.interpreter.matchers.planning.helpers
Helper utility class for functional dependency analysis.

G

gcCounters(TimelyMemory.CumulativeCounter, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
Garbage collects the counter of the given tuple and timestamp if the new diff is zero.
GenericPatternMatch - Class in tools.refinery.interpreter.api
Generic signature object implementation.
GenericPatternMatcher - Class in tools.refinery.interpreter.api
This is a generic pattern matcher for any Refinery Interpreter pattern, with "interpretative" query execution.
GenericPatternMatcher(GenericQuerySpecification<? extends GenericPatternMatcher>) - Constructor for class tools.refinery.interpreter.api.GenericPatternMatcher
 
GenericQueryGroup - Class in tools.refinery.interpreter.api
Generic implementation of IQueryGroup, covering an arbitrarily chosen set of patterns.
GenericQueryGroup(Set<IQuerySpecification<?>>) - Constructor for class tools.refinery.interpreter.api.GenericQueryGroup
Creates a GenericQueryGroup object with a set of patterns.
GenericQuerySpecification<Matcher> - Class in tools.refinery.interpreter.api
This is a generic query specification for Refinery Interpreter pattern matchers, for "interpretative" query execution.
GenericQuerySpecification(PQuery) - Constructor for class tools.refinery.interpreter.api.GenericQuerySpecification
Instantiates query specification for the given internal query representation.
get() - Method in class tools.refinery.interpreter.matchers.util.SingletonInstanceProvider
 
get(int) - Method in class tools.refinery.interpreter.api.GenericPatternMatch
 
get(int) - Method in class tools.refinery.interpreter.api.impl.BasePatternMatch
 
get(int) - Method in interface tools.refinery.interpreter.api.IPatternMatch
Returns the value of the parameter at the given position, or null if position is invalid.
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple0
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple1
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple2
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple3
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple4
 
get(int) - Method in interface tools.refinery.interpreter.matchers.tuple.ITuple
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple1
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple2
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple3
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple4
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.MaskedTuple
 
get(int) - Method in class tools.refinery.interpreter.matchers.tuple.VolatileMaskedTuple
 
get(Object) - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
get(String) - Method in class tools.refinery.interpreter.api.GenericPatternMatch
 
get(String) - Method in interface tools.refinery.interpreter.api.IPatternMatch
Returns the value of the parameter with the given name, or null if name is invalid.
get(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
get(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
get(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Retrieves tuples that have the specified signature
get(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
get(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
get(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
get(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
get(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
get(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
get(ITuple) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
getActualParametersTuple() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternCallBasedDeferred
 
getAffectedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
getAffectedVariables() - Method in interface tools.refinery.interpreter.matchers.psystem.PConstraint
All variables affected by this constraint.
getAggregate(Accumulator) - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IMultisetAggregationOperator
 
getAggregate(AggregateResult) - Method in class tools.refinery.interpreter.matchers.psystem.aggregations.AbstractMemorylessAggregationOperator
 
getAggregate(SortedMap<T, Integer>) - Method in class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator
 
getAggregate(AverageAccumulator<Double>) - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleAverageOperator
 
getAggregate(AverageAccumulator<Integer>) - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerAverageOperator
 
getAggregate(AverageAccumulator<Long>) - Method in class tools.refinery.interpreter.matchers.aggregators.LongAverageOperator
 
getAggregatedColumn() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
getAggregateResultType() - Method in class tools.refinery.interpreter.matchers.psystem.aggregations.BoundAggregator
 
getAggregateResultTypeAsInputKey() - Method in class tools.refinery.interpreter.matchers.psystem.aggregations.BoundAggregator
 
getAggregator() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
getAggregatorLogic(Class<?>) - Method in class tools.refinery.interpreter.matchers.aggregators.avg
 
getAggregatorLogic(Class<?>) - Method in class tools.refinery.interpreter.matchers.aggregators.count
 
getAggregatorLogic(Class<?>) - Method in class tools.refinery.interpreter.matchers.aggregators.max
 
getAggregatorLogic(Class<?>) - Method in class tools.refinery.interpreter.matchers.aggregators.min
 
getAggregatorLogic(Class<?>) - Method in class tools.refinery.interpreter.matchers.aggregators.sum
 
getAggregatorLogic(Class<?>) - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IAggregatorFactory
Given type parameters selected from AggregatorType annotations, returns a run-time aggregator operator that is bound to the actual types.
getAllAnnotations() - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
getAllAnnotations() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getAllAnnotations() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQueryHeader
Returns the list of annotations specified for this query
getAllAttributeNames() - Method in class tools.refinery.interpreter.matchers.psystem.annotations.PAnnotation
Returns a set of all attribute names used in this annotation
getAllDeducedVariables() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
Variables which have been assigned a value; includes visible variables (see SubPlan.getVisibleVariables()) and additionally any variables hidden by a projection (see PProject).
getAllEnforcedConstraints() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
All constraints that are known to hold at this point
getAllImpliedTypeJudgements(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
The closure of all type judgments of enforced constraints at this point.
getAllMatches() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getAllMatches() - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns the set of all pattern matches.
getAllMatches(Object[]) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Returns the set of all matches of the pattern that conform to the given fixed values of some parameters.
getAllMatches(Match) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getAllMatches(Match) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns the set of all matches of the pattern that conform to the given fixed values of some parameters.
getAllMatches(TupleMask, ITuple) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Returns the set of all matches of the pattern that conform to the given fixed values of some parameters.
getAllReferredQueries() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getAllReferredQueries() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PDisjunction
Returns all queries required to evaluate this query (transitively).
getAllReferredQueries() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQuery
Returns all queries required to evaluate this query (transitively).
getAllSurrogateQueries() - Method in class tools.refinery.interpreter.matchers.context.surrogate.SurrogateQueryRegistry
 
getAllUnaryTypeRestrictions(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.PBody
All unary input keys directly prescribed by constraints, grouped by variable.
getAllValues(String) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getAllValues(String) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Retrieve the set of values that occur in matches for the given parameterName.
getAllValues(String) - Method in class tools.refinery.interpreter.matchers.psystem.annotations.PAnnotation
Returns all values of a selected attribute
getAllValues(String, Match) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getAllValues(String, Match) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Retrieve the set of values that occur in matches for the given parameterName, that conforms to the given fixed values of some parameters.
getAllVariables() - Method in class tools.refinery.interpreter.matchers.psystem.PBody
 
getAnnotationsByName(String) - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
getAnnotationsByName(String) - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getAnnotationsByName(String) - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQueryHeader
Returns the list of annotations with a specified name
getAnyUnenforcedConstraint(PBody, SubPlan) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.BuildHelper
Finds an arbitrary constraint that is not enforced at the given plan.
getAppearCallback() - Method in class tools.refinery.interpreter.api.MatchUpdateAdapter
 
getAPrioriVariables() - Method in class tools.refinery.interpreter.matchers.planning.operations.PStart
 
getArity() - Method in class tools.refinery.interpreter.matchers.context.common.JavaTransitiveInstancesKey
 
getArity() - Method in interface tools.refinery.interpreter.matchers.context.IInputKey
The width of tuples in this relation.
getBackendClass() - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackendFactory
The backend instances created by this factory are guaranteed to conform to the returned class.
getBackendHintSettings() - Method in class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
Each entry in the immutable map overrides backend-specific options regarding query evaluation.
getBaseIndex() - Method in class tools.refinery.interpreter.api.InterpreterEngine
Provides access to the internal base index component of the engine, responsible for keeping track of basic contents of the model.
getBaseIndex() - Method in interface tools.refinery.interpreter.api.scope.IEngineContext
Returns the base index.
getBaseIndex() - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getBodies() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PDisjunction
Returns an immutable set of bodies that consists of this disjunction
getBody() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
 
getBody() - Method in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
getBody() - Method in interface tools.refinery.interpreter.matchers.psystem.PConstraint
 
getCachingResultProvider(PQuery) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getCachingResultProvider(PQuery) - Method in interface tools.refinery.interpreter.matchers.context.IQueryCacheContext
Returns a caching result provider for the given query; it must be constructed if it does not exist yet.
getCancellationToken() - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
 
getCandidateQuantifiedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
getCandidateQuantifiedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
getCandidateQuantifiedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.NegativePatternCall
 
getCandidateQuantifiedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternCallBasedDeferred
 
getCandidateQuantifiedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternMatchCounter
 
getCanonicalTraceables(PTraceable) - Method in interface tools.refinery.interpreter.matchers.psystem.rewriters.IPTraceableTraceProvider
Find and return the canonical PTraceables in the original query which are the sources of the given derivative PTraceable according to the transformation.
getCanonicalTraceables(PTraceable) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.MappingTraceCollector
 
getCanonicalTraceables(PTraceable) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.NopTraceCollector
 
getCapabilities() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getConditionalImplications(IInputKey) - Method in class tools.refinery.interpreter.matchers.context.AbstractQueryMetaContext
 
getConditionalImplications(IInputKey) - Method in interface tools.refinery.interpreter.matchers.context.IQueryMetaContext
Returns known "double dispatch" implications, where the given implying key implies other input keys under certain additional conditions (themselves input keys).
getConditionalImpliedJudgements(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.TypeJudgement
 
getConnectivity() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.RepresentativeElectionConstraint
 
getConstraints() - Method in class tools.refinery.interpreter.matchers.psystem.PBody
 
getConstraintsOfType(Class<ConstraintType>) - Method in class tools.refinery.interpreter.matchers.psystem.PBody
 
getContainerDisjunction() - Method in class tools.refinery.interpreter.matchers.psystem.PBody
Returns the disjunction the body is contained with.
getCopiedBody() - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
Returns the body with the copied variables and constraints.
getCount(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
getCount(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
getCount(T) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
getCount(T) - Method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
getCount(T) - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
Returns the number of occurrences of the given value.
getCount(T) - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
getCount(Value) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
getCount(Value) - Method in class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
getCountAtInfinity() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
Returns the number of tuples that are present at the moment 'infinity'.
getCounter(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
On-demand initializes and returns the counter for the given tuple and timestamp.
getCountUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
getCountUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
getCountUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
getCountUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
getCountUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
getCountUnsafe(Object) - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
Returns the number of occurrences of the given value (which may be of any type).
getCountUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
getCountUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
getCurrentMatchers() - Method in class tools.refinery.interpreter.api.InterpreterEngine
Access a copy of available InterpreterMatcher pattern matchers.
getCurrentMatchers() - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getDeclaredUnaryType() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PParameter
Yield an IInputKey representation of the type declared for this parameter.
getDeducedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
getDeducedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.BaseTypeSafeConstraint
 
getDeducedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Equality
 
getDeducedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExportedParameter
 
getDeducedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Inequality
 
getDeducedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
getDeducedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.NegativePatternCall
 
getDeducedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternMatchCounter
 
getDeducedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.TypeFilterConstraint
 
getDeducedVariables() - Method in class tools.refinery.interpreter.matchers.psystem.EnumerablePConstraint
 
getDeducedVariables() - Method in interface tools.refinery.interpreter.matchers.psystem.PConstraint
The set of variables whose potential values can be enumerated (once all non-deduced variables have known values).
getDefault() - Static method in class tools.refinery.interpreter.api.InterpreterEngineOptions
 
getDefaultBackendFactory() - Method in class tools.refinery.interpreter.api.InterpreterEngineOptions
Returns the configured default backend
getDefaultCachingBackendFactory() - Method in class tools.refinery.interpreter.api.InterpreterEngineOptions
Returns the configured default caching backend.
getDefaultLogger() - Static method in class tools.refinery.interpreter.util.InterpreterLoggingUtil
 
getDefaultSearchBackendFactory() - Method in class tools.refinery.interpreter.api.InterpreterEngineOptions
Returns the configured default search-based backend.
getDefaultValue() - Method in class tools.refinery.interpreter.matchers.backend.QueryHintOption
Returns the default value of this hint option, which is to be used by query backends in the case no overriding value is assigned.
getDefaultValue() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
getDeferringVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.BaseTypeSafeConstraint
 
getDeferringVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExportedParameter
 
getDeferringVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Inequality
 
getDeferringVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternCallBasedDeferred
 
getDeferringVariables() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.TypeFilterConstraint
 
getDeferringVariables() - Method in class tools.refinery.interpreter.matchers.psystem.VariableDeferredPConstraint
 
getDeltaConstraints() - Method in class tools.refinery.interpreter.matchers.planning.operations.PApply
 
getDeltaConstraints() - Method in class tools.refinery.interpreter.matchers.planning.operations.PEnumerate
 
getDeltaConstraints() - Method in class tools.refinery.interpreter.matchers.planning.operations.PJoin
 
getDeltaConstraints() - Method in class tools.refinery.interpreter.matchers.planning.operations.POperation
Newly enforced constraints
getDeltaConstraints() - Method in class tools.refinery.interpreter.matchers.planning.operations.PProject
 
getDeltaConstraints() - Method in class tools.refinery.interpreter.matchers.planning.operations.PStart
 
getDeltaEnforcedConstraints() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
The new constraints enforced at this stage of plan, that aren't yet enforced at parents (results are also included in SubPlan.getAllEnforcedConstraints())
getDirection() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PParameter
 
getDirection() - Method in class tools.refinery.interpreter.matchers.util.Signed
 
getDirectJudgements(Set<PConstraint>, IQueryMetaContext) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.TypeHelper
Gets direct judgements reported by constraints.
getDirectlyImpliedJudgements(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.TypeJudgement
 
getDirectReferredQueries() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getDirectReferredQueries() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PDisjunction
Returns all queries directly referred in the constraints.
getDirectReferredQueries() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQuery
Returns all queries directly referred in the constraints.
getDirectUnifiedInto() - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
 
getDisappearCallback() - Method in class tools.refinery.interpreter.api.MatchUpdateAdapter
 
getDisjunctBodies() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getDisjunctBodies() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQuery
Returns all bodies associated with the query in their canonical form.
getDistinctElements() - Method in class tools.refinery.interpreter.matchers.tuple.AbstractTuple
 
getDistinctElements() - Method in interface tools.refinery.interpreter.matchers.tuple.ITuple
 
getDomainType() - Method in class tools.refinery.interpreter.matchers.psystem.aggregations.BoundAggregator
 
getDomainTypeAsInputKey() - Method in class tools.refinery.interpreter.matchers.psystem.aggregations.BoundAggregator
 
getDynamicSurrogateQueries() - Method in class tools.refinery.interpreter.matchers.context.surrogate.SurrogateQueryRegistry
 
getElements() - Method in class tools.refinery.interpreter.matchers.tuple.AbstractTuple
As the tuple is supposed to be immutable, do not modify the returned array.
getElements() - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple
 
getElements() - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple0
 
getElements() - Method in interface tools.refinery.interpreter.matchers.tuple.ITuple
As the tuple is supposed to be immutable, do not modify the returned array.
getEngine() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getEngine() - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns the engine that the matcher uses.
getEngineDefaultHints() - Method in class tools.refinery.interpreter.api.InterpreterEngineOptions
 
getEngineOptions() - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Returns the immutable InterpreterEngineOptions of the engine.
getEngineOptions() - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getEnumerablePConstraint() - Method in class tools.refinery.interpreter.matchers.planning.operations.PEnumerate
 
getEquivalentJudgement() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.TypeFilterConstraint
 
getEquivalentJudgement() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.TypeConstraint
 
getEquivalentJudgement() - Method in interface tools.refinery.interpreter.matchers.psystem.ITypeConstraint
 
getEvaluationHints() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getEvaluationHints() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQuery
Optional hints regarding the query evaluation strategy, to be interpreted by the query engine.
getEvaluator() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExpressionEvaluation
 
getEvaluator() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.RelationEvaluation
 
getException() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PProblem
 
getExistingMatcher(IQuerySpecification<Matcher>) - Method in class tools.refinery.interpreter.api.InterpreterEngine
Access an existing pattern matcher based on a IQuerySpecification.
getExistingMatcher(IQuerySpecification<Matcher>) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getExistingMatcher(IQuerySpecification<Matcher>, QueryEvaluationHint) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Access an existing pattern matcher based on a IQuerySpecification, and optional hints override.
getExistingMatcher(IQuerySpecification<Matcher>, QueryEvaluationHint) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getFactory() - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackend
 
getFactory() - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackendFactoryProvider
Returns a query backend factory instance.
getFirstAnnotationByName(String) - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
getFirstAnnotationByName(String) - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getFirstAnnotationByName(String) - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQueryHeader
Returns the first annotation with a specified name
getFirstOmittedIndex() - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Returns the first index of the source that is not selected by the mask, or empty if all indices are selected.
getFirstValue(String) - Method in class tools.refinery.interpreter.matchers.psystem.annotations.PAnnotation
Returns the value of the first occurrence of an attribute
getFirstValue(String, Class<T>) - Method in class tools.refinery.interpreter.matchers.psystem.annotations.PAnnotation
Returns the value of the first occurrence of an attribute
getFullyQualifiedName() - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
getFullyQualifiedName() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQueryHeader
Identifies the pattern for which matchers can be instantiated.
getFunctionalDependencies(Set<? extends PConstraint>, boolean) - Method in class tools.refinery.interpreter.matchers.psystem.analysis.QueryAnalyzer
Functional dependency information, expressed on PVariables within a body, that the selected constraints imply.
getFunctionalDependencies(IInputKey) - Method in interface tools.refinery.interpreter.matchers.context.IQueryMetaContext
Returns functional dependencies of the input key expressed in terms of column indices.
getFunctionalDependencies(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
getFunctionalDependencies(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
getFunctionalDependencies(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Equality
 
getFunctionalDependencies(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExpressionEvaluation
 
getFunctionalDependencies(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternMatchCounter
 
getFunctionalDependencies(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.TypeFilterConstraint
 
getFunctionalDependencies(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.ConstantValue
 
getFunctionalDependencies(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.TypeConstraint
 
getFunctionalDependencies(IQueryMetaContext) - Method in interface tools.refinery.interpreter.matchers.psystem.PConstraint
A (preferably minimal) cover of known functional dependencies between variables.
getFunctionalDependencies(IQueryMetaContext, IInputKey, Tuple) - Static method in class tools.refinery.interpreter.matchers.psystem.ITypeConstraint.TypeConstraintUtil
 
getHintProvider() - Method in interface tools.refinery.interpreter.matchers.context.IQueryBackendContext
 
getImplications(IInputKey) - Method in interface tools.refinery.interpreter.matchers.context.IQueryMetaContext
Returns known direct implications, e.g.
getImpliedIndices() - Method in class tools.refinery.interpreter.matchers.context.InputKeyImplication
The implied instance tuple consists of the values in the implying tuple at these indices.
getImpliedJudgements(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
getImpliedJudgements(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
getImpliedJudgements(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.TypeFilterConstraint
 
getImpliedJudgements(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.AbstractTransitiveClosure
 
getImpliedJudgements(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.PositivePatternCall
 
getImpliedJudgements(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.RepresentativeElectionConstraint
 
getImpliedJudgements(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.TypeConstraint
 
getImpliedJudgements(IQueryMetaContext) - Method in interface tools.refinery.interpreter.matchers.psystem.ITypeInfoProviderConstraint
Returns type information implied by this constraint.
getImpliedKey() - Method in class tools.refinery.interpreter.matchers.context.InputKeyImplication
An instance tuple of this input key is implied by another key.
getImplyingKey() - Method in class tools.refinery.interpreter.matchers.context.InputKeyImplication
Optional.
getIndicesAsList() - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
 
getInputArities() - Method in interface tools.refinery.interpreter.matchers.psystem.IRelationEvaluator
For each input relation that this evaluator requires, this method returns the expected arities of the relations in order.
getInputKey() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.TypeFilterConstraint
 
getInputKey() - Method in class tools.refinery.interpreter.matchers.psystem.TypeJudgement
 
getInputParameterNames() - Method in interface tools.refinery.interpreter.matchers.psystem.IExpressionEvaluator
All input parameter names should be reported correctly.
getInstanceClass() - Method in class tools.refinery.interpreter.matchers.context.common.JavaTransitiveInstancesKey
 
getInternal(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
getInternal(Object) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
getInternalQueryRepresentation() - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
getInternalQueryRepresentation() - Method in interface tools.refinery.interpreter.api.IQuerySpecification
Returns the definition of the query in a format intended for consumption by the query evaluator.
getIntroducedVariables() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
Delta compared to first parent: variables that are visible here but were not visible at the first parent.
getKeysetSize() - Method in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
getKeysetSize() - Method in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
getKeysetSize() - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
 
getKeysetSize() - Method in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
getKeysetSize() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
getKeysetSize() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
getKeysetSize() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
getKeysetSize() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
getKeysetSize() - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
getLevel() - Method in interface tools.refinery.interpreter.api.InterpreterModelUpdateListener
This may be queried only ONCE (!!!) at the registration of the listener.
getLocalSize() - Method in class tools.refinery.interpreter.matchers.tuple.BaseLeftInheritanceTuple
 
getLocalSize() - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple
 
getLocalSize() - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple1
 
getLocalSize() - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple2
 
getLocalSize() - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple3
 
getLocalSize() - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple4
 
getLocation() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PProblem
 
getLogger() - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getLogger() - Method in interface tools.refinery.interpreter.matchers.context.IQueryBackendContext
 
getLogger(Class<?>) - Static method in class tools.refinery.interpreter.util.InterpreterLoggingUtil
Provides a class-specific logger that also stores the global logger settings of the Refinery Interpreter runtime
getLogger(Class<?>, String) - Static method in class tools.refinery.interpreter.util.InterpreterLoggingUtil
Provides a named logger that also stores the global logger settings of the Refinery Interpreter runtime
getMask() - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
The mask according to which tuples are projected and indexed.
getMatcher(String) - Method in class tools.refinery.interpreter.api.InterpreterEngine
Access a pattern matcher for the graph pattern with the given fully qualified name.
getMatcher(String) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getMatcher(InterpreterEngine) - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
getMatcher(InterpreterEngine) - Method in interface tools.refinery.interpreter.api.IQuerySpecification
Initializes the pattern matcher within an existing InterpreterEngine.
getMatcher(IQuerySpecification<Matcher>) - Method in class tools.refinery.interpreter.api.InterpreterEngine
Access a pattern matcher based on a IQuerySpecification.
getMatcher(IQuerySpecification<Matcher>) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getMatcher(IQuerySpecification<Matcher>, QueryEvaluationHint) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Access a pattern matcher based on a IQuerySpecification, overriding some of the default query evaluation hints.
getMatcher(IQuerySpecification<Matcher>, QueryEvaluationHint) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getMax() - Static method in class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator
 
getMetaContext() - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Provides metamodel-specific info independent of the runtime instance model.
getMin() - Static method in class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator
 
getMonotonousID() - Method in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
getMonotonousID() - Method in interface tools.refinery.interpreter.matchers.psystem.PConstraint
Returns an integer ID that is guaranteed to increase strictly monotonously for constraints within a pBody.
getName() - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleAverageOperator
 
getName() - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleSumOperator
 
getName() - Method in class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator
 
getName() - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerAverageOperator
 
getName() - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerSumOperator
 
getName() - Method in class tools.refinery.interpreter.matchers.aggregators.LongAverageOperator
 
getName() - Method in class tools.refinery.interpreter.matchers.aggregators.LongSumOperator
 
getName() - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IMultisetAggregationOperator
A name or identifier of the operator.
getName() - Method in class tools.refinery.interpreter.matchers.psystem.annotations.PAnnotation
Return the name of the annotation
getName() - Method in class tools.refinery.interpreter.matchers.psystem.annotations.ParameterReference
 
getName() - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
 
getName() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PParameter
 
getNextContainer() - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
getOneArbitraryMatch() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getOneArbitraryMatch() - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns an arbitrarily chosen pattern match.
getOneArbitraryMatch(Object[]) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Returns an arbitrarily chosen match of the pattern that conforms to the given fixed values of some parameters.
getOneArbitraryMatch(Match) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getOneArbitraryMatch(Match) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns an arbitrarily chosen match of the pattern that conforms to the given fixed values of some parameters.
getOneArbitraryMatch(TupleMask, ITuple) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Returns an arbitrarily chosen match of the pattern that conforms to the given fixed values of some parameters.
getOperation() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
 
getOperator() - Method in class tools.refinery.interpreter.matchers.psystem.aggregations.BoundAggregator
 
getOptionalColumn() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
getOrCreateVariableByName(String) - Method in class tools.refinery.interpreter.matchers.psystem.PBody
Finds and returns a PVariable by name.
getOrEmpty(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Retrieves tuples that have the specified signature.
getOrEmptyWithTimeline(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Retrieves tuples with their associated timelines that have the specified signature.
getOutputArity() - Method in interface tools.refinery.interpreter.matchers.psystem.IRelationEvaluator
Returns the arity of the output relation that this evaluator computes.
getOutputVariable() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.BaseTypeSafeConstraint
 
getOwner() - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
The node owning this memory.
getParameter(String) - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQueryHeader
Returns a parameter by name if exists
getParameterName() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExportedParameter
The name of the parameter; usually, it is expected that ExportedParameter.getParameterVariable() is more useful, except maybe for debugging purposes.
getParameterNames() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getParameterNames() - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
getParameterNames() - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns the array of symbolic parameter names.
getParameterNames() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getParameterNames() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQueryHeader
Return the list of parameter names
getParameters() - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
getParameters() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQueryHeader
Returns a list of parameter descriptions
getParameterVariable() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExportedParameter
 
getParentPlans() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
 
getPartition(V) - Method in class tools.refinery.interpreter.matchers.algorithms.UnionFind
Returns the partition in which the given element can be found, or null otherwise.
getPartitionHeads() - Method in class tools.refinery.interpreter.matchers.algorithms.UnionFind
 
getPartitions() - Method in class tools.refinery.interpreter.matchers.algorithms.UnionFind
Returns all partitions.
getPattern() - Method in class tools.refinery.interpreter.matchers.psystem.PBody
 
getPatternDescription() - Method in exception class tools.refinery.interpreter.matchers.planning.QueryProcessingException
 
getPatternName() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getPatternName() - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Fully qualified name of the pattern.
getPatternParameter() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExportedParameter
 
getPayload() - Method in class tools.refinery.interpreter.matchers.util.Signed
 
getPConstraint() - Method in class tools.refinery.interpreter.matchers.planning.operations.PApply
 
getPosetComparator(Iterable<IInputKey>) - Method in class tools.refinery.interpreter.matchers.context.AbstractQueryMetaContext
 
getPosetComparator(Iterable<IInputKey>) - Method in interface tools.refinery.interpreter.matchers.context.IQueryMetaContext
Returns an IPosetComparator for the given set of IInputKeys.
getPositionOfParameter(String) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getPositionOfParameter(String) - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
getPositionOfParameter(String) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns the index of the symbolic parameter with the given name.
getPositionOfParameter(String) - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getPositionOfParameter(String) - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQueryHeader
Returns the index of a named parameter
getPProblems() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getPProblems() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQuery
Returns a list describing the problems that were found in this query.
getPreferredScopeClass() - Method in interface tools.refinery.interpreter.api.IQuerySpecification
The query is formulated over this kind of modeling platform.
getPrettyPrintableName() - Method in class tools.refinery.interpreter.matchers.context.common.JavaTransitiveInstancesKey
 
getPrettyPrintableName() - Method in interface tools.refinery.interpreter.matchers.context.IInputKey
A user-friendly name that can be shown on screen for debug purposes, included in exceptions, etc.
getProjectedFunctionalDependencies(PQuery, boolean) - Method in class tools.refinery.interpreter.matchers.psystem.analysis.QueryAnalyzer
Functional dependency information, expressed on query parameters, that the match set of the query is guaranteed to respect.
getPSystem() - Method in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
For backwards compatibility.
getQualifiedName() - Method in class tools.refinery.interpreter.matchers.backend.QueryHintOption
Returns the qualified name, a unique string identifier of the option.
getQuery() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PDisjunction
Returns the corresponding query specification.
getQueryAnalyzer() - Method in interface tools.refinery.interpreter.matchers.context.IQueryBackendContext
 
getQueryBackend() - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
The underlying query evaluator backend.
getQueryBackend(IQueryBackendFactory) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Provides access to the selected query backend component of the Refinery Interpreter engine.
getQueryBackend(IQueryBackendFactory) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
Provides access to the selected query backend component of the Refinery Interpreter engine.
getQueryBackendFactory() - Method in class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
A suggestion for choosing the query evaluator algorithm.
getQueryBackendFactory(QueryEvaluationHint) - Method in class tools.refinery.interpreter.api.InterpreterEngineOptions
 
getQueryBackendRequirementType() - Method in class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
Returns the backend requirement described by this hint.
getQueryCacheContext() - Method in interface tools.refinery.interpreter.matchers.context.IQueryBackendContext
 
getQueryEvaluationHint(PQuery) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getQueryEvaluationHint(PQuery) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackendHintProvider
Suggests query evaluation hints regarding a query.
getQueryRuntimeContext() - Method in interface tools.refinery.interpreter.api.scope.IEngineContext
Provides instance model information for pattern matching.
getReferredQueries() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.RelationEvaluation
 
getReferredQueries() - Method in interface tools.refinery.interpreter.matchers.psystem.IMultiQueryReference
 
getReferredQueries() - Method in interface tools.refinery.interpreter.matchers.psystem.IQueryReference
 
getReferredQuery() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternCallBasedDeferred
 
getReferredQuery() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.AbstractTransitiveClosure
 
getReferredQuery() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.PositivePatternCall
 
getReferredQuery() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.RepresentativeElectionConstraint
 
getReferredQuery() - Method in interface tools.refinery.interpreter.matchers.psystem.IQueryReference
 
getReferringConstraints() - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
 
getReferringConstraintsOfType(Class<ConstraintType>) - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
 
getRegisteredQuerySpecifications() - Method in class tools.refinery.interpreter.api.InterpreterEngine
 
getRegisteredSurrogateQueries() - Method in class tools.refinery.interpreter.matchers.context.surrogate.SurrogateQueryRegistry
 
getRemovalReasons(PTraceable) - Method in interface tools.refinery.interpreter.matchers.psystem.rewriters.IPTraceableTraceProvider
Returns the reasons for which the traceable element has been removed by the rewriters.
getRemovalReasons(PTraceable) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.MappingTraceCollector
 
getRemovalReasons(PTraceable) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.NopTraceCollector
 
getRequiredMatcherCapability(PQuery, QueryEvaluationHint) - Method in interface tools.refinery.interpreter.matchers.context.IQueryBackendContext
 
getResultProvider(IQuerySpecification<?>) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
Returns an internal interface towards the query backend to feed the matcher with results.
getResultProvider(IQuerySpecification<?>, QueryEvaluationHint) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
Returns an internal interface towards the query backend to feed the matcher with results.
getResultProvider(PQuery) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackend
Returns a result provider for a given query.
getResultProvider(PQuery, QueryEvaluationHint) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getResultProvider(PQuery, QueryEvaluationHint) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackend
Returns a result provider for a given query.
getResultProvider(PQuery, QueryEvaluationHint) - Method in interface tools.refinery.interpreter.matchers.context.IQueryResultProviderAccess
Get a result provider for the given PQuery, which conforms the capabilities requested by the given QueryEvaluationHint object.
getResultProviderAccess() - Method in interface tools.refinery.interpreter.matchers.context.IQueryBackendContext
 
getResultProviderOfMatcher(InterpreterMatcher<? extends IPatternMatch>) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Return the underlying result provider for the given matcher.
getResultProviderOfMatcher(InterpreterMatcher<? extends IPatternMatch>) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getResultVariable() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
getResultVariable() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
getResultVariable() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternMatchCounter
 
getResumableSignatures() - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
 
getResumableSignatures() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
getResumableSignatures() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
getResumableSignatures() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
getResumableSignatures() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
getResumableSignatures() - Method in interface tools.refinery.interpreter.matchers.util.resumable.MaskedResumable
Returns the set of signatures for which lazy folding shall be resumed at the next timestamp.
getResumableTimestamp() - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
 
getResumableTimestamp() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
getResumableTimestamp() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
getResumableTimestamp() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
getResumableTimestamp() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
getResumableTimestamp() - Method in interface tools.refinery.interpreter.matchers.util.resumable.Resumable
Returns the smallest timestamp where lazy folding shall be resumed, or null if there is no more folding to do in this resumable.
getResumableTimestamp() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
getResumableTuples() - Method in interface tools.refinery.interpreter.matchers.util.resumable.UnmaskedResumable
Returns the set of tuples for which lazy folding shall be resumed at the next timestamp.
getResumableTuples() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
getRewrittenTraceables(PTraceable) - Method in interface tools.refinery.interpreter.matchers.psystem.rewriters.IPTraceableTraceProvider
Find and return the PTraceables in the rewritten query which are the destinations of the given source PTraceable according to the transformation.
getRewrittenTraceables(PTraceable) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.MappingTraceCollector
 
getRewrittenTraceables(PTraceable) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.NopTraceCollector
 
getRuntimeContext() - Method in interface tools.refinery.interpreter.matchers.context.IQueryBackendContext
 
getScope() - Method in class tools.refinery.interpreter.api.InterpreterEngine
 
getScope() - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
getShortDescription() - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleAverageOperator
 
getShortDescription() - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleSumOperator
 
getShortDescription() - Method in class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator
 
getShortDescription() - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerAverageOperator
 
getShortDescription() - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerSumOperator
 
getShortDescription() - Method in class tools.refinery.interpreter.matchers.aggregators.LongAverageOperator
 
getShortDescription() - Method in class tools.refinery.interpreter.matchers.aggregators.LongSumOperator
 
getShortDescription() - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IMultisetAggregationOperator
A textual description of the operator.
getShortDescription() - Method in interface tools.refinery.interpreter.matchers.psystem.IExpressionEvaluator
A textual description of the expression.
getShortDescription() - Method in interface tools.refinery.interpreter.matchers.psystem.IRelationEvaluator
A textual description of the evaluator.
getShortMessage() - Method in exception class tools.refinery.interpreter.exception.InterpreterException
 
getShortMessage() - Method in exception class tools.refinery.interpreter.matchers.planning.QueryProcessingException
 
getShortMessage() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PProblem
 
getShortName() - Method in class tools.refinery.interpreter.matchers.planning.operations.PApply
 
getShortName() - Method in class tools.refinery.interpreter.matchers.planning.operations.PEnumerate
 
getShortName() - Method in class tools.refinery.interpreter.matchers.planning.operations.PJoin
 
getShortName() - Method in class tools.refinery.interpreter.matchers.planning.operations.POperation
 
getShortName() - Method in class tools.refinery.interpreter.matchers.planning.operations.PProject
 
getShortName() - Method in class tools.refinery.interpreter.matchers.planning.operations.PStart
 
getSignatures() - Method in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
getSignatures() - Method in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
getSignatures() - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Retrieves a read-only view of exactly those signatures for which at least one tuple is stored
getSignatures() - Method in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
getSignatures() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
getSignatures() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
getSignatures() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
getSignatures() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
getSignatures() - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
getSigned(int) - Method in class tools.refinery.interpreter.matchers.util.timeline.CompactTimeline
 
getSigned(int) - Method in class tools.refinery.interpreter.matchers.util.timeline.SingletonTimeline
 
getSigned(int) - Method in class tools.refinery.interpreter.matchers.util.timeline.Timeline
 
getSimpleName() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQueryHeader
Returns the non-qualified name of the query.
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple0
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple1
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple2
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple3
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple4
 
getSize() - Method in interface tools.refinery.interpreter.matchers.tuple.ITuple
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple1
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple2
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple3
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple4
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.MaskedTuple
 
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Returns the size of the masked tuples described by this mask
getSize() - Method in class tools.refinery.interpreter.matchers.tuple.VolatileMaskedTuple
 
getSourceWidth() - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Returns the size of the original tuples handled by this mask
getSpecification() - Method in class tools.refinery.interpreter.api.GenericPatternMatcher
 
getSpecification() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
getSpecification() - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
The pattern that will be matched.
getSpecifications() - Method in class tools.refinery.interpreter.api.GenericQueryGroup
 
getSpecifications() - Method in class tools.refinery.interpreter.api.impl.BaseGeneratedPatternGroup
 
getSpecifications() - Method in interface tools.refinery.interpreter.api.IQueryGroup
Returns the currently assigned IQuerySpecifications.
getStatus() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getStatus() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQuery
Returns the initialization status of the definition
getStringID() - Method in class tools.refinery.interpreter.matchers.context.common.JavaTransitiveInstancesKey
 
getStringID() - Method in interface tools.refinery.interpreter.matchers.context.IInputKey
An internal string identifier that can be used to uniquely identify to input key (relevant for distributed applications).
getSuggestedEliminationOrdering() - Method in class tools.refinery.interpreter.matchers.context.AbstractQueryMetaContext
 
getSuggestedEliminationOrdering() - Method in interface tools.refinery.interpreter.matchers.context.IQueryMetaContext
For query normalizing, this is the order suggested for trying to eliminate input keys.
getSupplierKey() - Method in class tools.refinery.interpreter.matchers.psystem.KeyedEnumerablePConstraint
 
getSurrogateQuery(IInputKey) - Method in class tools.refinery.interpreter.matchers.context.surrogate.SurrogateQueryRegistry
 
getSymbolicParameters() - Method in class tools.refinery.interpreter.matchers.psystem.PBody
Returns the exported parameter constraints of the body.
getSymbolicParameterVariables() - Method in class tools.refinery.interpreter.matchers.psystem.PBody
Returns the symbolic parameters of the body.
getTotalSize() - Method in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
getTotalSize() - Method in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
getTotalSize() - Method in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
getTotalSize() - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
 
getTotalSize() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
getTotalSize() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
getTotalSize() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
getTotalSize() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
getTotalSize() - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
getToVariables() - Method in class tools.refinery.interpreter.matchers.planning.operations.PProject
 
getTraceables(PQuery) - Static method in class tools.refinery.interpreter.matchers.psystem.queries.PQueries
Returns all PTraceables contained in the given PQuery: itself, its bodies and their constraints.
getTraceCollector() - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.AbstractRewriterTraceSource
 
getTraces() - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.AbstractRewriterTraceSource
 
getTuplesAtInfinity() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
getTypeGuarantees() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getTypeGuarantees() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQuery
Type information, expressed on query parameters, that all matches of the query are guaranteed to respect.
getTypeName() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PParameter
Returns a textual representation of the declared type of the parameter
getTypesImpliedByCall(PQuery, Tuple) - Static method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.PositivePatternCall
 
getUnifiedIntoRoot() - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
 
getUniqueVariables() - Method in class tools.refinery.interpreter.matchers.psystem.PBody
 
getUniverseType() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.BinaryReflexiveTransitiveClosure
Returns the type whose instances should be returned as 0-long paths.
getUnsigned(int) - Method in class tools.refinery.interpreter.matchers.util.timeline.CompactTimeline
 
getUnsigned(int) - Method in class tools.refinery.interpreter.matchers.util.timeline.SingletonTimeline
 
getUnsigned(int) - Method in class tools.refinery.interpreter.matchers.util.timeline.Timeline
 
getValue(Object, Class<? extends T>, Supplier<T>) - Method in interface tools.refinery.interpreter.matchers.util.ICache
Return a selected value for the key object.
getValue(Object, Class<? extends T>, Supplier<T>) - Method in class tools.refinery.interpreter.matchers.util.PurgableCache
 
getValue(String) - Method in interface tools.refinery.interpreter.matchers.psystem.IValueProvider
Returns the value of the selected variable
getValue(String) - Method in class tools.refinery.interpreter.matchers.tuple.TupleValueProvider
 
getValue(ITuple, int) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Returns a selected masked value from the selected tuple.
getValueOrDefault(QueryEvaluationHint) - Method in class tools.refinery.interpreter.matchers.backend.QueryHintOption
Returns the value of this hint option from the given hint collection, or the default value if not defined.
getValueOrDefault(QueryHintOption<HintValue>) - Method in class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
Returns the value of the given hint option from the given hint collection, or the default value if not defined.
getValueOrNull(QueryEvaluationHint) - Method in class tools.refinery.interpreter.matchers.backend.QueryHintOption
Returns the value of this hint option from the given hint collection, or null if not defined.
getValueOrNull(QueryHintOption<HintValue>) - Method in class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
Returns the value of the given hint option from the given hint collection, or null if not defined.
getVariable() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.ConstantValue
 
getVariableByNameChecked(Object) - Method in class tools.refinery.interpreter.matchers.psystem.PBody
Find a PVariable by name
getVariableInTuple(int) - Method in class tools.refinery.interpreter.matchers.psystem.EnumerablePConstraint
 
getVariableMapping() - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
getVariablesTuple() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.TypeFilterConstraint
 
getVariablesTuple() - Method in class tools.refinery.interpreter.matchers.psystem.EnumerablePConstraint
 
getVariablesTuple() - Method in class tools.refinery.interpreter.matchers.psystem.TypeJudgement
 
getVisibility() - Method in class tools.refinery.interpreter.api.GenericQuerySpecification
 
getVisibility() - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
getVisibility() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
getVisibility() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQueryHeader
Returns the visibility information about the query.
getVisibleVariables() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
Variables which are assigned a value at this point (results are also included in SubPlan.getAllDeducedVariables())
getWeakenedAlternativeJudgements(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.TypeJudgement
 
getWeakenedAlternatives(IInputKey) - Method in class tools.refinery.interpreter.matchers.context.AbstractQueryMetaContext
 
getWeakenedAlternatives(IInputKey) - Method in interface tools.refinery.interpreter.matchers.context.IQueryMetaContext
Returns a set of implications (weakened alternatives), with a suggestion for the query planner that satisfying them first may help in satisfying the implying key.
getWho() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Equality
 
getWho() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Inequality
 
getWithTimeline(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
getWithTimeline(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
getWithTimeline(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
getWithTimeline(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Retrieves the tuples and their associated timelines that have the specified signature.
getWithTimeline(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
getWithTimeline(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
getWithTimeline(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
getWithTimeline(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
getWithTimeline(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
getWithTimestampInternal(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
getWithTimestampInternal(Object) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
getWithWhom() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Equality
 
getWithWhom() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Inequality
 
getWrappedKey() - Method in class tools.refinery.interpreter.matchers.context.common.BaseInputKeyWrapper
 
getWrapperInstanceClass() - Method in class tools.refinery.interpreter.matchers.context.common.JavaTransitiveInstancesKey
 

H

handleSingleton(Key, Bucket) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
hashCode() - Method in class tools.refinery.interpreter.api.GenericPatternMatch
 
hashCode() - Method in class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
 
hashCode() - Method in class tools.refinery.interpreter.matchers.context.common.BaseInputKeyWrapper
 
hashCode() - Method in class tools.refinery.interpreter.matchers.context.InputKeyImplication
 
hashCode() - Method in class tools.refinery.interpreter.matchers.planning.operations.PApply
 
hashCode() - Method in class tools.refinery.interpreter.matchers.planning.operations.PEnumerate
 
hashCode() - Method in class tools.refinery.interpreter.matchers.planning.operations.PJoin
 
hashCode() - Method in class tools.refinery.interpreter.matchers.planning.operations.PProject
 
hashCode() - Method in class tools.refinery.interpreter.matchers.planning.operations.PStart
 
hashCode() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
 
hashCode() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PParameter
 
hashCode() - Method in class tools.refinery.interpreter.matchers.psystem.TypeJudgement
 
hashCode() - Method in class tools.refinery.interpreter.matchers.tuple.Tuple
 
hashCode() - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
 
hashCode() - Method in class tools.refinery.interpreter.matchers.tuple.VolatileTuple
 
hashCode() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
hashCode() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
hashCode() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
hashCode() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
hashCode() - Method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
hashCode() - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
hashCode() - Method in class tools.refinery.interpreter.matchers.util.Signed
 
hashCode() - Method in class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
hashCode(IMemoryView<T>) - Static method in interface tools.refinery.interpreter.matchers.util.IMemoryView
Provides semantic hashCode() comparison.
hashCode(IMultiLookup<Key, Value>) - Static method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Provides semantic hashCode() comparison.
hasMatch() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
hasMatch() - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Indicates whether the query has any kind of matches.
hasMatch(Object[]) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Decides whether there are any matches of the pattern that conform to the given fixed values of some parameters.
hasMatch(Match) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
hasMatch(Match) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Indicates whether the given combination of specified pattern parameters constitute a valid pattern match, under any possible substitution of the unspecified parameters (if any).
hasMatch(TupleMask, ITuple) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Decides whether there are any matches of the pattern that conform to the given fixed values of some parameters.
hasSurrogateQueryFQN(IInputKey) - Method in class tools.refinery.interpreter.matchers.context.surrogate.SurrogateQueryRegistry
 
HierarchicalName() - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.IVariableRenamer.HierarchicalName
 

I

IAggregatorFactory - Interface in tools.refinery.interpreter.matchers.psystem.aggregations
Describes an aggregation operator keyword, potentially with type polymorphism.
IBaseIndex - Interface in tools.refinery.interpreter.api.scope
Represents the index maintained on the model.
ICache - Interface in tools.refinery.interpreter.matchers.util
A cache is a simple key-value pair that stores calculated values for specific key objects
ICallDelegationStrategy - Interface in tools.refinery.interpreter.matchers.backend
Function object that specifies how hints (including backend preferences) shall propagate through pattern calls.
IConstraintFilter - Interface in tools.refinery.interpreter.matchers.psystem.rewriters
Helper interface to exclude constraints from PBody copy processes
IConstraintFilter.AllowAllFilter - Class in tools.refinery.interpreter.matchers.psystem.rewriters
 
IConstraintFilter.ExportedParameterFilter - Class in tools.refinery.interpreter.matchers.psystem.rewriters
 
IDeltaBag<T> - Interface in tools.refinery.interpreter.matchers.util
An IMemory that represents the difference between two states of a set or IMultiset, and therefore may contain values with a negative multiplicity.
identity(int) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance of the given size that maps every single element intact
IdentityMaskedTupleMemory<Timestamp> - Class in tools.refinery.interpreter.matchers.memories
Specialized for identity mask; tuples are stored as a simple set/multiset memory.
IdentityMaskedTupleMemory(TupleMask, CollectionsFactory.MemoryType, Object) - Constructor for class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
IDerivativeModificationReason - Interface in tools.refinery.interpreter.matchers.psystem.rewriters
This is a role indication interface, implementations may provide a reason about why a modification is made during PQuery normalization.
IEngineContext - Interface in tools.refinery.interpreter.api.scope
The context of the engine is instantiated by the scope, and provides information and services regarding the model the towards the engine.
IExpressionEvaluator - Interface in tools.refinery.interpreter.matchers.psystem
An expression evaluator is used to execute arbitrary Java code during pattern matching.
IFlattenCallPredicate - Interface in tools.refinery.interpreter.matchers.psystem.rewriters
Interface used by the PQueryFlattener to decide which positive pattern calls to flatten
IFlattenCallPredicate.And - Class in tools.refinery.interpreter.matchers.psystem.rewriters
Flattens only if all operand predicates vote for flattening.
IIndexingErrorListener - Interface in tools.refinery.interpreter.api.scope
This interface contains callbacks for various internal errors from the
invalid reference
base index
.
IInputKey - Interface in tools.refinery.interpreter.matchers.context
An input key identifies an input (extensional) relation, such as the instance set of a given node or edge type, or the direct containment relation.
IInstanceObserver - Interface in tools.refinery.interpreter.api.scope
Listener interface for lightweight observation of changes in edges leaving from given source instance elements.
IMatcherCapability - Interface in tools.refinery.interpreter.matchers.backend
Implementations of this interface can be used to decide whether a matcher created by an arbitrary backend can potentially be used as a substitute for another matcher.
IMatchUpdateListener<Match> - Interface in tools.refinery.interpreter.api
An interface for low-level notifications about match appearance and disappearance.
IMemory<T> - Interface in tools.refinery.interpreter.matchers.util
A memory containing a positive or negative number of equal() copies for some values.
IMemoryView<T> - Interface in tools.refinery.interpreter.matchers.util
A read-only view on a memory containing a positive or negative number of equal() copies for some values.
IModifiableTuple - Interface in tools.refinery.interpreter.matchers.tuple
A tuple that allows modifying the underlying value.
IMultiLookup<Key,Value> - Interface in tools.refinery.interpreter.matchers.util
A multi-map that associates sets / multisets / delta sets of values to each key.
IMultiLookup.ChangeGranularity - Enum Class in tools.refinery.interpreter.matchers.util
How significant was the change? *
IMultiLookupAbstract<Key,Value,Bucket> - Interface in tools.refinery.interpreter.matchers.util
Specialized multimap implementation that saves memory by storing singleton value objects (multiplicity 1) instead of multiset buckets whenever there is only one value associated with a key.
IMultiLookupAbstract.ToMultisetsAbstract<Key,Value> - Interface in tools.refinery.interpreter.matchers.util
A multi-lookup whose buckets are multisets.
IMultiLookupAbstract.ToSetsAbstract<Key,Value> - Interface in tools.refinery.interpreter.matchers.util
A multi-lookup whose buckets are sets.
IMultiQueryReference - Interface in tools.refinery.interpreter.matchers.psystem
A PConstraint that implements this interface refers to a list of PQueries.
IMultiset<T> - Interface in tools.refinery.interpreter.matchers.util
An IMemory that always contains values with a nonnegative multiplicity.
IMultisetAggregationOperator<Domain,Accumulator,AggregateResult> - Interface in tools.refinery.interpreter.matchers.psystem.aggregations
A single column aggregator is used to incrementally compute the aggregate of a multiset of values according to an aggregator operator.
IN - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.queries.PParameterDirection
The parameters marked with this constraints shall be set to a value before calling the pattern
includeDependencies(Map<Set<A>, Set<A>>, Map<Set<A>, Set<A>>) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.FunctionalDependencyHelper
Adds all given dependencies to a mutable accumulator.
includeDependency(Map<Set<A>, Set<A>>, Set<A>, Set<A>) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.FunctionalDependencyHelper
Adds a given dependency to a mutable accumulator.
INDEX - Enum constant in enum class tools.refinery.interpreter.api.InterpreterModelUpdateListener.ChangeLevel
 
IndexingService - Enum Class in tools.refinery.interpreter.matchers.context
These are the different services which can be provided by an IQueryRuntimeContext implementation.
indices - Variable in class tools.refinery.interpreter.matchers.tuple.TupleMask
indices[i] specifies the index of the substitution in the original tuple that occupies the i-th place in the masked signature.
Inequality - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
 
Inequality(PBody, PVariable, PVariable) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.Inequality
 
Inequality(PBody, PVariable, PVariable, boolean) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.Inequality
 
inferConstraint(PConstraint) - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
Indicate that a given constraint was found to be automatically satisfied at this point without additional operations.
inferUnaryTypes(Set<PConstraint>, IQueryMetaContext) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.TypeHelper
Infers unary type information for variables, based on the given constraints.
inferUnaryTypesFor(Iterable<PVariable>, Map<PVariable, Set<TypeJudgement>>) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.TypeHelper
Collects the type constraints for the specified collection of variables.
inferUnaryTypesFor(Iterable<PVariable>, Set<PConstraint>, IQueryMetaContext) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.TypeHelper
Collects the type constraints for the specified collection of variables.
inheritedIndex - Variable in class tools.refinery.interpreter.matchers.tuple.BaseLeftInheritanceTuple
The number of elements that aren't stored locally, but inherited from an ancestor Tuple instead.
InitializablePQuery - Interface in tools.refinery.interpreter.matchers.psystem
Adds extra methods to the PQuery interface to initialize its contents.
initializeBodies(Set<PBody>) - Method in interface tools.refinery.interpreter.matchers.psystem.InitializablePQuery
Sets up the bodies of the pattern.
initializeWith(MaskedTupleMemory<Timestamp>, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Initializes the contents of this memory based on the contents of another memory.
initializeWith(MaskedTupleMemory<Timestamp>, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
initializeWith(MaskedTupleMemory<Timestamp>, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
initializeWith(MaskedTupleMemory<Timestamp>, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
initializeWith(MaskedTupleMemory<Timestamp>, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
INITIALIZING - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.queries.PQuery.PQueryStatus
Marks that the query definition is being initialized
INOUT - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.queries.PParameterDirection
Default value, no additional constraint is applied
InputKeyImplication - Class in tools.refinery.interpreter.matchers.context
Data object representing the implication of an input key, in use cases including edge supertypes, edge opposites, node type constraints, etc.
InputKeyImplication(IInputKey, IInputKey, List<Integer>) - Constructor for class tools.refinery.interpreter.matchers.context.InputKeyImplication
 
inputVariables - Variable in class tools.refinery.interpreter.matchers.psystem.basicdeferred.BaseTypeSafeConstraint
 
INSERT - Enum constant in enum class tools.refinery.interpreter.matchers.util.Direction
 
insertOverridingValue(Map<QueryHintOption<?>, Object>, HintValue) - Method in class tools.refinery.interpreter.matchers.backend.QueryHintOption
Puts a value of this hint option into an option-to-value map.
insertValueIfNondefault(Map<QueryHintOption<?>, Object>, HintValue) - Method in class tools.refinery.interpreter.matchers.backend.QueryHintOption
Puts a value of this hint option into an option-to-value map, if the given value differs from the default value of the option.
instance() - Static method in class tools.refinery.interpreter.matchers.context.surrogate.SurrogateQueryRegistry
 
instance() - Static method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
INSTANCE - Static variable in class tools.refinery.interpreter.matchers.aggregators.DoubleAverageOperator
 
INSTANCE - Static variable in class tools.refinery.interpreter.matchers.aggregators.DoubleSumOperator
 
INSTANCE - Static variable in class tools.refinery.interpreter.matchers.aggregators.IntegerAverageOperator
 
INSTANCE - Static variable in class tools.refinery.interpreter.matchers.aggregators.IntegerSumOperator
 
INSTANCE - Static variable in class tools.refinery.interpreter.matchers.aggregators.LongAverageOperator
 
INSTANCE - Static variable in class tools.refinery.interpreter.matchers.aggregators.LongSumOperator
 
INSTANCE - Static variable in class tools.refinery.interpreter.matchers.psystem.rewriters.NopTraceCollector
 
INSTANCE - Static variable in class tools.refinery.interpreter.matchers.tuple.FlatTuple0
 
INSTANCES - Enum constant in enum class tools.refinery.interpreter.matchers.context.IndexingService
Enables enumeration of instances and reverse-navigation.
instantiate() - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
For backward compatibility of code generated with previous versions of viatra query, this method has a default implementation returning null, indicating that a matcher can only be created using the old method, which ignores the hints provided by the user.
instantiate() - Method in interface tools.refinery.interpreter.api.IQuerySpecification
Creates a new uninitialized matcher, which is not functional until an engine initializes it.
instantiate(InterpreterEngine) - Method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
IntegerAverageOperator - Class in tools.refinery.interpreter.matchers.aggregators
 
integersToIntArray(Collection<Integer>) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
 
IntegerSumOperator - Class in tools.refinery.interpreter.matchers.aggregators
Incrementally computes the sum of java.lang.Integer values
internalEquals(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.AbstractTuple
Compares the elements stored in this tuple to another tuple
internalEquals(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.BaseLeftInheritanceTuple
Optimized equals calculation (prediction: true, since hash values match)
internalEquals(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple
 
internalEquals(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple0
 
internalEquals(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple1
 
internalEquals(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple2
 
internalEquals(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple3
 
internalEquals(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.FlatTuple4
 
InterpreterBaseIndexChangeListener - Interface in tools.refinery.interpreter.api.scope
Listener interface for change notifications from the Refinery Base index.
InterpreterEngine - Class in tools.refinery.interpreter.api
A Viatra Query (incremental) evaluation engine, attached to a model such as an EMF resource.
InterpreterEngine() - Constructor for class tools.refinery.interpreter.api.InterpreterEngine
 
InterpreterEngineImpl - Class in tools.refinery.interpreter.internal.apiimpl
A Refinery Interpreter engine back-end (implementation)
InterpreterEngineImpl(QueryScope) - Constructor for class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
InterpreterEngineImpl(QueryScope, InterpreterEngineOptions) - Constructor for class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
InterpreterEngineInitializationListener - Interface in tools.refinery.interpreter.api
Listener interface to get notifications when a new managed engine is initialized.
InterpreterEngineLifecycleListener - Interface in tools.refinery.interpreter.api
Listener interface for getting notification on changes in an InterpreterEngine.
InterpreterEngineOptions - Class in tools.refinery.interpreter.api
This class is intended to provide options to a created InterpreterEngine instance.
InterpreterEngineOptions.Builder - Class in tools.refinery.interpreter.api
 
InterpreterException - Exception Class in tools.refinery.interpreter.exception
A general Refinery Interpreter-related problem during the operation of the Refinery Interpreter engine, or the loading, manipulation and evaluation of queries.
InterpreterException(String, String) - Constructor for exception class tools.refinery.interpreter.exception.InterpreterException
 
InterpreterException(String, String, Throwable) - Constructor for exception class tools.refinery.interpreter.exception.InterpreterException
 
InterpreterException(QueryProcessingException) - Constructor for exception class tools.refinery.interpreter.exception.InterpreterException
 
InterpreterException(QueryInitializationException) - Constructor for exception class tools.refinery.interpreter.exception.InterpreterException
 
InterpreterLoggingUtil - Class in tools.refinery.interpreter.util
Centralized logger of the Refinery Interpreter runtime.
InterpreterMatcher<Match> - Interface in tools.refinery.interpreter.api
Interface for a Refinery Interpreter matcher associated with a graph pattern.
InterpreterModelUpdateListener - Interface in tools.refinery.interpreter.api
Listener interface for model changes affecting different levels of the Refinery Interpreter architecture.
InterpreterModelUpdateListener.ChangeLevel - Enum Class in tools.refinery.interpreter.api
Possible notification levels for changes
InterpreterRuntimeException - Exception Class in tools.refinery.interpreter.matchers
A common base class for all exceptions thrown by various Refinery Interpreter APIs.
InterpreterRuntimeException() - Constructor for exception class tools.refinery.interpreter.matchers.InterpreterRuntimeException
 
InterpreterRuntimeException(String) - Constructor for exception class tools.refinery.interpreter.matchers.InterpreterRuntimeException
 
InterpreterRuntimeException(String, Throwable) - Constructor for exception class tools.refinery.interpreter.matchers.InterpreterRuntimeException
 
InterpreterRuntimeException(String, Throwable, boolean, boolean) - Constructor for exception class tools.refinery.interpreter.matchers.InterpreterRuntimeException
 
InterpreterRuntimeException(Throwable) - Constructor for exception class tools.refinery.interpreter.matchers.InterpreterRuntimeException
 
intersection(Set<A>, Set<A>) - Static method in class tools.refinery.interpreter.matchers.util.Sets
 
invertIndex() - Method in class tools.refinery.interpreter.matchers.tuple.AbstractTuple
Calculates an inverted index of the elements of this pattern.
invertIndex() - Method in interface tools.refinery.interpreter.matchers.tuple.ITuple
Calculates an inverted index of the elements of this pattern.
invertIndexWithMupliplicity() - Method in class tools.refinery.interpreter.matchers.tuple.AbstractTuple
Calculates an inverted index of the elements of this pattern.
invertIndexWithMupliplicity() - Method in interface tools.refinery.interpreter.matchers.tuple.ITuple
Calculates an inverted index of the elements of this pattern.
IOperationCompiler<Collector> - Interface in tools.refinery.interpreter.matchers.planning
An implicit common parameter is the "effort" PatternDescription.
IPatternMatch - Interface in tools.refinery.interpreter.api
Generic interface for a single match of a pattern.
IPosetComparator - Interface in tools.refinery.interpreter.matchers.context
Implementations of this interface aid the query engine with the ordering of poset elements.
IProvider<T> - Interface in tools.refinery.interpreter.matchers.util
A provider interface useful in various registry instances.
IProvider.ProvidedValueFunction - Class in tools.refinery.interpreter.matchers.util
 
IPTraceableTraceProvider - Interface in tools.refinery.interpreter.matchers.psystem.rewriters
This interface provides methods to trace the PTraceables of a transformed PQuery produced by a PDisjunctionRewriter.
IQueryBackend - Interface in tools.refinery.interpreter.matchers.backend
Internal interface for a Refienry Interpreter query specification.
IQueryBackendContext - Interface in tools.refinery.interpreter.matchers.context
This interface is a collector which holds every API that is provided by the engine to control the operation of the backends.
IQueryBackendFactory - Interface in tools.refinery.interpreter.matchers.backend
A Query Backend Factory identifies a query evaluator implementation, and can create an evaluator instance (an IQueryBackend) tied to a specific Refinery Interpreter engine upon request.
IQueryBackendFactoryProvider - Interface in tools.refinery.interpreter.matchers.backend
A provider interface for IQueryBackendFactory instances.
IQueryBackendHintProvider - Interface in tools.refinery.interpreter.matchers.backend
Provides query evaluation hints consisting of the Engine default hints and the hints provided by the pattern itself.
IQueryCacheContext - Interface in tools.refinery.interpreter.matchers.context
Provides information on already cached queries to query evaluator backends at runtime.
IQueryGroup - Interface in tools.refinery.interpreter.api
Generic interface for group of query specifications.
IQueryMetaContext - Interface in tools.refinery.interpreter.matchers.context
Provides metamodel information (relationship of input keys) to query evaluator backends at runtime and at query planning time.
IQueryPlannerStrategy - Interface in tools.refinery.interpreter.matchers.planning
An algorithm that builds a query plan based on a PSystem representation of a body of constraints.
IQueryReference - Interface in tools.refinery.interpreter.matchers.psystem
A PConstraint that implements this interface refers to a PQuery.
IQueryResultProvider - Interface in tools.refinery.interpreter.matchers.backend
An internal interface of the query backend that provides results of a given query.
IQueryResultProviderAccess - Interface in tools.refinery.interpreter.matchers.context
This interface exposes API to request IQueryResultProvider for PQuery instances.
IQueryRuntimeContext - Interface in tools.refinery.interpreter.matchers.context
Provides instance model information (relations corresponding to input keys) to query evaluator backends at runtime.
IQueryRuntimeContextListener - Interface in tools.refinery.interpreter.matchers.context
Listens for changes in the runtime context.
IQuerySpecification<Matcher> - Interface in tools.refinery.interpreter.api
API interface for a Refinery Interpreter query specification.
IRelationEvaluator - Interface in tools.refinery.interpreter.matchers.psystem
Implementations of this interface take an arbitrary number of input relations with their contents and compute the tuples of a single output relation.
IRewriterTraceCollector - Interface in tools.refinery.interpreter.matchers.psystem.rewriters
This is the internal API of IPTraceableTraceProvider expected to be used by copier and rewriter implementations.
IRRELEVANT - Enum constant in enum class tools.refinery.interpreter.matchers.util.TimelyMemory.SignChange
 
isCaching() - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackend
 
isCaching() - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackendFactory
Returns whether the current backend is caching
isCoalescing() - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
 
isCompatibleWith(IPatternMatch) - Method in class tools.refinery.interpreter.api.impl.BasePatternMatch
 
isCompatibleWith(IPatternMatch) - Method in interface tools.refinery.interpreter.api.IPatternMatch
Checks that this match is compatible with the given other match.
isCompatibleWithQueryScope(Class<? extends QueryScope>) - Method in class tools.refinery.interpreter.api.scope.QueryScope
Determines whether a query engine initialized on this scope can evaluate queries formulated against the given scope type.
isDeducable() - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
Determines whether there are any constraints that can deduce this variable
isDisposed() - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Returns true if the AdvancedInterpreterEngine.dispose() method was called on this engine previously.
isDisposed() - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
isEliminable() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Inequality
A weak inequality constraint is eliminable if who is the same as withWhom, or if any if them is undeducible.
isEmpty() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
isEmpty() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
isEmpty() - Method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
isEmpty() - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
 
isEmpty() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Returns true if this collection is empty, false otherwise.
isEmpty() - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
isEmpty() - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
isEmpty() - Method in class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
isEmpty() - Method in class tools.refinery.interpreter.matchers.util.timeline.CompactTimeline
 
isEmpty() - Method in class tools.refinery.interpreter.matchers.util.timeline.SingletonTimeline
 
isEmpty() - Method in class tools.refinery.interpreter.matchers.util.timeline.Timeline
 
isEmpty() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
isEnumerable() - Method in class tools.refinery.interpreter.matchers.context.common.JavaTransitiveInstancesKey
 
isEnumerable() - Method in interface tools.refinery.interpreter.matchers.context.IInputKey
Returns true iff instance tuples of the key can be enumerated.
isEnumerable(IInputKey) - Method in interface tools.refinery.interpreter.matchers.context.IQueryMetaContext
Returns true iff instance tuples of the given key can be enumerated.
ISetMemory<T> - Interface in tools.refinery.interpreter.matchers.util
An IMemory that always contains values with a 0 or +1 multiplicity.
isIdentity() - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
 
isIdentity() - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask0
 
isIdentity() - Method in class tools.refinery.interpreter.matchers.tuple.TupleMaskIdentity
 
isIndexed(IInputKey, IndexingService) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Returns true if index is available for the given key providing the given service.
isLazy - Variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
isLazy - Variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
isLazy - Variable in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
isLessOrEqual(Tuple, Tuple) - Method in interface tools.refinery.interpreter.matchers.context.IPosetComparator
Returns true if the 'left' tuple of poset elements is smaller or equal than the 'right' tuple of poset elements according to the partial order that this poset comparator employs.
isMoot() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Equality
An equality is moot if it compares the a variable with itself.
isMutable() - Method in interface tools.refinery.interpreter.api.IPatternMatch
Returns whether the match object can be further modified after its creation.
isMutable() - Method in class tools.refinery.interpreter.matchers.psystem.PBody
 
isMutable() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
isMutable() - Method in class tools.refinery.interpreter.matchers.psystem.queries.PDisjunction
Decides whether a disjunction is mutable.
isMutable() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQuery
An option to check mutability of the query.
isNeutral(Accumulator) - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IMultisetAggregationOperator
 
isNeutral(Double) - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleSumOperator
 
isNeutral(Integer) - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerSumOperator
 
isNeutral(Long) - Method in class tools.refinery.interpreter.matchers.aggregators.LongSumOperator
 
isNeutral(SortedMap<T, Integer>) - Method in class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator
 
isNeutral(AverageAccumulator<Double>) - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleAverageOperator
 
isNeutral(AverageAccumulator<Integer>) - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerAverageOperator
 
isNeutral(AverageAccumulator<Long>) - Method in class tools.refinery.interpreter.matchers.aggregators.LongAverageOperator
 
isNonrepeating() - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
 
isOptionOverridden(QueryHintOption<?>) - Method in class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
Returns whether the given hint option is overridden.
isOrdered() - Method in class tools.refinery.interpreter.matchers.planning.operations.PProject
 
isOverriddenIn(QueryEvaluationHint) - Method in class tools.refinery.interpreter.matchers.backend.QueryHintOption
Returns whether this hint option is defined in the given hint collection.
isPosetKey(IInputKey) - Method in class tools.refinery.interpreter.matchers.context.AbstractQueryMetaContext
 
isPosetKey(IInputKey) - Method in interface tools.refinery.interpreter.matchers.context.IQueryMetaContext
Returns true if the given IInputKey represents a poset type.
isPresentAtInfinity() - Method in class tools.refinery.interpreter.matchers.util.timeline.CompactTimeline
 
isPresentAtInfinity() - Method in class tools.refinery.interpreter.matchers.util.timeline.SingletonTimeline
 
isPresentAtInfinity() - Method in class tools.refinery.interpreter.matchers.util.timeline.Timeline
 
isPresentAtInfinity(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Returns true if there is any tuple with the given signature that is present at the timestamp +inf, false otherwise.
isPresentAtInfinity(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
isPresentAtInfinity(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
isPresentAtInfinity(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
isPresentAtInfinity(ITuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
isPresentAtInfinity(Tuple) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
Returns true if the given tuple is present at the moment 'infinity'.
isPresentAtInfinityInteral(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
isPresentAtInfinityInteral(Object) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
isReadyAt(SubPlan, IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.BaseTypeSafeConstraint
 
isReadyAt(SubPlan, IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Equality
 
isReadyAt(SubPlan, IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.DeferredPConstraint
 
isReadyAt(SubPlan, IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.VariableDeferredPConstraint
Refine further if needed
isRemoved(PTraceable) - Method in interface tools.refinery.interpreter.matchers.psystem.rewriters.IPTraceableTraceProvider
Returns whether the given traceable element has been removed by every rewriter for a reason.
isRemoved(PTraceable) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.MappingTraceCollector
 
isRemoved(PTraceable) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.NopTraceCollector
 
isResultCached(PQuery) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
isResultCached(PQuery) - Method in interface tools.refinery.interpreter.matchers.context.IQueryCacheContext
Checks if there already is a caching result provider for the given query.
isSameUnion(Set<V>) - Method in class tools.refinery.interpreter.matchers.algorithms.UnionFind
Returns if all given elements are in the same partition.
isStateless(IInputKey) - Method in interface tools.refinery.interpreter.matchers.context.IQueryMetaContext
Returns true iff the set of instance tuples of the given key is immutable.
isSystemDefaultCachingBackend() - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackendFactoryProvider
Returns whether the given query backend should be considered as system default caching backend.
isSystemDefaultEngine() - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackendFactoryProvider
Returns whether the given query backend should be considered as system default.
isSystemDefaultSearchBackend() - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackendFactoryProvider
Returns whether the given query backend should be considered as system default search backend.
isTainted() - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Indicates whether the engine is in a tainted, inconsistent state due to some internal errors.
isTainted() - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
isTimely() - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Returns true of this memory is timely, false otherwise.
isTimely() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
isTimely() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
isTimely() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
isTimely() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
isTrivial(Set<A>, Set<A>) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.FunctionalDependencyHelper
 
isUnique() - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
 
isUnwinding() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExpressionEvaluation
 
isUpdatePropagationDelayed() - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Returns true if the update propagation in this engine is currently delayed, false otherwise.
isUpdatePropagationDelayed() - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
isVirtual() - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
 
isWeak() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Inequality
The inequality constraint is weak if it can be ignored when who is the same as withWhom, or if any if them is undeducible.
iterator() - Method in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
iterator() - Method in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
iterator() - Method in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
iterator() - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Iterates over distinct tuples stored in the memory, regardless of their signatures.
iterator() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
iterator() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
iterator() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
iterator() - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
iterator() - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
iterator() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
iterator() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
iterator() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
iterator() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
iterator() - Method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
iterator() - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
iterator() - Method in class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
iteratorOf(LongIterable) - Static method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
Helper for iterating a LongIterable
ITuple - Interface in tools.refinery.interpreter.matchers.tuple
Represents both mutable and immutable tuples
ITypeConstraint - Interface in tools.refinery.interpreter.matchers.psystem
Common superinterface of enumerable and deferred type constraints.
ITypeConstraint.TypeConstraintUtil - Class in tools.refinery.interpreter.matchers.psystem
Static internal utility class for implementations of ITypeConstraints.
ITypeInfoProviderConstraint - Interface in tools.refinery.interpreter.matchers.psystem
 
IUpdateable - Interface in tools.refinery.interpreter.matchers.backend
Internal interface for the query backend to singal an update to a query result.
IValueProvider - Interface in tools.refinery.interpreter.matchers.psystem
Helper interface to get values from a tuple of variables.
IVariableRenamer - Interface in tools.refinery.interpreter.matchers.psystem.rewriters
Helper interface to ease the naming of the new variables during flattening
IVariableRenamer.HierarchicalName - Class in tools.refinery.interpreter.matchers.psystem.rewriters
 
IVariableRenamer.SameName - Class in tools.refinery.interpreter.matchers.psystem.rewriters
 

J

JavaTransitiveInstancesKey - Class in tools.refinery.interpreter.matchers.context.common
Instance tuples are of form (x), where object x is an instance of the given Java class or its subclasses.
JavaTransitiveInstancesKey(Class<?>) - Constructor for class tools.refinery.interpreter.matchers.context.common.JavaTransitiveInstancesKey
Preferred constructor.
JavaTransitiveInstancesKey(String) - Constructor for class tools.refinery.interpreter.matchers.context.common.JavaTransitiveInstancesKey
Call this constructor only in contexts where the class itself is not available for loading, e.g.

K

keepSelectedIndices(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Returns a tuple `result`, same arity as the original tuple, that satisfies `this.transform(result).equals(this.transform(tuple))`.
KEY - Enum constant in enum class tools.refinery.interpreter.matchers.util.IMultiLookup.ChangeGranularity
First key-value pair with given key inserted, or last pair with given key deleted.
KeyedEnumerablePConstraint<KeyType> - Class in tools.refinery.interpreter.matchers.psystem
 
KeyedEnumerablePConstraint(PBody, Tuple, KeyType) - Constructor for class tools.refinery.interpreter.matchers.psystem.KeyedEnumerablePConstraint
 
keyPosition - Variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
keyPosition - Variable in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
keySet() - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
keySet() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
keyToString() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.BinaryReflexiveTransitiveClosure
 
keyToString() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.BinaryTransitiveClosure
 
keyToString() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.ConstantValue
 
keyToString() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.PositivePatternCall
 
keyToString() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.RepresentativeElectionConstraint
 
keyToString() - Method in class tools.refinery.interpreter.matchers.psystem.basicenumerables.TypeConstraint
 
keyToString() - Method in class tools.refinery.interpreter.matchers.psystem.KeyedEnumerablePConstraint
 

L

LeftInheritanceTuple - Class in tools.refinery.interpreter.matchers.tuple
Tuple that inherits another tuple on the left.
LeftInheritanceTuple1 - Class in tools.refinery.interpreter.matchers.tuple
 
LeftInheritanceTuple1(Tuple, Object) - Constructor for class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple1
 
LeftInheritanceTuple2 - Class in tools.refinery.interpreter.matchers.tuple
 
LeftInheritanceTuple2(Tuple, Object, Object) - Constructor for class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple2
 
LeftInheritanceTuple3 - Class in tools.refinery.interpreter.matchers.tuple
 
LeftInheritanceTuple3(Tuple, Object, Object, Object) - Constructor for class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple3
 
LeftInheritanceTuple4 - Class in tools.refinery.interpreter.matchers.tuple
 
LeftInheritanceTuple4(Tuple, Object, Object, Object, Object) - Constructor for class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple4
 
leftInheritanceTupleOf(Tuple, Object...) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a left inheritance tuple that extends an ancestor tuple by the given "local" elements.
LeftJoinConstraint - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
 
LeftJoinConstraint(PBody, Tuple, PQuery, PVariable, int, Object) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
LifecycleProvider - Class in tools.refinery.interpreter.internal.engine
 
LifecycleProvider(AdvancedInterpreterEngine, Logger) - Constructor for class tools.refinery.interpreter.internal.engine.LifecycleProvider
 
linear(int, int) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance of the given size that maps the first 'size' elements intact
listenerAdded(Listener) - Method in class tools.refinery.interpreter.internal.engine.ListenerContainer
 
listenerAdded(InterpreterEngineLifecycleListener) - Method in class tools.refinery.interpreter.internal.engine.LifecycleProvider
 
listenerAdded(InterpreterModelUpdateListener) - Method in class tools.refinery.interpreter.internal.engine.ModelUpdateProvider
 
ListenerContainer<Listener> - Class in tools.refinery.interpreter.internal.engine
 
ListenerContainer() - Constructor for class tools.refinery.interpreter.internal.engine.ListenerContainer
 
listenerRemoved(Listener) - Method in class tools.refinery.interpreter.internal.engine.ListenerContainer
 
listenerRemoved(InterpreterEngineLifecycleListener) - Method in class tools.refinery.interpreter.internal.engine.LifecycleProvider
 
listenerRemoved(InterpreterModelUpdateListener) - Method in class tools.refinery.interpreter.internal.engine.ModelUpdateProvider
 
listeners - Variable in class tools.refinery.interpreter.internal.engine.ListenerContainer
 
localEquals(BaseLeftInheritanceTuple) - Method in class tools.refinery.interpreter.matchers.tuple.BaseLeftInheritanceTuple
Checks the equivalence of local elements only, after ancestor tuple has been determined to be equal.
localEquals(BaseLeftInheritanceTuple) - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple
Optimized equals calculation (prediction: true, since hash values match)
localEquals(BaseLeftInheritanceTuple) - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple1
Optimized equals calculation (prediction: true, since hash values match)
localEquals(BaseLeftInheritanceTuple) - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple2
 
localEquals(BaseLeftInheritanceTuple) - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple3
 
localEquals(BaseLeftInheritanceTuple) - Method in class tools.refinery.interpreter.matchers.tuple.LeftInheritanceTuple4
 
LongAverageOperator - Class in tools.refinery.interpreter.matchers.aggregators
 
LongSumOperator - Class in tools.refinery.interpreter.matchers.aggregators
Incrementally computes the sum of java.lang.Long values
lookup(Key) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Returns a (read-only) bucket of values associated with the given key.
lookup(Key) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
lookupAndRemoveAll(Key) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Returns a (read-only) bucket of values associated with the given key, while simultaneously removing them.
lookupAndRemoveAll(Key) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
lookupExists(Key) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Returns true if there are any values associated with the given key.
lookupExists(Key) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
lookupOrEmpty(Key) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Returns a (read-only) bucket of values associated with the given key.
lookupUnsafe(Object) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Returns a (read-only) bucket of values associated with the given key, which can be of any type.
lookupUnsafe(Object) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
lookupUnsafeOrEmpty(Object) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Returns a (read-only) bucket of values associated with the given key.
lowLevelGet(Key) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
Implementor shall bind to the low-level get() or equivalent of the underlying Key-to-Object map
lowLevelGetUnsafe(Object) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
Implementor shall bind to the low-level get() or equivalent of the underlying Key-to-Object map
lowLevelKeySet() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
Implementor shall bind to the low-level keySet() or equivalent of the underlying Key-to-Object map
lowLevelPut(Key, Object) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
Implementor shall bind to the low-level put() or equivalent of the underlying Key-to-Object map
lowLevelPutIfAbsent(Key, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
Implementor shall bind to the low-level putIfAbsent() or equivalent of the underlying Key-to-Object map
lowLevelRemove(Key) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
Implementor shall bind to the low-level remove() or equivalent of the underlying Key-to-Object map
lowLevelSize() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
Implementor shall bind to the low-level size() or equivalent of the underlying Key-to-Object map
lowLevelValues() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
Implementor shall bind to the low-level values() or equivalent of the underlying Key-to-Object map

M

makeImmutableList(T...) - Static method in class tools.refinery.interpreter.api.impl.BasePatternMatch
 
makeSet(Collection<V>) - Method in class tools.refinery.interpreter.matchers.algorithms.UnionFind
Creates a new union set from a collection of elements.
makeSet(V) - Method in class tools.refinery.interpreter.matchers.algorithms.UnionFind
This method creates a single set containing the given node.
MapBackedMemoryView<T> - Class in tools.refinery.interpreter.matchers.util
Wraps a Mapinvalid input: '<'T, Integer> (mapping elements to non-zero multiplicities) into an IMemoryView.
MapBackedMemoryView(Map<T, Integer>) - Constructor for class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
MappingTraceCollector - Class in tools.refinery.interpreter.matchers.psystem.rewriters
Multimap-based implementation to contain and query traces
MappingTraceCollector() - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.MappingTraceCollector
 
MarkedMemory<Value> - Interface in tools.refinery.interpreter.matchers.util
Internal marker type, must only be instantiated inside implementors of IMultiLookupImpl
MarkedMemory.MarkedDeltaBag<Value> - Interface in tools.refinery.interpreter.matchers.util
 
MarkedMemory.MarkedMultiset<Value> - Interface in tools.refinery.interpreter.matchers.util
 
MarkedMemory.MarkedSet<Value> - Interface in tools.refinery.interpreter.matchers.util
 
mask - Variable in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
The mask by which the tuples are indexed.
mask - Variable in class tools.refinery.interpreter.matchers.tuple.VolatileMaskedTuple
 
MaskedResumable<Timestamp> - Interface in tools.refinery.interpreter.matchers.util.resumable
A masked Resumable implementation, which maintains lazy folding per tuple signature.
MaskedTuple - Class in tools.refinery.interpreter.matchers.tuple
A tuple that transparently provides a masked (transformed) view of another tuple.
MaskedTuple(Tuple, TupleMask) - Constructor for class tools.refinery.interpreter.matchers.tuple.MaskedTuple
 
MaskedTupleMemory<Timestamp> - Class in tools.refinery.interpreter.matchers.memories
Indexes a collection of tuples by their signature (i.e.
MaskedTupleMemory(TupleMask, Object) - Constructor for class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
 
matcherInstantiated(InterpreterMatcher<? extends IPatternMatch>) - Method in interface tools.refinery.interpreter.api.InterpreterEngineLifecycleListener
Called after a matcher is instantiated in the engine
matcherInstantiated(InterpreterMatcher<? extends IPatternMatch>) - Method in class tools.refinery.interpreter.internal.engine.LifecycleProvider
 
MATCHSET - Enum constant in enum class tools.refinery.interpreter.api.InterpreterModelUpdateListener.ChangeLevel
 
matchToArray(Match) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
Converts the Match object of a pattern match to the array representation.
MatchUpdateAdapter<Match> - Class in tools.refinery.interpreter.api
A default implementation of IMatchUpdateListener that contains two match processors, one for appearance, one for disappearance.
MatchUpdateAdapter() - Constructor for class tools.refinery.interpreter.api.MatchUpdateAdapter
Constructs an instance without any match processors registered yet.
MatchUpdateAdapter(Consumer<Match>, Consumer<Match>) - Constructor for class tools.refinery.interpreter.api.MatchUpdateAdapter
Constructs an instance by specifying match processors.
max - Class in tools.refinery.interpreter.matchers.aggregators
This aggregator calculates the maximum value of a selected aggregate parameter of a called pattern.
max() - Constructor for class tools.refinery.interpreter.matchers.aggregators.max
 
MAX - Enum constant in enum class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator.Extreme
 
memory - Variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
memory - Variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
memoryMap - Variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
memoryMap - Variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
MemoryViewBackedMapView<T> - Class in tools.refinery.interpreter.matchers.util
A partial and read-only Map implementation, mapping elements to multiplicities backed by an IMemoryView.
MemoryViewBackedMapView(IMemoryView<T>) - Constructor for class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
merge(TimelyMemory.FoldingState) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory.FoldingState
The returned result will never be null, even if the resulting diff is zero.
mergeAdditive(Diff<Timestamp>) - Method in class tools.refinery.interpreter.matchers.util.timeline.Timeline
Merges this timeline with the given timestamp diff.
mergeBody(PBody) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
mergeBody(PBody, IVariableRenamer, IConstraintFilter) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
Merge all variables and constraints from a source body to a target body.
mergeMultiplicative(Timeline<Timestamp>) - Method in class tools.refinery.interpreter.matchers.util.timeline.Timeline
 
mergeUniques(Iterable<T>, Iterable<T>, Comparator<T>) - Static method in class tools.refinery.interpreter.matchers.algorithms.OrderedIterableMerge
Lazily merges two iterables, each ordered according to a given comparator.
min - Class in tools.refinery.interpreter.matchers.aggregators
This aggregator calculates the minimum value of a selected aggregate parameter of a called pattern.
min() - Constructor for class tools.refinery.interpreter.matchers.aggregators.min
 
min(Optional<Double>, double) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.StatisticsHelper
 
min(Optional<Double>, Optional<Double>) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.StatisticsHelper
 
MIN - Enum constant in enum class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator.Extreme
 
MODEL - Enum constant in enum class tools.refinery.interpreter.api.InterpreterModelUpdateListener.ChangeLevel
 
ModelUpdateProvider - Class in tools.refinery.interpreter.internal.engine
 
ModelUpdateProvider(AdvancedInterpreterEngine, Logger) - Constructor for class tools.refinery.interpreter.internal.engine.ModelUpdateProvider
 
MOOT_EQUALITY - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.rewriters.ConstraintRemovalReason
 
multiply(Direction) - Method in enum class tools.refinery.interpreter.matchers.util.Direction
Returns the direction that is the product of this direction and the other direction.
MULTISETS - Enum constant in enum class tools.refinery.interpreter.matchers.util.CollectionsFactory.MemoryType
Duplicate key-value pairs allowed

N

NegativePatternCall - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
 
NegativePatternCall(PBody, Tuple, PQuery) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.NegativePatternCall
 
negativesAllowed() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
negativesAllowed() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToMultisetsAbstract
 
negativesAllowed() - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToSetsAbstract
 
NeverFlattenCallPredicate - Class in tools.refinery.interpreter.matchers.psystem.rewriters
 
NeverFlattenCallPredicate() - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.NeverFlattenCallPredicate
 
newConstantVariable(Object) - Method in class tools.refinery.interpreter.matchers.psystem.PBody
 
newEmptyMatch() - Method in class tools.refinery.interpreter.api.GenericQuerySpecification
 
newEmptyMatch() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
newEmptyMatch() - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns an empty, mutable Match for the matcher.
newEmptyMatch() - Method in interface tools.refinery.interpreter.api.IQuerySpecification
Returns an empty, mutable Match compatible with matchers of this query.
newEmptyMatch(GenericQuerySpecification<? extends GenericPatternMatcher>) - Static method in class tools.refinery.interpreter.api.GenericPatternMatch
Returns an empty, mutable match.
newMatch(Object...) - Method in class tools.refinery.interpreter.api.GenericQuerySpecification
 
newMatch(Object...) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
newMatch(Object...) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns a new (partial) Match object for the matcher.
newMatch(Object...) - Method in interface tools.refinery.interpreter.api.IQuerySpecification
Returns a new (partial) Match object compatible with matchers of this query.
newMatch(GenericQuerySpecification<? extends GenericPatternMatcher>, Object...) - Static method in class tools.refinery.interpreter.api.GenericPatternMatch
Returns a new (partial) match.
newMutableMatch(GenericQuerySpecification<? extends GenericPatternMatcher>, Object...) - Static method in class tools.refinery.interpreter.api.GenericPatternMatch
Returns a mutable (partial) match.
newSet(Iterable<A>) - Static method in class tools.refinery.interpreter.matchers.util.Sets
 
newVirtualVariable() - Method in class tools.refinery.interpreter.matchers.psystem.PBody
 
newVirtualVariable(String) - Method in class tools.refinery.interpreter.matchers.psystem.PBody
 
NO_BACKEND_ADHESION - Static variable in interface tools.refinery.interpreter.matchers.backend.ICallDelegationStrategy
Options known for callee are used to override caller options, including the backend selection.
NO_CHANGE - Enum constant in enum class tools.refinery.interpreter.api.InterpreterModelUpdateListener.ChangeLevel
 
NONE - Static variable in interface tools.refinery.interpreter.CancellationToken
 
NopTraceCollector - Class in tools.refinery.interpreter.matchers.psystem.rewriters
This implementation does not store any traces and scales to NOP for every traceability feature.
normalizationTraceCollector - Static variable in class tools.refinery.interpreter.matchers.backend.CommonQueryHintOptions
This hint instructs the query backends to record trace information into the given trace collector
normalizeBody(PBody) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyNormalizer
Provides a normalized version of the pattern body.
NOTIFICATIONS - Enum constant in enum class tools.refinery.interpreter.matchers.context.IndexingService
The indexer can provide notifications about changes in the model.
notifyAppearance(Match) - Method in interface tools.refinery.interpreter.api.IMatchUpdateListener
Will be invoked on each new match that appears.
notifyAppearance(Match) - Method in class tools.refinery.interpreter.api.MatchUpdateAdapter
 
notifyBinaryChanged(Object, Object) - Method in interface tools.refinery.interpreter.api.scope.IInstanceObserver
 
notifyChanged(boolean) - Method in interface tools.refinery.interpreter.api.scope.InterpreterBaseIndexChangeListener
Called after a model change is handled by the Refinery Interpreter base index and if indexChanged == onlyOnIndexChange().
notifyChanged(InterpreterModelUpdateListener.ChangeLevel) - Method in interface tools.refinery.interpreter.api.InterpreterModelUpdateListener
Called after each change with also sending the level of change.
notifyDisappearance(Match) - Method in interface tools.refinery.interpreter.api.IMatchUpdateListener
Will be invoked on each existing match that disappears.
notifyDisappearance(Match) - Method in class tools.refinery.interpreter.api.MatchUpdateAdapter
 
notifyTernaryChanged(Object, Object) - Method in interface tools.refinery.interpreter.api.scope.IInstanceObserver
 
NullaryMaskedTupleMemory<Timestamp> - Class in tools.refinery.interpreter.matchers.memories
Specialized for nullary mask; tuples are stored as a simple set/multiset memory.
NullaryMaskedTupleMemory(TupleMask, CollectionsFactory.MemoryType, Object) - Constructor for class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
numParentSubPlans() - Method in class tools.refinery.interpreter.matchers.planning.operations.PApply
 
numParentSubPlans() - Method in class tools.refinery.interpreter.matchers.planning.operations.PEnumerate
 
numParentSubPlans() - Method in class tools.refinery.interpreter.matchers.planning.operations.PJoin
 
numParentSubPlans() - Method in class tools.refinery.interpreter.matchers.planning.operations.POperation
 
numParentSubPlans() - Method in class tools.refinery.interpreter.matchers.planning.operations.PProject
 
numParentSubPlans() - Method in class tools.refinery.interpreter.matchers.planning.operations.PStart
 

O

of(Set<IQuerySpecification<?>>) - Static method in class tools.refinery.interpreter.api.GenericQueryGroup
Creates a generic IQueryGroup instance from IQuerySpecification objects.
of(Stream<IQuerySpecification<?>>) - Static method in class tools.refinery.interpreter.api.GenericQueryGroup
Creates a generic IQueryGroup instance from IQuerySpecification objects.
of(IQueryGroup...) - Static method in class tools.refinery.interpreter.api.GenericQueryGroup
Creates a generic IQueryGroup instance from other IQueryGroup objects (subgroups).
of(IQuerySpecification<?>...) - Static method in class tools.refinery.interpreter.api.GenericQueryGroup
Creates a generic IQueryGroup instance from IQuerySpecification objects.
OK - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.queries.PQuery.PQueryStatus
The query definition was successfully initialized
omit(int, int) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance that maps the tuple intact save for a single element at the specified index which is omitted
onlyOnIndexChange() - Method in interface tools.refinery.interpreter.api.scope.InterpreterBaseIndexChangeListener
NOTE: it is possible that this method is called only ONCE! Consider returning a constant value that is set in the constructor.
opposite() - Method in enum class tools.refinery.interpreter.matchers.util.Direction
 
optionalColumn - Variable in class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
OrderedIterableMerge - Class in tools.refinery.interpreter.matchers.algorithms
 
OUT - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.queries.PParameterDirection
The parameters marked with this constraints shall not be set to a value before calling the pattern
outputVariable - Variable in class tools.refinery.interpreter.matchers.psystem.basicdeferred.BaseTypeSafeConstraint
 
overrideBy(QueryEvaluationHint) - Method in class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
Override values in this hint and return a consolidated instance.
owner - Variable in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
The object "owning" this memory.

P

PAnnotation - Class in tools.refinery.interpreter.matchers.psystem.annotations
A container describing query annotations
PAnnotation(String) - Constructor for class tools.refinery.interpreter.matchers.psystem.annotations.PAnnotation
 
PApply - Class in tools.refinery.interpreter.matchers.planning.operations
Represents a constraint application on a single parent SubPlan.
PApply(PConstraint) - Constructor for class tools.refinery.interpreter.matchers.planning.operations.PApply
 
parameterDirectionPredicate(PParameterDirection) - Static method in class tools.refinery.interpreter.matchers.psystem.queries.PQueries
 
parameterNames() - Method in class tools.refinery.interpreter.api.impl.BasePatternMatch
 
parameterNames() - Method in interface tools.refinery.interpreter.api.IPatternMatch
Returns the list of symbolic parameter names.
ParameterReference - Class in tools.refinery.interpreter.matchers.psystem.annotations
An annotation parameter referencing a query parameter by name.
ParameterReference(String) - Constructor for class tools.refinery.interpreter.matchers.psystem.annotations.ParameterReference
 
parameterTypes() - Element in annotation interface tools.refinery.interpreter.matchers.psystem.aggregations.AggregatorType
 
parent - Variable in class tools.refinery.interpreter.matchers.algorithms.UnionFindNodeProperty
 
PARTIAL_BACKEND_ADHESION - Static variable in interface tools.refinery.interpreter.matchers.backend.ICallDelegationStrategy
Options known for callee are used to override caller options, including the backend selection.
PatternCallBasedDeferred - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
 
PatternCallBasedDeferred(PBody, Tuple, PQuery) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternCallBasedDeferred
 
PatternCallBasedDeferred(PBody, Tuple, PQuery, Set<PVariable>) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternCallBasedDeferred
 
patternCallPlan(Tuple, PQuery) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
patternCollector(PQuery) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
patternFinished(PQuery, Collector) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
PatternMatchCounter - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
 
PatternMatchCounter(PBody, Tuple, PQuery, PVariable) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternMatchCounter
 
patternName() - Method in class tools.refinery.interpreter.api.impl.BasePatternMatch
 
patternName() - Method in interface tools.refinery.interpreter.api.IPatternMatch
Identifies the name of the pattern for which this is a match.
pBody - Variable in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
PBody - Class in tools.refinery.interpreter.matchers.psystem
A set of constraints representing a pattern body
PBody(PQuery) - Constructor for class tools.refinery.interpreter.matchers.psystem.PBody
 
PBodyCopier - Class in tools.refinery.interpreter.matchers.psystem.rewriters
This class can create a new PBody for a PQuery.
PBodyCopier(PBody, IRewriterTraceCollector) - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
PBodyCopier(PQuery) - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
 
PBodyNormalizer - Class in tools.refinery.interpreter.matchers.psystem.rewriters
A disjunction rewriter for creating a normalized form of specification, unifying variables and running basic sanity checks.
PBodyNormalizer(IQueryMetaContext) - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyNormalizer
 
PConstraint - Interface in tools.refinery.interpreter.matchers.psystem
 
PDisjunction - Class in tools.refinery.interpreter.matchers.psystem.queries
A disjunction is a set of bodies representing separate conditions.
PDisjunction(Set<PBody>) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.PDisjunction
 
PDisjunction(PQuery, Set<PBody>) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.PDisjunction
 
PDisjunctionRewriter - Class in tools.refinery.interpreter.matchers.psystem.rewriters
An abstract base class for creating alternative representations for PDisjunctions.
PDisjunctionRewriter() - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.PDisjunctionRewriter
 
PDisjunctionRewriterCacher - Class in tools.refinery.interpreter.matchers.psystem.rewriters
A rewriter that stores the previously computed results of a rewriter or a rewriter chain.
PDisjunctionRewriterCacher(List<PDisjunctionRewriter>) - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.PDisjunctionRewriterCacher
 
PDisjunctionRewriterCacher(PDisjunctionRewriter) - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.PDisjunctionRewriterCacher
 
PDisjunctionRewriterCacher(PDisjunctionRewriter...) - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.PDisjunctionRewriterCacher
 
peekExistingResultProvider(PQuery) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryBackend
Returns an existing result provider for a given query, if it was previously constructed, returns null otherwise.
PEnumerate - Class in tools.refinery.interpreter.matchers.planning.operations
Represents a base relation defined by the instance set of an enumerable PConstraint; there are no parent SubPlans.
PEnumerate(EnumerablePConstraint) - Constructor for class tools.refinery.interpreter.matchers.planning.operations.PEnumerate
 
pickFrom(SortedMap<T, Integer>) - Method in enum class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator.Extreme
 
PJoin - Class in tools.refinery.interpreter.matchers.planning.operations
Represents a natural join of two parent SubPlans.
PJoin() - Constructor for class tools.refinery.interpreter.matchers.planning.operations.PJoin
 
plan(PBody, Logger, IQueryMetaContext) - Method in interface tools.refinery.interpreter.matchers.planning.IQueryPlannerStrategy
 
POperation - Class in tools.refinery.interpreter.matchers.planning.operations
Abstract superclass for representing a high-level query evaluation operation.
POperation() - Constructor for class tools.refinery.interpreter.matchers.planning.operations.POperation
 
PositivePatternCall - Class in tools.refinery.interpreter.matchers.psystem.basicenumerables
 
PositivePatternCall(PBody, Tuple, PQuery) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicenumerables.PositivePatternCall
 
powerSet(Set<A>) - Static method in class tools.refinery.interpreter.matchers.util.Sets
 
PParameter - Class in tools.refinery.interpreter.matchers.psystem.queries
A descriptor for declared PQuery parameters.
PParameter(String) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.PParameter
 
PParameter(String, String) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.PParameter
 
PParameter(String, String, IInputKey) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.PParameter
 
PParameter(String, String, IInputKey, PParameterDirection) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.PParameter
 
PParameterDirection - Enum Class in tools.refinery.interpreter.matchers.psystem.queries
Values of this enum describe a constraint to the calling of patterns regarding its parameters.
PProblem - Class in tools.refinery.interpreter.matchers.psystem.queries
Represents an error that was detected while the PQuery object was built from a source.
PProblem(Exception, String) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.PProblem
 
PProblem(Exception, String, Integer, Integer) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.PProblem
 
PProblem(String) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.PProblem
 
PProblem(String, Integer, Integer) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.PProblem
 
PProblem(QueryProcessingException) - Constructor for class tools.refinery.interpreter.matchers.psystem.queries.PProblem
 
pProblems - Variable in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
PProject - Class in tools.refinery.interpreter.matchers.planning.operations
Represents a projection of a single parent SubPlan onto a limited set of variables.
PProject(List<PVariable>) - Constructor for class tools.refinery.interpreter.matchers.planning.operations.PProject
 
PProject(Set<PVariable>) - Constructor for class tools.refinery.interpreter.matchers.planning.operations.PProject
 
PQueries - Class in tools.refinery.interpreter.matchers.psystem.queries
Utility class for using PQueries in functional/streaming collection operations effectively
PQuery - Interface in tools.refinery.interpreter.matchers.psystem.queries
Internal representation of a query / graph pattern (using a constraint system formalism), to be interpreted by a query evaluator (IQueryBackend).
PQuery.PQueryStatus - Enum Class in tools.refinery.interpreter.matchers.psystem.queries
 
PQueryFlattener - Class in tools.refinery.interpreter.matchers.psystem.rewriters
This rewriter class holds the query flattening logic
PQueryFlattener(IFlattenCallPredicate) - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.PQueryFlattener
 
PQueryHeader - Interface in tools.refinery.interpreter.matchers.psystem.queries
Represents header information (metainfo) about a query.
Preconditions - Class in tools.refinery.interpreter.matchers.util
This class was motivated by the similar Preconditions class from Guava to provide simple precondition checking functionality.
prepare(AdvancedInterpreterEngine) - Method in class tools.refinery.interpreter.api.impl.BaseQueryGroup
 
prepare(InterpreterEngine) - Method in class tools.refinery.interpreter.api.impl.BaseQueryGroup
 
prepare(InterpreterEngine) - Method in interface tools.refinery.interpreter.api.IQueryGroup
Initializes matchers for the group of patterns within an InterpreterEngine.
prepareGroup(IQueryGroup, QueryEvaluationHint) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Initializes matchers for a group of patterns as one step (optionally overriding some of the default query evaluation hints).
prepareGroup(IQueryGroup, QueryEvaluationHint) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
presentAtInfinity - Variable in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
prettyPrint() - Method in class tools.refinery.interpreter.api.GenericPatternMatch
 
prettyPrint() - Method in interface tools.refinery.interpreter.api.IPatternMatch
Prints the list of parameter-value pairs.
prettyPrint(Accumulator) - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IMultisetAggregationOperator
Pretty prints the contents of the given accumulator.
prettyPrintValue(Object) - Static method in class tools.refinery.interpreter.api.impl.BasePatternMatch
 
PRIVATE - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.queries.PVisibility
A private query is not expected to be called directly, only by a different query matcher.
PROCESSING_PROBLEM - Static variable in exception class tools.refinery.interpreter.exception.InterpreterException
 
processInitializerError(ExceptionInInitializerError) - Static method in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
projectDependencies(Map<Set<A>, Set<A>>, Set<A>) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.FunctionalDependencyHelper
Returns the dependency set over attributes in
invalid reference
targetAttributes
that are implied by a given source dependency set.
ProvidedValueFunction() - Constructor for class tools.refinery.interpreter.matchers.util.IProvider.ProvidedValueFunction
 
PStart - Class in tools.refinery.interpreter.matchers.planning.operations
No constraints, and no parent SubPlan, just a (possibly empty) set of a priori known (input) variables.
PStart(Set<PVariable>) - Constructor for class tools.refinery.interpreter.matchers.planning.operations.PStart
 
PStart(PVariable...) - Constructor for class tools.refinery.interpreter.matchers.planning.operations.PStart
 
PTraceable - Interface in tools.refinery.interpreter.matchers.psystem
Marker interface for PSystem elements that can be traced.
PUBLIC - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.queries.PVisibility
A public (default) visibility means a pattern can be called at any time.
publishedAs() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
publishedAs() - Method in interface tools.refinery.interpreter.matchers.psystem.queries.PQuery
Returns the end-user query specification API objects that wrap this query.
PurgableCache - Class in tools.refinery.interpreter.matchers.util
 
PurgableCache() - Constructor for class tools.refinery.interpreter.matchers.util.PurgableCache
 
purge() - Method in class tools.refinery.interpreter.matchers.util.PurgableCache
Removes all values stored in the cache
put(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
put(T, Integer) - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
putAll(Map<? extends T, ? extends Integer>) - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
putEager(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
putLazy(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
putOnTab(PQuery) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
PVariable - Class in tools.refinery.interpreter.matchers.psystem
 
PVisibility - Enum Class in tools.refinery.interpreter.matchers.psystem.queries
 

Q

query - Variable in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternCallBasedDeferred
 
QUERY_INIT_PROBLEM - Static variable in exception class tools.refinery.interpreter.exception.InterpreterException
 
QueryAnalyzer - Class in tools.refinery.interpreter.matchers.psystem.analysis
Object responsible for computing and caching static query analysis results.
QueryAnalyzer(IQueryMetaContext) - Constructor for class tools.refinery.interpreter.matchers.psystem.analysis.QueryAnalyzer
 
QueryEvaluationHint - Class in tools.refinery.interpreter.matchers.backend
Provides Refinery Interpreter with additional hints on how a query should be evaluated.
QueryEvaluationHint(Map<QueryHintOption<?>, Object>, IQueryBackendFactory) - Constructor for class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
Specifies the suggested query backend, and value settings for additional backend-specific options.
QueryEvaluationHint(Map<QueryHintOption<?>, Object>, QueryEvaluationHint.BackendRequirement) - Constructor for class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
Specifies the suggested query backend requirements, and value settings for additional backend-specific options.
QueryEvaluationHint.BackendRequirement - Enum Class in tools.refinery.interpreter.matchers.backend
 
QueryHintOption<HintValue> - Class in tools.refinery.interpreter.matchers.backend
Each instance of this class corresponds to a given hint option.
QueryHintOption(Class<?>, String, T) - Constructor for class tools.refinery.interpreter.matchers.backend.QueryHintOption
This is the recommended constructor for hint options defined as static fields within an enclosing class.
QueryHintOption(String, HintValue) - Constructor for class tools.refinery.interpreter.matchers.backend.QueryHintOption
Instantiates an option object with the given name and default value.
QueryInitializationException - Exception Class in tools.refinery.interpreter.matchers.psystem.queries
Represent an exception that occurred while initializing the specification of a query.
QueryInitializationException(String, String[], String, Object) - Constructor for exception class tools.refinery.interpreter.matchers.psystem.queries.QueryInitializationException
 
QueryInitializationException(String, String[], String, Object, Throwable) - Constructor for exception class tools.refinery.interpreter.matchers.psystem.queries.QueryInitializationException
 
QueryProcessingException - Exception Class in tools.refinery.interpreter.matchers.planning
 
QueryProcessingException(String, Object) - Constructor for exception class tools.refinery.interpreter.matchers.planning.QueryProcessingException
 
QueryProcessingException(String, String[], String, Object) - Constructor for exception class tools.refinery.interpreter.matchers.planning.QueryProcessingException
 
QueryProcessingException(String, String[], String, Object, Throwable) - Constructor for exception class tools.refinery.interpreter.matchers.planning.QueryProcessingException
 
QueryResultWrapper - Class in tools.refinery.interpreter.internal.apiimpl
Internal class for wrapping a query result providing backend.
QueryResultWrapper() - Constructor for class tools.refinery.interpreter.internal.apiimpl.QueryResultWrapper
 
QueryScope - Class in tools.refinery.interpreter.api.scope
Defines a scope for a Refinery Interpreter engine, which determines the set of model elements that query evaluation operates on.
QueryScope() - Constructor for class tools.refinery.interpreter.api.scope.QueryScope
 
querySpecification - Variable in class tools.refinery.interpreter.api.impl.BaseMatcher
 
querySpecifications - Variable in class tools.refinery.interpreter.api.impl.BaseGeneratedPatternGroup
Returns IQuerySpecification objects for handling them as a group.
queryStatusPredicate(PQuery.PQueryStatus) - Static method in class tools.refinery.interpreter.matchers.psystem.queries.PQueries
Predicate checking for the status of selected queries

R

raiseDuplicateDeletion(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
 
raiseDuplicateInsertion(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
 
raiseIndexingError(int) - Method in class tools.refinery.interpreter.matchers.tuple.AbstractTuple
 
rank - Variable in class tools.refinery.interpreter.matchers.algorithms.UnionFindNodeProperty
 
rawAccumulateAllValues(int, Object[], Set<T>) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
Uses an existing set to accumulate all values of the parameter with the given name.
rawCountMatches(Object[]) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
Returns the number of all matches of the pattern that conform to the given fixed values of some parameters.
rawForEachMatch(Object[], Consumer<? super Match>) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
Executes the given processor on each match of the pattern that conforms to the given fixed values of some parameters.
rawForOneArbitraryMatch(Object[], Consumer<? super Match>) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
Executes the given processor on an arbitrarily chosen match of the pattern that conforms to the given fixed values of some parameters.
rawGetOneArbitraryMatch(Object[]) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
Returns an arbitrarily chosen match of the pattern that conforms to the given fixed values of some parameters.
rawHasMatch(Object[]) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
Indicates whether the given combination of specified pattern parameters constitute a valid pattern match, under any possible substitution of the unspecified parameters.
rawStreamAllMatches(Object[]) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
Returns a stream of all matches of the pattern that conform to the given fixed values of some parameters.
rawStreamAllValues(int, Object[]) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
Retrieve a stream of values that occur in matches for the given parameterName, that conforms to the given fixed values of some parameters.
reciprocal() - Method in enum class tools.refinery.interpreter.matchers.util.Accuracy
 
refer(PConstraint) - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
Register that this variable is referred by the given constraint.
registerFoldingState(Timestamp, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
registerFoldingState(Timestamp, Object) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
registerSurrogateQueryForFeature(IInputKey, PQuery) - Method in class tools.refinery.interpreter.matchers.context.surrogate.SurrogateQueryRegistry
 
registerSurrogateQueryForFeature(IInputKey, IProvider<PQuery>) - Method in class tools.refinery.interpreter.matchers.context.surrogate.SurrogateQueryRegistry
 
reinitialize() - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
RelationEvaluation - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
A constraint which prescribes the evaluation of custom Java logic that takes an arbitrary number of input relations and produces one output relation.
RelationEvaluation(PBody, Tuple, List<PQuery>, IRelationEvaluator) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.RelationEvaluation
 
remove(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
remove(Object) - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
remove(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
remove(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
remove(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Removes a tuple occurrence from the memory.
remove(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
remove(Tuple) - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
remove(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
remove(Tuple, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
 
remove(Tuple, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
remove(Tuple, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Removes a tuple occurrence from the memory with the given signature.
remove(Tuple, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
remove(Tuple, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
removeAll(Collection<?>) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
removeBaseIndexChangeListener(InterpreterBaseIndexChangeListener) - Method in interface tools.refinery.interpreter.api.scope.IBaseIndex
Removes a registered listener.
removeDynamicSurrogateQueryForFeature(IInputKey) - Method in class tools.refinery.interpreter.matchers.context.surrogate.SurrogateQueryRegistry
 
removeEager(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
removeFromBucket(Bucket, Value, boolean) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
Decreases the multiplicity of the value in the bucket.
removeFromBucket(MarkedMemory.MarkedMultiset<Value>, Value, boolean) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToMultisetsAbstract
 
removeFromBucket(MarkedMemory.MarkedSet<Value>, Value, boolean) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract.ToSetsAbstract
 
removeIndexingErrorListener(IIndexingErrorListener) - Method in interface tools.refinery.interpreter.api.scope.IBaseIndex
Removes a listener for internal errors in the index
removeInstanceObserver(IInstanceObserver, Object) - Method in interface tools.refinery.interpreter.api.scope.IBaseIndex
Unregisters a lightweight observer for the given Object.
removeInternal(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
removeInternal(Object, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
removeInternal(Tuple, Object) - Method in class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
removeLazy(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
removeLifecycleListener(InterpreterEngineLifecycleListener) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Remove an existing lifecycle listener from this engine instance.
removeLifecycleListener(InterpreterEngineLifecycleListener) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
removeListener(Listener) - Method in class tools.refinery.interpreter.internal.engine.ListenerContainer
 
removeMatchUpdateListener(InterpreterMatcher<Match>, IMatchUpdateListener<? super Match>) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Remove an existing match update event listener to this engine instance.
removeMatchUpdateListener(InterpreterMatcher<Match>, IMatchUpdateListener<? super Match>) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
removeModelUpdateListener(InterpreterModelUpdateListener) - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Remove an existing model update event listener to this engine instance.
removeModelUpdateListener(InterpreterModelUpdateListener) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
removeOne(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
removeOne(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
removeOne(T) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsDeltaBag
 
removeOne(T) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsMultiset
 
removeOne(T) - Method in interface tools.refinery.interpreter.matchers.util.IMemory
Removes one occurrence of the given value from the memory.
removeOne(T) - Method in interface tools.refinery.interpreter.matchers.util.ISetMemory
 
removeOne(Value) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
removeOneInternal(Long, boolean) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
removeOneInternal(T, boolean) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsMultiset
 
removeOneOrNop(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongMultiset
 
removeOneOrNop(Long) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory
 
removeOneOrNop(T) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsMultiset
 
removeOneOrNop(T) - Method in interface tools.refinery.interpreter.matchers.util.IDeltaBag
 
removeOneOrNop(T) - Method in interface tools.refinery.interpreter.matchers.util.IMemory
Removes one occurrence of the given value from the memory, if possible.
removeOneOrNop(Value) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
removePair(Key, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Removes key-value pair from the lookup structure, or fails if not possible.
removePair(Key, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
removePairInternal(Key, Value, boolean) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
removePairOrNop(Key, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookup
Removes key-value pair from the lookup structure.
removePairOrNop(Key, Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
removeUpdateListener(Object) - Method in interface tools.refinery.interpreter.matchers.backend.IQueryResultProvider
Removes an existing listener previously registered with the given tag.
removeUpdateListener(IInputKey, Tuple, IQueryRuntimeContextListener) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Unsubscribes from updates in the extensional relation identified by the input key, optionally seeded with the given tuple.
removeWithTimestamp(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Removes a tuple occurrence from the memory with the given timestamp.
removeWithTimestamp(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
removeWithTimestamp(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
removeWithTimestamp(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
removeWithTimestamp(Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
removeWithTimestamp(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
Removes a tuple occurrence from the memory with the given signature and timestamp.
removeWithTimestamp(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
removeWithTimestamp(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
removeWithTimestamp(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
removeWithTimestamp(Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
replaceAll(Object, Object) - Method in class tools.refinery.interpreter.matchers.tuple.Tuple
 
replaceVariable(PVariable, PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
replaceVariable(PVariable, PVariable) - Method in interface tools.refinery.interpreter.matchers.psystem.PConstraint
 
RepresentativeElectionConstraint - Class in tools.refinery.interpreter.matchers.psystem.basicenumerables
 
RepresentativeElectionConstraint(PBody, Tuple, PQuery, Connectivity) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicenumerables.RepresentativeElectionConstraint
 
requestResultProvider(IQueryReference, QueryEvaluationHint) - Method in class tools.refinery.interpreter.matchers.backend.ResultProviderRequestor
 
resampleDerivedFeatures() - Method in interface tools.refinery.interpreter.api.scope.IBaseIndex
Updates the value of indexed derived features that are not well-behaving.
ResultProviderRequestor - Class in tools.refinery.interpreter.matchers.backend
Uniform way of requesting result providers for pattern calls within queries.
ResultProviderRequestor(IQueryBackend, IQueryResultProviderAccess, IQueryBackendHintProvider, ICallDelegationStrategy, QueryEvaluationHint, QueryEvaluationHint) - Constructor for class tools.refinery.interpreter.matchers.backend.ResultProviderRequestor
 
resultVariable - Variable in class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
resultVariable - Variable in class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
Resumable<Timestamp> - Interface in tools.refinery.interpreter.matchers.util.resumable
A resumable lazily folds its state towards higher timestamps.
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
 
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
resumeAt(Timestamp) - Method in interface tools.refinery.interpreter.matchers.util.resumable.MaskedResumable
When called, the folding of the state shall be resumed at the given timestamp.
resumeAt(Timestamp) - Method in interface tools.refinery.interpreter.matchers.util.resumable.UnmaskedResumable
When called, the folding of the state shall be resumed at the given timestamp.
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
retainAll(Collection<?>) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
returnTypes() - Element in annotation interface tools.refinery.interpreter.matchers.psystem.aggregations.AggregatorType
 
revertFrom(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Returns a tuple `result` that satisfies `this.transform(result).equals(masked)`.
revertFrom(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMaskIdentity
 
rewrite(PDisjunction) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyNormalizer
 
rewrite(PDisjunction) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PDisjunctionRewriter
 
rewrite(PDisjunction) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PDisjunctionRewriterCacher
 
rewrite(PDisjunction) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PQueryFlattener
 
rewrite(PDisjunction) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.SurrogateQueryRewriter
 
rewrite(PQuery) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PDisjunctionRewriter
 
RewriterException - Exception Class in tools.refinery.interpreter.matchers.psystem.rewriters
An exception to wrap various issues during PDisjunction rewriting.
RewriterException(String, String[], String, Object) - Constructor for exception class tools.refinery.interpreter.matchers.psystem.rewriters.RewriterException
 
RewriterException(String, String[], String, Object, Throwable) - Constructor for exception class tools.refinery.interpreter.matchers.psystem.rewriters.RewriterException
 

S

SameName() - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.IVariableRenamer.SameName
 
selectSingle(int, int) - Static method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance that selects a single element of the tuple.
set(int, Object) - Method in class tools.refinery.interpreter.api.impl.BasePatternMatch
 
set(int, Object) - Method in interface tools.refinery.interpreter.api.IPatternMatch
Sets the parameter at the given position to the given value.
set(int, Object) - Method in interface tools.refinery.interpreter.matchers.tuple.IModifiableTuple
Sets the selected value for a tuple
set(int, Object) - Method in class tools.refinery.interpreter.matchers.tuple.VolatileModifiableMaskedTuple
 
set(String, Object) - Method in class tools.refinery.interpreter.api.GenericPatternMatch
 
set(String, Object) - Method in interface tools.refinery.interpreter.api.IPatternMatch
Sets the parameter with the given name to the given value.
set(IModifiableTuple, int, Object) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Sets the selected value in the original tuple based on the mask definition
setAppearCallback(Consumer<Match>) - Method in class tools.refinery.interpreter.api.MatchUpdateAdapter
 
setBackend(InterpreterEngine, IQueryResultProvider, IMatcherCapability) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
setBackend(InterpreterEngine, IQueryResultProvider, IMatcherCapability) - Method in class tools.refinery.interpreter.internal.apiimpl.QueryResultWrapper
 
setBodies(Set<PBody>) - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
setCallCount(int) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.IVariableRenamer.HierarchicalName
 
setContainerDisjunction(PDisjunction) - Method in class tools.refinery.interpreter.matchers.psystem.PBody
 
setContext(IQueryMetaContext) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyNormalizer
 
setDisappearCallback(Consumer<Match>) - Method in class tools.refinery.interpreter.api.MatchUpdateAdapter
 
setEvaluationHints(QueryEvaluationHint) - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
setPatternDescription(Object) - Method in exception class tools.refinery.interpreter.matchers.planning.QueryProcessingException
 
Sets - Class in tools.refinery.interpreter.matchers.util
This class was motivated by the similar Sets class from Guava to provide simple set manipulation functionality.
Sets() - Constructor for class tools.refinery.interpreter.matchers.util.Sets
 
SETS - Enum constant in enum class tools.refinery.interpreter.matchers.util.CollectionsFactory.MemoryType
A single key-value pair is stored at most once
setStatus(PQuery.PQueryStatus) - Method in interface tools.refinery.interpreter.matchers.psystem.InitializablePQuery
Sets the query status.
setStatus(PQuery.PQueryStatus) - Method in class tools.refinery.interpreter.matchers.psystem.PBody
Sets a specific status for the body.
setStatus(PQuery.PQueryStatus) - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
setSymbolicParameters(List<ExportedParameter>) - Method in class tools.refinery.interpreter.matchers.psystem.PBody
Sets the exported parameter constraints of the body, if this instance is mutable.
setSystemDefaultBackends(IQueryBackendFactory, IQueryBackendFactory, IQueryBackendFactory) - Static method in class tools.refinery.interpreter.api.InterpreterEngineOptions
 
setTraceCollector(IRewriterTraceCollector) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.AbstractRewriterTraceSource
 
SetWrapper(LongSet) - Constructor for class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
shouldCalculateImpliedTypes(PQuery) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyNormalizer
Returns whether unary constraint elimination is enabled.
shouldExpandWeakenedAlternatives(PQuery) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyNormalizer
Returns whether 'weakened alternative' suggestions of the context shall be expanded as additional PConstraints.
shouldFlatten(PositivePatternCall) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.DefaultFlattenCallPredicate
 
shouldFlatten(PositivePatternCall) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.IFlattenCallPredicate.And
 
shouldFlatten(PositivePatternCall) - Method in interface tools.refinery.interpreter.matchers.psystem.rewriters.IFlattenCallPredicate
Decides whether the called query by the pattern call should be flattened into the caller or not.
shouldFlatten(PositivePatternCall) - Method in class tools.refinery.interpreter.matchers.psystem.rewriters.NeverFlattenCallPredicate
 
signatureToTuples - Variable in class tools.refinery.interpreter.matchers.memories.DefaultMaskedTupleMemory
Maps a signature tuple to the bucket of tuples with the given signature.
Signed<Payload> - Class in tools.refinery.interpreter.matchers.util
A piece of data associated with a direction.
Signed(Direction, Payload) - Constructor for class tools.refinery.interpreter.matchers.util.Signed
 
SingletonInstanceProvider<T> - Class in tools.refinery.interpreter.matchers.util
A provider implementation that always returns the same object instance.
SingletonInstanceProvider(T) - Constructor for class tools.refinery.interpreter.matchers.util.SingletonInstanceProvider
 
SingletonMemoryView<Value> - Class in tools.refinery.interpreter.matchers.util
An immutable memory view that consists of a single non-null element with multiplicity 1.
SingletonMemoryView(Value) - Constructor for class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
SingletonTimeline<Timestamp> - Class in tools.refinery.interpreter.matchers.util.timeline
A timeline which solely consists of one timestamp value, representing a single insertion.
size() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
size() - Method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
size() - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
 
size() - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
size() - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
size() - Method in class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
size() - Method in class tools.refinery.interpreter.matchers.util.timeline.CompactTimeline
 
size() - Method in class tools.refinery.interpreter.matchers.util.timeline.SingletonTimeline
 
size() - Method in class tools.refinery.interpreter.matchers.util.timeline.Timeline
 
size() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
source - Variable in class tools.refinery.interpreter.matchers.tuple.VolatileMaskedTuple
 
sourceWidth - Variable in class tools.refinery.interpreter.matchers.tuple.TupleMask
the size of the tuple this mask is applied to
SPECIFIC - Enum constant in enum class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint.BackendRequirement
The current hint specifies that a specific backend is to be used
specification() - Method in class tools.refinery.interpreter.api.GenericPatternMatch
 
specification() - Method in interface tools.refinery.interpreter.api.IPatternMatch
 
start - Variable in class tools.refinery.interpreter.matchers.util.timeline.SingletonTimeline
 
staticArityFlatTupleOf() - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a flat tuple consisting of no elements.
staticArityFlatTupleOf(Object) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a flat tuple consisting of the given single element.
staticArityFlatTupleOf(Object, Object) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a flat tuple consisting of the given elements.
staticArityFlatTupleOf(Object, Object, Object) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a flat tuple consisting of the given elements.
staticArityFlatTupleOf(Object, Object, Object, Object) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a flat tuple consisting of the given elements.
staticArityLeftInheritanceTupleOf(Tuple, Object) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a left inheritance tuple consisting of the given single local element.
staticArityLeftInheritanceTupleOf(Tuple, Object, Object) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a left inheritance tuple consisting of the given local elements.
staticArityLeftInheritanceTupleOf(Tuple, Object, Object, Object) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a left inheritance tuple consisting of the given local elements.
staticArityLeftInheritanceTupleOf(Tuple, Object, Object, Object, Object) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a left inheritance tuple consisting of the given local elements.
STATISTICS - Enum constant in enum class tools.refinery.interpreter.matchers.context.IndexingService
Cardinality information is available.
StatisticsHelper - Class in tools.refinery.interpreter.matchers.planning.helpers
Helpers dealing with optionally present statistics information
status - Variable in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
streamAllMatches() - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
streamAllMatches() - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns a stream of all pattern matches.
streamAllMatches(Match) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
streamAllMatches(Match) - Method in interface tools.refinery.interpreter.api.InterpreterMatcher
Returns a stream of all matches of the pattern that conform to the given fixed values of some parameters.
STRONG - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.basicenumerables.Connectivity
 
SubPlan - Class in tools.refinery.interpreter.matchers.planning
A plan representing a subset of (or possibly all the) constraints evaluated.
SubPlan(PBody, POperation, List<? extends SubPlan>) - Constructor for class tools.refinery.interpreter.matchers.planning.SubPlan
A SubPlan is constructed by applying a POperation on zero or more parent SubPlans.
SubPlan(PBody, POperation, SubPlan...) - Constructor for class tools.refinery.interpreter.matchers.planning.SubPlan
A SubPlan is constructed by applying a POperation on zero or more parent SubPlans.
SubPlanFactory - Class in tools.refinery.interpreter.matchers.planning
Single entry point for creating subplans.
SubPlanFactory(PBody) - Constructor for class tools.refinery.interpreter.matchers.planning.SubPlanFactory
 
subsumeTypes(Set<TypeJudgement>, Set<TypeJudgement>, IQueryMetaContext) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.TypeHelper
Calculates a remainder set of types from a larger set, that are not subsumed by a given set of subsuming types.
sum - Class in tools.refinery.interpreter.matchers.aggregators
This aggregator calculates the sum of the values of a selected aggregate parameter of a called pattern.
sum() - Constructor for class tools.refinery.interpreter.matchers.aggregators.sum
 
supplierKey - Variable in class tools.refinery.interpreter.matchers.psystem.KeyedEnumerablePConstraint
 
SurrogateQueryRegistry - Class in tools.refinery.interpreter.matchers.context.surrogate
 
SurrogateQueryRewriter - Class in tools.refinery.interpreter.matchers.psystem.rewriters
 
SurrogateQueryRewriter() - Constructor for class tools.refinery.interpreter.matchers.psystem.rewriters.SurrogateQueryRewriter
 

T

ternaryEdgeTypePlan(Tuple, Object) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
theContainedVersionOf(T) - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
Where supported, returns the stored element that is equal to the given value, or null if none.
theContainedVersionOf(Value) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
theContainedVersionOfUnsafe(Object) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsSetMemory
 
theContainedVersionOfUnsafe(Object) - Method in interface tools.refinery.interpreter.matchers.util.IMemoryView
Where supported, returns the stored element that is equal to the given value (of any type), or null if none.
Timeline<Timestamp> - Class in tools.refinery.interpreter.matchers.util.timeline
A timeline describes the life cycle of a piece of data (typically a tuple in a relation) as a sequence of moments.
Timeline() - Constructor for class tools.refinery.interpreter.matchers.util.timeline.Timeline
 
timelines - Variable in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
Timelines<Timestamp> - Class in tools.refinery.interpreter.matchers.util.timeline
Utility class for creating Timelines.
Timelines() - Constructor for class tools.refinery.interpreter.matchers.util.timeline.Timelines
 
TimelyDefaultMaskedTupleMemory<Timestamp> - Class in tools.refinery.interpreter.matchers.memories.timely
Default timely implementation that covers all cases.
TimelyDefaultMaskedTupleMemory(TupleMask, Object, boolean) - Constructor for class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
TimelyIdentityMaskedTupleMemory<Timestamp> - Class in tools.refinery.interpreter.matchers.memories.timely
Timely specialization for identity mask.
TimelyIdentityMaskedTupleMemory(TupleMask, Object, boolean) - Constructor for class tools.refinery.interpreter.matchers.memories.timely.TimelyIdentityMaskedTupleMemory
 
TimelyMemory<Timestamp> - Class in tools.refinery.interpreter.matchers.util
A timely memory implementation that incrementally maintains the Timelines of tuples.
TimelyMemory() - Constructor for class tools.refinery.interpreter.matchers.util.TimelyMemory
 
TimelyMemory(boolean) - Constructor for class tools.refinery.interpreter.matchers.util.TimelyMemory
 
TimelyMemory.CumulativeCounter - Class in tools.refinery.interpreter.matchers.util
 
TimelyMemory.FoldingState - Class in tools.refinery.interpreter.matchers.util
 
TimelyMemory.SignChange - Enum Class in tools.refinery.interpreter.matchers.util
 
TimelyNullaryMaskedTupleMemory<Timestamp> - Class in tools.refinery.interpreter.matchers.memories.timely
Timely specialization for nullary mask.
TimelyNullaryMaskedTupleMemory(TupleMask, Object, boolean) - Constructor for class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
TimelyUnaryMaskedTupleMemory<Timestamp> - Class in tools.refinery.interpreter.matchers.memories.timely
Timely specialization for unary mask.
TimelyUnaryMaskedTupleMemory(TupleMask, Object, boolean) - Constructor for class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
toArray() - Method in class tools.refinery.interpreter.api.GenericPatternMatch
 
toArray() - Method in interface tools.refinery.interpreter.api.IPatternMatch
Converts the match to an array representation, with each pattern parameter at their respective position.
toArray() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
toArray(T[]) - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsLongSetMemory.SetWrapper
 
toImmutable() - Method in class tools.refinery.interpreter.api.GenericPatternMatch
 
toImmutable() - Method in interface tools.refinery.interpreter.api.IPatternMatch
Takes an immutable snapshot of this match.
toImmutable() - Method in interface tools.refinery.interpreter.matchers.tuple.ITuple
 
toImmutable() - Method in class tools.refinery.interpreter.matchers.tuple.Tuple
 
toImmutable() - Method in class tools.refinery.interpreter.matchers.tuple.VolatileTuple
Creates an immutable tuple from the values stored in the tuple.
toLongString() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
 
tools.refinery.interpreter - package tools.refinery.interpreter
 
tools.refinery.interpreter.api - package tools.refinery.interpreter.api
 
tools.refinery.interpreter.api.impl - package tools.refinery.interpreter.api.impl
 
tools.refinery.interpreter.api.scope - package tools.refinery.interpreter.api.scope
 
tools.refinery.interpreter.exception - package tools.refinery.interpreter.exception
 
tools.refinery.interpreter.internal.apiimpl - package tools.refinery.interpreter.internal.apiimpl
 
tools.refinery.interpreter.internal.engine - package tools.refinery.interpreter.internal.engine
 
tools.refinery.interpreter.matchers - package tools.refinery.interpreter.matchers
 
tools.refinery.interpreter.matchers.aggregators - package tools.refinery.interpreter.matchers.aggregators
 
tools.refinery.interpreter.matchers.algorithms - package tools.refinery.interpreter.matchers.algorithms
 
tools.refinery.interpreter.matchers.backend - package tools.refinery.interpreter.matchers.backend
 
tools.refinery.interpreter.matchers.context - package tools.refinery.interpreter.matchers.context
 
tools.refinery.interpreter.matchers.context.common - package tools.refinery.interpreter.matchers.context.common
 
tools.refinery.interpreter.matchers.context.surrogate - package tools.refinery.interpreter.matchers.context.surrogate
 
tools.refinery.interpreter.matchers.memories - package tools.refinery.interpreter.matchers.memories
 
tools.refinery.interpreter.matchers.memories.timely - package tools.refinery.interpreter.matchers.memories.timely
 
tools.refinery.interpreter.matchers.planning - package tools.refinery.interpreter.matchers.planning
 
tools.refinery.interpreter.matchers.planning.helpers - package tools.refinery.interpreter.matchers.planning.helpers
 
tools.refinery.interpreter.matchers.planning.operations - package tools.refinery.interpreter.matchers.planning.operations
 
tools.refinery.interpreter.matchers.psystem - package tools.refinery.interpreter.matchers.psystem
 
tools.refinery.interpreter.matchers.psystem.aggregations - package tools.refinery.interpreter.matchers.psystem.aggregations
 
tools.refinery.interpreter.matchers.psystem.analysis - package tools.refinery.interpreter.matchers.psystem.analysis
 
tools.refinery.interpreter.matchers.psystem.annotations - package tools.refinery.interpreter.matchers.psystem.annotations
 
tools.refinery.interpreter.matchers.psystem.basicdeferred - package tools.refinery.interpreter.matchers.psystem.basicdeferred
 
tools.refinery.interpreter.matchers.psystem.basicenumerables - package tools.refinery.interpreter.matchers.psystem.basicenumerables
 
tools.refinery.interpreter.matchers.psystem.queries - package tools.refinery.interpreter.matchers.psystem.queries
 
tools.refinery.interpreter.matchers.psystem.rewriters - package tools.refinery.interpreter.matchers.psystem.rewriters
 
tools.refinery.interpreter.matchers.tuple - package tools.refinery.interpreter.matchers.tuple
 
tools.refinery.interpreter.matchers.util - package tools.refinery.interpreter.matchers.util
 
tools.refinery.interpreter.matchers.util.resumable - package tools.refinery.interpreter.matchers.util.resumable
 
tools.refinery.interpreter.matchers.util.timeline - package tools.refinery.interpreter.matchers.util.timeline
 
tools.refinery.interpreter.util - package tools.refinery.interpreter.util
 
toShortString() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
 
toString() - Method in class tools.refinery.interpreter.api.impl.BasePatternMatch
 
toString() - Method in class tools.refinery.interpreter.api.InterpreterEngineOptions
 
toString() - Method in class tools.refinery.interpreter.matchers.algorithms.UnionFindNodeProperty
 
toString() - Method in class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint
 
toString() - Method in class tools.refinery.interpreter.matchers.backend.QueryHintOption
 
toString() - Method in class tools.refinery.interpreter.matchers.context.common.JavaTransitiveInstancesKey
 
toString() - Method in class tools.refinery.interpreter.matchers.memories.MaskedTupleMemory
 
toString() - Method in class tools.refinery.interpreter.matchers.planning.operations.POperation
 
toString() - Method in class tools.refinery.interpreter.matchers.planning.SubPlan
 
toString() - Method in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
toString() - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
 
toString() - Method in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
toString() - Method in class tools.refinery.interpreter.matchers.psystem.TypeJudgement
 
toString() - Method in class tools.refinery.interpreter.matchers.tuple.AbstractTuple
 
toString() - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
 
toString() - Method in class tools.refinery.interpreter.matchers.util.EclipseCollectionsBagMemory
 
toString() - Method in class tools.refinery.interpreter.matchers.util.EmptyMemory
 
toString() - Method in class tools.refinery.interpreter.matchers.util.MapBackedMemoryView
 
toString() - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
toString() - Method in class tools.refinery.interpreter.matchers.util.Signed
 
toString() - Method in class tools.refinery.interpreter.matchers.util.SingletonMemoryView
 
toString() - Method in class tools.refinery.interpreter.matchers.util.timeline.Timeline
 
toString() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory.CumulativeCounter
 
toString() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory.FoldingState
 
toString() - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
 
toStringRest() - Method in class tools.refinery.interpreter.matchers.psystem.BasePConstraint
 
toStringRest() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.AggregatorConstraint
 
toStringRest() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Equality
 
toStringRest() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExportedParameter
 
toStringRest() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.ExpressionEvaluation
 
toStringRest() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.Inequality
 
toStringRest() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.LeftJoinConstraint
 
toStringRest() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.NegativePatternCall
 
toStringRest() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.PatternMatchCounter
 
toStringRest() - Method in class tools.refinery.interpreter.matchers.psystem.basicdeferred.TypeFilterConstraint
 
toStringRest() - Method in class tools.refinery.interpreter.matchers.psystem.EnumerablePConstraint
 
toStringRestRest() - Method in class tools.refinery.interpreter.matchers.psystem.EnumerablePConstraint
 
toStringRestRest() - Method in class tools.refinery.interpreter.matchers.psystem.KeyedEnumerablePConstraint
 
transform(List<T>) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Generates an immutable, masked view of the original tuple.
transform(List<T>) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask0
 
transform(List<T>) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMaskIdentity
 
transform(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Generates an immutable, masked view of the original tuple.
transform(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask0
 
transform(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMaskIdentity
 
transform(TupleMask) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Transforms a given mask directly, instead of transforming tuples that were transformed by the other mask.
transform(TupleMask) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask0
 
transform(TupleMask) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMaskIdentity
 
transformHints(IQueryReference, QueryEvaluationHint, IQueryBackend, IQueryBackendHintProvider) - Method in interface tools.refinery.interpreter.matchers.backend.ICallDelegationStrategy
Specifies how hints (including backend preferences) shall propagate through pattern calls.
transformUnique(List<T>) - Method in class tools.refinery.interpreter.matchers.tuple.TupleMask
Transforms the given list by applying the mask and putting all results into a set; keeping only a single element in case of the mapping result in duplicate values.
transitiveContainmentPlan(Tuple) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
transitiveGeneralizationPlan(Tuple) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
transitiveInstantiationPlan(Tuple) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
trimUnneccessaryVariables(SubPlanFactory, SubPlan, boolean, QueryAnalyzer) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.BuildHelper
Reduces the number of tuples by trimming (existentially quantifying) the set of variables that are visible in the subplan, are not exported parameters, have all their constraints already enforced in the subplan, and thus will not be needed anymore.
Tuple - Class in tools.refinery.interpreter.matchers.tuple
Immutable tuple.
Tuple() - Constructor for class tools.refinery.interpreter.matchers.tuple.Tuple
Creates a Tuple instance Derivatives should call calcHash()
TupleMask - Class in tools.refinery.interpreter.matchers.tuple
Specifies select indices of a tuple.
TupleMask(int[], int, int[], Boolean) - Constructor for class tools.refinery.interpreter.matchers.tuple.TupleMask
Creates a TupleMask instance with the given indices array
TupleMask0 - Class in tools.refinery.interpreter.matchers.tuple
 
TupleMaskIdentity - Class in tools.refinery.interpreter.matchers.tuple
 
tuples - Variable in class tools.refinery.interpreter.matchers.memories.IdentityMaskedTupleMemory
 
tuples - Variable in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
Tuples - Class in tools.refinery.interpreter.matchers.tuple
Common static factory utilities for tuples.
tupleToMatch(Tuple) - Method in class tools.refinery.interpreter.api.GenericPatternMatcher
 
tupleToMatch(Tuple) - Method in class tools.refinery.interpreter.api.impl.BaseMatcher
 
TupleValueProvider - Class in tools.refinery.interpreter.matchers.tuple
 
TupleValueProvider(ITuple, Map<String, Integer>) - Constructor for class tools.refinery.interpreter.matchers.tuple.TupleValueProvider
Wraps a tuple with an index mapping
TYPE_SUBSUMED - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.rewriters.ConstraintRemovalReason
 
typeClosure(Set<TypeJudgement>, Set<TypeJudgement>, IQueryMetaContext) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.TypeHelper
Calculates the closure of a set of type judgements (with respect to supertyping), where the closure has been calculated before for a given base set, but not for a separate delta set.
typeClosure(Set<TypeJudgement>, IQueryMetaContext) - Static method in class tools.refinery.interpreter.matchers.planning.helpers.TypeHelper
Calculates the closure of a set of type judgements, with respect to supertyping.
TypeConstraint - Class in tools.refinery.interpreter.matchers.psystem.basicenumerables
Represents an enumerable type constraint that asserts that values substituted for the given tuple of variables form a tuple that belongs to an enumerable extensional relation identified by an IInputKey.
TypeConstraint(PBody, Tuple, IInputKey) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicenumerables.TypeConstraint
 
TypeFilterConstraint - Class in tools.refinery.interpreter.matchers.psystem.basicdeferred
Represents a non-enumerable type constraint that asserts that values substituted for the given tuple of variables form a tuple that belongs to a (typically non-enumerable) extensional relation identified by an IInputKey.
TypeFilterConstraint(PBody, Tuple, IInputKey) - Constructor for class tools.refinery.interpreter.matchers.psystem.basicdeferred.TypeFilterConstraint
 
TypeHelper - Class in tools.refinery.interpreter.matchers.planning.helpers
 
TypeJudgement - Class in tools.refinery.interpreter.matchers.psystem
A judgement that means that the given tuple of variables will represent a tuple of values that is a member of the extensional relation identified by the given input key.
TypeJudgement(IInputKey, Tuple) - Constructor for class tools.refinery.interpreter.matchers.psystem.TypeJudgement
 

U

UnaryMaskedTupleMemory<Timestamp> - Class in tools.refinery.interpreter.matchers.memories
Specialized for unary mask; tuples are indexed by a single column as opposed to a projection (signature) tuple.
UnaryMaskedTupleMemory(TupleMask, CollectionsFactory.MemoryType, Object) - Constructor for class tools.refinery.interpreter.matchers.memories.UnaryMaskedTupleMemory
 
unaryTypePlan(Tuple, Object) - Method in interface tools.refinery.interpreter.matchers.planning.IOperationCompiler
 
unifyInto(PVariable) - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
Replaces this variable with a given other, resulting in their unification.
UNINITIALIZED - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.queries.PQuery.PQueryStatus
Marks that the query definition is not initialized
union(Set<A>, Set<A>) - Static method in class tools.refinery.interpreter.matchers.util.Sets
 
union(V, V) - Method in class tools.refinery.interpreter.matchers.algorithms.UnionFind
Union by rank implementation of the two sets which contain x and y; x and/or y can be a single element from the universe.
UnionFind<V> - Class in tools.refinery.interpreter.matchers.algorithms
Union-find data structure implementation.
UnionFind() - Constructor for class tools.refinery.interpreter.matchers.algorithms.UnionFind
Instantiate a new union-find data structure.
UnionFind(Iterable<V>) - Constructor for class tools.refinery.interpreter.matchers.algorithms.UnionFind
Instantiate a new union-find data structure with the given elements as separate sets.
UnionFindNodeProperty<V> - Class in tools.refinery.interpreter.matchers.algorithms
 
UnionFindNodeProperty() - Constructor for class tools.refinery.interpreter.matchers.algorithms.UnionFindNodeProperty
 
UnionFindNodeProperty(int, V) - Constructor for class tools.refinery.interpreter.matchers.algorithms.UnionFindNodeProperty
 
UNIT_RELATION - Static variable in class tools.refinery.interpreter.matchers.memories.NullaryMaskedTupleMemory
 
UNIT_RELATION - Static variable in class tools.refinery.interpreter.matchers.memories.timely.TimelyNullaryMaskedTupleMemory
 
unite(Set<V>) - Method in class tools.refinery.interpreter.matchers.algorithms.UnionFind
Places the given elements in to the same partition.
UnmaskedResumable<Timestamp> - Interface in tools.refinery.interpreter.matchers.util.resumable
A unmasked Resumable implementation, which maintains lazy folding without caring about tuple signatures.
unrefer(PConstraint) - Method in class tools.refinery.interpreter.matchers.psystem.PVariable
Register that this variable is no longer referred by the given constraint.
unregisterFoldingState(Timestamp, Tuple) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyDefaultMaskedTupleMemory
 
unregisterFoldingState(Timestamp, Object) - Method in class tools.refinery.interpreter.matchers.memories.timely.TimelyUnaryMaskedTupleMemory
 
UNSPECIFIED - Enum constant in enum class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint.BackendRequirement
The current hint does not specify any backend requirement
unwrapElement(Object) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Unwraps the internal representation of the element into its original form
unwrapTuple(Tuple) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Unwraps the tuple of internal representations of elements into their original forms
update(Accumulator, Domain, boolean) - Method in interface tools.refinery.interpreter.matchers.psystem.aggregations.IMultisetAggregationOperator
 
update(Double, Double, boolean) - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleSumOperator
 
update(Integer, Integer, boolean) - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerSumOperator
 
update(Long, Long, boolean) - Method in class tools.refinery.interpreter.matchers.aggregators.LongSumOperator
 
update(SortedMap<T, Integer>, T, boolean) - Method in class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator
 
update(AverageAccumulator<Double>, Double, boolean) - Method in class tools.refinery.interpreter.matchers.aggregators.DoubleAverageOperator
 
update(AverageAccumulator<Integer>, Integer, boolean) - Method in class tools.refinery.interpreter.matchers.aggregators.IntegerAverageOperator
 
update(AverageAccumulator<Long>, Long, boolean) - Method in class tools.refinery.interpreter.matchers.aggregators.LongAverageOperator
 
update(IInputKey, Tuple, boolean) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContextListener
The given tuple was inserted into or removed from the input relation indicated by the given key.
update(Tuple, boolean) - Method in interface tools.refinery.interpreter.matchers.backend.IUpdateable
This callback method must be free of exceptions, even RuntimeExceptions (though not Errors).
updateTimeline(Tuple, Diff<Timestamp>) - Method in class tools.refinery.interpreter.matchers.util.TimelyMemory
Updates and garbage collects the timeline of the given tuple based on the given timeline diff.
updateTuple(IModifiableTuple) - Method in class tools.refinery.interpreter.matchers.tuple.VolatileModifiableMaskedTuple
 
updateTuple(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.VolatileMaskedTuple
 
updateTuple(ITuple) - Method in class tools.refinery.interpreter.matchers.tuple.VolatileModifiableMaskedTuple
 

V

VALUE - Enum constant in enum class tools.refinery.interpreter.matchers.util.IMultiLookup.ChangeGranularity
First occurrence of given key-value pair inserted, or last occurrence of the pair deleted, while key still has values associated.
valueOf(String) - Static method in enum class tools.refinery.interpreter.api.InterpreterModelUpdateListener.ChangeLevel
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator.Extreme
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint.BackendRequirement
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.context.IndexingService
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.psystem.basicenumerables.Connectivity
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.psystem.queries.PParameterDirection
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.psystem.queries.PQuery.PQueryStatus
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.psystem.queries.PVisibility
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.psystem.rewriters.ConstraintRemovalReason
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.util.Accuracy
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.util.CollectionsFactory.MemoryType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.util.Direction
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.util.IMultiLookup.ChangeGranularity
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.matchers.util.TimelyMemory.SignChange
Returns the enum constant of this class with the specified name.
values() - Static method in enum class tools.refinery.interpreter.api.InterpreterModelUpdateListener.ChangeLevel
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.aggregators.ExtremumOperator.Extreme
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.backend.QueryEvaluationHint.BackendRequirement
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.context.IndexingService
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.psystem.basicenumerables.Connectivity
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.psystem.queries.PParameterDirection
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.psystem.queries.PQuery.PQueryStatus
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.psystem.queries.PVisibility
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.psystem.rewriters.ConstraintRemovalReason
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.util.Accuracy
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.util.CollectionsFactory.MemoryType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.util.Direction
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class tools.refinery.interpreter.matchers.util.IMultiLookup.ChangeGranularity
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Method in class tools.refinery.interpreter.matchers.util.MemoryViewBackedMapView
 
values() - Static method in enum class tools.refinery.interpreter.matchers.util.TimelyMemory.SignChange
Returns an array containing the constants of this enum class, in the order they are declared.
VariableDeferredPConstraint - Class in tools.refinery.interpreter.matchers.psystem
A kind of deferred constraint that can only be checked when a set of deferring variables are all present in a plan.
VariableDeferredPConstraint(PBody, Set<PVariable>) - Constructor for class tools.refinery.interpreter.matchers.psystem.VariableDeferredPConstraint
 
variableMapping - Variable in class tools.refinery.interpreter.matchers.psystem.rewriters.PBodyCopier
Mapping between the original and the copied variables
variablesTuple - Variable in class tools.refinery.interpreter.matchers.psystem.EnumerablePConstraint
 
VIRTUAL_VARIABLE_PREFIX - Static variable in class tools.refinery.interpreter.matchers.psystem.PBody
 
visibility - Variable in class tools.refinery.interpreter.matchers.psystem.queries.BasePQuery
 
VolatileMaskedTuple - Class in tools.refinery.interpreter.matchers.tuple
This class provides a volatile tuple view with a given mask of a given tuple instance.
VolatileMaskedTuple(ITuple, TupleMask) - Constructor for class tools.refinery.interpreter.matchers.tuple.VolatileMaskedTuple
 
VolatileMaskedTuple(TupleMask) - Constructor for class tools.refinery.interpreter.matchers.tuple.VolatileMaskedTuple
 
VolatileModifiableMaskedTuple - Class in tools.refinery.interpreter.matchers.tuple
A masked tuple implementation that allows modifying the backing tuple.
VolatileModifiableMaskedTuple(IModifiableTuple, TupleMask) - Constructor for class tools.refinery.interpreter.matchers.tuple.VolatileModifiableMaskedTuple
 
VolatileModifiableMaskedTuple(TupleMask) - Constructor for class tools.refinery.interpreter.matchers.tuple.VolatileModifiableMaskedTuple
 
VolatileTuple - Class in tools.refinery.interpreter.matchers.tuple
Mutable tuple without explicit modification commands.
VolatileTuple() - Constructor for class tools.refinery.interpreter.matchers.tuple.VolatileTuple
 

W

WARNING - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.queries.PQuery.PQueryStatus
The query definition was initialized, but some issues were present
WEAK - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.basicenumerables.Connectivity
 
WEAK_INEQUALITY_SELF_LOOP - Enum constant in enum class tools.refinery.interpreter.matchers.psystem.rewriters.ConstraintRemovalReason
 
wideFlatTupleOf(Object...) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a flat tuple consisting of the given elements.
wideLeftInheritanceTupleOf(Tuple, Object...) - Static method in class tools.refinery.interpreter.matchers.tuple.Tuples
Creates a left inheritance tuple consisting of the given local elements.
wipe() - Method in class tools.refinery.interpreter.api.AdvancedInterpreterEngine
Discards any pattern matcher caches and forgets known patterns.
wipe() - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
withDefaultBackend(IQueryBackendFactory) - Method in class tools.refinery.interpreter.api.InterpreterEngineOptions.Builder
Note that this backend factory overrides the factory defined by the hint added by InterpreterEngineOptions.Builder.withDefaultHint(QueryEvaluationHint).
withDefaultCachingBackend(IQueryBackendFactory) - Method in class tools.refinery.interpreter.api.InterpreterEngineOptions.Builder
 
withDefaultHint(QueryEvaluationHint) - Method in class tools.refinery.interpreter.api.InterpreterEngineOptions.Builder
Note that the backend factory in the hint is overridden by a factory added with InterpreterEngineOptions.Builder.withDefaultBackend(IQueryBackendFactory).
withDefaultSearchBackend(IQueryBackendFactory) - Method in class tools.refinery.interpreter.api.InterpreterEngineOptions.Builder
 
withFlushingChanges(Supplier<T>) - Method in class tools.refinery.interpreter.api.InterpreterEngine
 
withFlushingChanges(Supplier<T>) - Method in class tools.refinery.interpreter.internal.apiimpl.InterpreterEngineImpl
 
wrapElement(Object) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Wraps the external element into the internal representation that is to be used by the query backend
wrappedKey - Variable in class tools.refinery.interpreter.matchers.context.common.BaseInputKeyWrapper
 
wrappedPQuery - Variable in class tools.refinery.interpreter.api.impl.BaseQuerySpecification
 
wrapTuple(Tuple) - Method in interface tools.refinery.interpreter.matchers.context.IQueryRuntimeContext
Unwraps the tuple of elements into the internal representation that is to be used by the query backend

Y

yieldSingleton(Value) - Method in interface tools.refinery.interpreter.matchers.util.IMultiLookupAbstract
 
A B C D E F G H I J K L M N O P Q R S T U V W Y 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form