Index

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

A

a - Variable in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
AbstractColumnAggregatorNode<Domain,Accumulator,AggregateResult> - Class in tools.refinery.interpreter.rete.aggregation
Groups incoming tuples by the given mask, and aggregates values at a specific index in each group.
AbstractColumnAggregatorNode(ReteContainer, IMultisetAggregationOperator<Domain, Accumulator, AggregateResult>, TupleMask, int) - Constructor for class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
Creates a new column aggregator node.
AbstractColumnAggregatorNode(ReteContainer, IMultisetAggregationOperator<Domain, Accumulator, AggregateResult>, TupleMask, TupleMask) - Constructor for class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
Creates a new column aggregator node.
AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer - Class in tools.refinery.interpreter.rete.aggregation
A special non-iterable index that checks a suspected aggregate value for a given signature.
AbstractColumnAggregatorNode.AggregatorOuterIndexer - Class in tools.refinery.interpreter.rete.aggregation
A special non-iterable index that retrieves the aggregated, packed result (signature+aggregate) for the original signature.
AbstractColumnAggregatorNode.NetworkStructureChangeSensitiveLogic - Class in tools.refinery.interpreter.rete.aggregation
 
AbstractEvaluatorNode - Class in tools.refinery.interpreter.rete.eval
 
AbstractEvaluatorNode(ReteContainer, EvaluatorCore) - Constructor for class tools.refinery.interpreter.rete.eval.AbstractEvaluatorNode
 
AbstractUniquenessEnforcerNode - Class in tools.refinery.interpreter.rete.single
Ensures that no identical copies get to the output.
AbstractUniquenessEnforcerNode(ReteContainer, int) - Constructor for class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
AbstractUpdateSplittingMailbox<IndexerType,ReceiverType> - Class in tools.refinery.interpreter.rete.network.mailbox.timeless
An abstract mailbox implementation that is capable of splitting update messages based on some form of monotonicity (anti-monotone and monotone).
AbstractUpdateSplittingMailbox(ReceiverType, ReteContainer, MessageIndexerFactory<IndexerType>) - Constructor for class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
acceptPropagatedTraceInfo(TraceInfo) - Method in class tools.refinery.interpreter.rete.network.BaseNode
 
acceptPropagatedTraceInfo(TraceInfo) - Method in interface tools.refinery.interpreter.rete.network.Node
accepts traceability info propagated to this node
acceptPropagatedTraceInfo(TraceInfo) - Method in class tools.refinery.interpreter.rete.single.DefaultProductionNode
 
acceptPropagatedTraceInfo(TraceInfo) - Method in class tools.refinery.interpreter.rete.single.TimelyProductionNode
 
accessMatcher(PQuery) - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
Accesses the patternmatcher for a given pattern, constructs one if a matcher is not available yet.
accessProductionNode(PQuery) - Method in class tools.refinery.interpreter.rete.boundary.ReteBoundary
accesses the production node for specified pattern; builds pattern matcher if it doesn't exist yet
accessProductionTrace(PQuery) - Method in class tools.refinery.interpreter.rete.boundary.ReteBoundary
accesses the production node for specified pattern; builds pattern matcher if it doesn't exist yet
accessProjectionIndexer(RecipeTraceInfo, TupleMask) - Method in class tools.refinery.interpreter.rete.network.NodeProvisioner
 
accessProjectionIndexerOnetime(RecipeTraceInfo, TupleMask) - Method in class tools.refinery.interpreter.rete.network.NodeProvisioner
 
accumulator - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode.CumulativeAggregate
 
accumulator - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode.CumulativeAggregate
 
activateUnenqueued(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
activeNode - Variable in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer
 
ActiveNodeConflictTrace - Class in tools.refinery.interpreter.rete.traceability
 
ActiveNodeConflictTrace(ReteNodeRecipe, RecipeTraceInfo, RecipeTraceInfo) - Constructor for class tools.refinery.interpreter.rete.traceability.ActiveNodeConflictTrace
 
AdaptableMailbox - Interface in tools.refinery.interpreter.rete.network.mailbox
An adaptable mailbox can be wrapped by another mailbox to act in behalf of that.
adapter - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
adapter - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.UpdateSplittingMailbox
 
add(WholeKeyType) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
addAll(Collection<? extends WholeKeyType>) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
addDisconnectable(Disconnectable) - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
addFoldingState(Tuple, FoldingState, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
Registers the given folding state for the specified timestamp and tuple.
addRederivable(RederivableNode) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.RecursiveCommunicationGroup
 
Address<T> - Class in tools.refinery.interpreter.rete.remote
Remote identifier of a node of type T.
Address(T) - Constructor for class tools.refinery.interpreter.rete.remote.Address
Local-only constructor.
Address(ReteContainer, Long) - Constructor for class tools.refinery.interpreter.rete.remote.Address
General constructor.
addTarget(Address<? extends Receiver>) - Method in class tools.refinery.interpreter.rete.remote.RemoteReceiver
 
addTuple(V, V, int) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
Returns true if the tc relation did not contain previously such a tuple that is defined by (source,target), false otherwise (in this case count is incremented with the given count parameter).
addUpdateListener(IUpdateable, Object, boolean) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
aggregands - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode.CumulativeAggregate
 
aggregateAndPack(Tuple, Collection<Tuple>) - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
 
aggregateGroup(Tuple, Collection<Tuple>) - Method in class tools.refinery.interpreter.rete.aggregation.CountNode
 
aggregateGroup(Tuple, Collection<Tuple>) - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
Aggregates (reduces) a group of tuples.
aggregateGroupAfterUpdate(Tuple, Collection<Tuple>, Object, Direction, Tuple, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
Aggregates (reduces) a group of tuples, having access to the previous aggregated value (before the update) and the update definition.
aggregates - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
aggregateUpdate(Direction, Tuple, Tuple, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
 
AggregatorOuterIdentityIndexer(int) - Constructor for class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer
 
aggregatorOuterIdentityIndexers - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
aggregatorOuterIndexer - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
AggregatorOuterIndexer() - Constructor for class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIndexer
 
ALL - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.NodeSharingOption
 
AllZeroMap(Set<T>) - Constructor for class tools.refinery.interpreter.rete.network.communication.Timestamp.AllZeroMap
 
ANTI_MONOTONE - Enum constant in enum class tools.refinery.interpreter.rete.network.communication.PhasedSelector
Deletes
antiMonotoneBuffer - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
antiMonotoneQueue - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
appendChild(Receiver) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
appendChild(Receiver) - Method in class tools.refinery.interpreter.rete.network.StandardNode
 
appendChild(Receiver) - Method in interface tools.refinery.interpreter.rete.network.Supplier
appends a receiver that will continously receive insert and revoke updates from this supplier
appendChild(Receiver) - Method in class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
appendDiff(AggregateResult, Signed<Timestamp>, Map<AggregateResult, Diff<Timestamp>>) - Static method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
appendParent(Supplier) - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
appendParent(Supplier) - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
appendParent(Supplier) - Method in class tools.refinery.interpreter.rete.index.OnetimeIndexer
 
appendParent(Supplier) - Method in class tools.refinery.interpreter.rete.misc.SimpleReceiver
 
appendParent(Supplier) - Method in interface tools.refinery.interpreter.rete.network.Receiver
appends a parent that will continuously send insert and revoke updates to this supplier
appendParent(Supplier) - Method in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
appendParent(Supplier) - Method in class tools.refinery.interpreter.rete.single.DiscriminatorBucketNode
 
appendParent(Supplier) - Method in class tools.refinery.interpreter.rete.single.SingleInputNode
 
areInSameGroup(Node, Node) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
Returns true if the given two Nodes are in the same CommunicationGroup.
assignNewRepresentative(T, Set<T>) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
assignNode(Node) - Method in class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
 
assignNode(Node) - Method in interface tools.refinery.interpreter.rete.traceability.TraceInfo
 
assignTraceInfo(TraceInfo) - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
 
assignTraceInfo(TraceInfo) - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
assignTraceInfo(TraceInfo) - Method in class tools.refinery.interpreter.rete.index.StandardIndexer
 
assignTraceInfo(TraceInfo) - Method in class tools.refinery.interpreter.rete.misc.SimpleReceiver
 
assignTraceInfo(TraceInfo) - Method in class tools.refinery.interpreter.rete.network.BaseNode
 
assignTraceInfo(TraceInfo) - Method in interface tools.refinery.interpreter.rete.network.Node
assigns new traceability info to this node
assignTraceInfo(TraceInfo) - Method in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
assignTraceInfo(TraceInfo) - Method in class tools.refinery.interpreter.rete.single.SingleInputNode
 
asSupplier(Address<? extends Supplier>) - Method in class tools.refinery.interpreter.rete.network.NodeProvisioner
The powerful method for accessing any (supplier) Address as a local supplier.
attachAsFirstObserver(IGraphObserver<V>) - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
 
attachAsFirstObserver(IGraphObserver<V>) - Method in class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
attachAsFirstObserver(IGraphObserver<V>) - Method in interface tools.refinery.interpreter.rete.itc.igraph.IGraphDataSource
Attaches a new graph observer to this graph data source as the first one.
attachListener(IndexerListener) - Method in interface tools.refinery.interpreter.rete.index.Indexer
 
attachListener(IndexerListener) - Method in class tools.refinery.interpreter.rete.index.OnetimeIndexer
 
attachListener(IndexerListener) - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer
 
attachListener(IndexerListener) - Method in class tools.refinery.interpreter.rete.index.StandardIndexer
 
attachObserver(IGraphObserver<V>) - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
 
attachObserver(IGraphObserver<V>) - Method in class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
attachObserver(IGraphObserver<V>) - Method in interface tools.refinery.interpreter.rete.itc.igraph.IGraphDataSource
Attaches a new graph observer to this graph data source.
attachObserver(ITcObserver<V>) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
attachObserver(ITcObserver<V>) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
attachObserver(ITcObserver<V>) - Method in interface tools.refinery.interpreter.rete.itc.igraph.ITcDataSource
Attach a transitive closure relation observer.

B

b - Variable in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
backendContext - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
Bag - Class in tools.refinery.interpreter.rete.misc
 
Bag(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.misc.Bag
 
BaseNode - Class in tools.refinery.interpreter.rete.network
Base implementation for a Rete node.
BaseNode(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.network.BaseNode
 
BasicLinearLayout - Class in tools.refinery.interpreter.rete.construction.basiclinear
Basic layout that builds a linear RETE net based on a heuristic ordering of constraints.
BasicLinearLayout(IQueryBackendContext) - Constructor for class tools.refinery.interpreter.rete.construction.basiclinear.BasicLinearLayout
 
batchUpdate(Collection<Map.Entry<Tuple, Integer>>, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
batchUpdate(Collection<Map.Entry<Tuple, Integer>>, Timestamp) - Method in class tools.refinery.interpreter.rete.eval.RelationEvaluatorNode.BatchingReceiver
 
batchUpdate(Collection<Map.Entry<Tuple, Integer>>, Timestamp) - Method in interface tools.refinery.interpreter.rete.network.Receiver
Updates the receiver in batch style with a collection of updates.
BehaviorChangingMailbox - Class in tools.refinery.interpreter.rete.network.mailbox.timeless
This mailbox changes its behavior based on the position of its Receiver in the network topology.
BehaviorChangingMailbox(Receiver, ReteContainer) - Constructor for class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
BFS<V> - Class in tools.refinery.interpreter.rete.itc.alg.misc.bfs
 
BOTH - Enum constant in enum class tools.refinery.interpreter.rete.index.DualInputNode.Side
 
boundary - Variable in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
buffer - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
builderMethod - Static variable in class tools.refinery.interpreter.rete.util.Options
 
buildMatchersCoalesced(Collection<PQuery>) - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
Constructs RETE pattern matchers for a collection of patterns, if they are not available yet.

C

cachedResult - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode.CumulativeAggregate
 
cacheOutputOfEvaluatorsByDefault - Static variable in class tools.refinery.interpreter.rete.util.ReteHintOptions
 
calculateRequiredCapability(PQuery, QueryEvaluationHint) - Method in class tools.refinery.interpreter.rete.matcher.ReteBackendFactory
 
calibrate(Tuple, Tuple) - Method in class tools.refinery.interpreter.rete.index.DualInputNode
Simulates the behavior of the node for calibration purposes only.
calibrate(Tuple, Tuple) - Method in class tools.refinery.interpreter.rete.index.ExistenceNode
 
calibrate(Tuple, Tuple) - Method in class tools.refinery.interpreter.rete.index.JoinNode
 
CallbackNode - Class in tools.refinery.interpreter.rete.single
 
CallbackNode(ReteContainer, IUpdateable) - Constructor for class tools.refinery.interpreter.rete.single.CallbackNode
 
canBeSubstitute(IMatcherCapability) - Method in class tools.refinery.interpreter.rete.matcher.IncrementalMatcherCapability
 
check(Tuple) - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputStatelessFilterNode
 
check(Tuple) - Method in class tools.refinery.interpreter.rete.single.EqualityFilterNode
 
check(Tuple) - Method in class tools.refinery.interpreter.rete.single.FilterNode
Abstract filtering predicate.
check(Tuple) - Method in class tools.refinery.interpreter.rete.single.InequalityFilterNode
 
check(Tuple) - Method in class tools.refinery.interpreter.rete.single.ValueBinderFilterNode
 
checkAndTrimEqualVariables(SubPlan, PlanningTrace) - Static method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper
Makes sure that all variables in the tuple are different so that it can be used as CompiledSubPlan.
checkCancelled() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
childMailboxes - Variable in class tools.refinery.interpreter.rete.network.StandardNode
 
children - Variable in class tools.refinery.interpreter.rete.network.StandardNode
 
clear() - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
clear() - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
clear() - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
clear() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
clear() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
clear() - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
clear() - Method in class tools.refinery.interpreter.rete.eval.RelationEvaluatorNode
 
clear() - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
clear() - Method in class tools.refinery.interpreter.rete.misc.DeltaMonitor
 
clear() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
clear() - Method in class tools.refinery.interpreter.rete.network.indexer.DefaultMessageIndexer
 
clear() - Method in class tools.refinery.interpreter.rete.network.indexer.GroupBasedMessageIndexer
 
clear() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
clear() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
clear() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
clear() - Method in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
clear() - Method in class tools.refinery.interpreter.rete.single.RepresentativeElectionNode
 
clear() - Method in class tools.refinery.interpreter.rete.single.TransitiveClosureNode
 
clearables - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
clearAll() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Clears all memory contents in the network.
clock - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
cloneFor(SubPlan) - Method in class tools.refinery.interpreter.rete.traceability.PlanningTrace
Returns a new clone that reinterprets the same compiled form as the compiled form of a (potentially different) subPlan.
coincidence - Variable in class tools.refinery.interpreter.rete.index.DualInputNode
true if the primary and secondary slots coincide
CollectionHelper - Class in tools.refinery.interpreter.rete.itc.alg.util
 
collectNodesAlongPath(V, V, IGraphDataSource<V>) - Static method in class tools.refinery.interpreter.rete.itc.alg.misc.bfs.BFS
Performs a breadth first search on the given graph and collects all the nodes along the path from source to target if such path exists.
ColumnAggregatorNode<Domain,Accumulator,AggregateResult> - Class in tools.refinery.interpreter.rete.aggregation
Timeless implementation of the column aggregator node.
ColumnAggregatorNode(ReteContainer, IMultisetAggregationOperator<Domain, Accumulator, AggregateResult>, boolean, TupleMask, TupleMask, IPosetComparator) - Constructor for class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
Creates a new column aggregator node.
ColumnAggregatorNode(ReteContainer, IMultisetAggregationOperator<Domain, Accumulator, AggregateResult>, TupleMask, int) - Constructor for class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
Creates a new column aggregator node.
columnMask - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
communicationGroup - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
CommunicationGroup - Class in tools.refinery.interpreter.rete.network.communication
A communication group represents a set of nodes in the communication graph that form a strongly connected component.
CommunicationGroup(CommunicationTracker, Node, int) - Constructor for class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
CommunicationTracker - Class in tools.refinery.interpreter.rete.network.communication
An instance of this class is associated with every ReteContainer.
CommunicationTracker(Logger) - Constructor for class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
comparator - Variable in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.PosetTriplet
 
compare() - Method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
compare(Iterable<? extends T>, Iterable<? extends T>) - Method in class tools.refinery.interpreter.rete.util.LexicographicComparator
 
compare(PConstraint, PConstraint) - Method in class tools.refinery.interpreter.rete.construction.basiclinear.OrderingHeuristics
 
compare(JoinCandidate, JoinCandidate) - Method in class tools.refinery.interpreter.rete.construction.quasitree.JoinOrderingHeuristics
 
compare(Node, Node) - Method in class tools.refinery.interpreter.rete.network.communication.NodeComparator
 
compareTo(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
compareTo(Timestamp) - Method in class tools.refinery.interpreter.rete.network.communication.Timestamp
 
CompiledQuery - Class in tools.refinery.interpreter.rete.traceability
Indicates that recipe expresses the finished match set of a query.
CompiledQuery(ReteNodeRecipe, Map<PBody, ? extends RecipeTraceInfo>, PQuery) - Constructor for class tools.refinery.interpreter.rete.traceability.CompiledQuery
 
CompiledSubPlan - Class in tools.refinery.interpreter.rete.traceability
A trace marker associating a Rete recipe with a query SubPlan.
CompiledSubPlan(SubPlan, List<PVariable>, ReteNodeRecipe, Collection<? extends RecipeTraceInfo>) - Constructor for class tools.refinery.interpreter.rete.traceability.CompiledSubPlan
 
CompiledSubPlan(SubPlan, List<PVariable>, ReteNodeRecipe, RecipeTraceInfo...) - Constructor for class tools.refinery.interpreter.rete.traceability.CompiledSubPlan
 
compiler - Variable in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
CompilerHelper - Class in tools.refinery.interpreter.rete.construction.plancompiler
 
CompilerHelper.JoinHelper - Class in tools.refinery.interpreter.rete.construction.plancompiler
Calculated index mappings for a join, based on the common variables of the two parent subplans.
CompilerHelper.PosetTriplet - Class in tools.refinery.interpreter.rete.construction.plancompiler
 
complementerSecondaryMask - Variable in class tools.refinery.interpreter.rete.index.DualInputNode
Optional complementer mask
components - Variable in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
compute(IGraphDataSource<T>) - Static method in class tools.refinery.interpreter.rete.itc.alg.misc.topsort.TopologicalSorting
Returns a topological ordering for the given graph data source.
computePosetInfo(Iterable<Set<IInputKey>>, IQueryMetaContext) - Static method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper
 
computePosetInfo(List<PVariable>, PBody, IQueryMetaContext) - Static method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper
 
computePosetInfo(List<PParameter>, IQueryMetaContext) - Static method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper
 
computeSCC(IGraphDataSource<V>) - Static method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCC
Computes the SCCs for the given graph and returns them as a multiset.
configuration - Variable in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationTracker
 
connect(Receiver, boolean) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
Connects a new external receiver that will receive update notifications from now on.
connect(Receiver, Object, boolean) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
Connects a new external receiver that will receive update notifications from now on.
connect(Supplier, Receiver) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Connects a receiver to a supplier
connectAndSynchronize(Supplier, Receiver) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Connects a receiver to a remote supplier, and synchronizes it to the current contents of the supplier
connected - Variable in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
connectInput(InputRecipe, Node) - Method in class tools.refinery.interpreter.rete.boundary.InputConnector
Connects a given input enumerator node to the external input source.
connectInputFilter(InputFilterRecipe, Node) - Method in class tools.refinery.interpreter.rete.boundary.InputConnector
Connects a given input filter node to the external input source.
connectionFactory - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
connectRemoteNodes(Address<? extends Supplier>, Address<? extends Receiver>, boolean) - Method in class tools.refinery.interpreter.rete.network.Network
Establishes connection between a supplier and a receiver node, regardless which container they are in.
connectRemoteNodes(Address<? extends Supplier>, Address<? extends Receiver>, boolean) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Establishes connection between a supplier and a receiver node, regardless which container they are in.
connectRemoteSupplier(Address<? extends Supplier>, Receiver, boolean) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Establishes connection between a remote supplier and a local receiver node.
connectThroughContext(ReteEngine, IInputKey) - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputStatelessFilterNode
 
connectThroughContext(ReteEngine, IInputKey, Tuple) - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
connectToIndexers(IterableIndexer, Indexer) - Method in class tools.refinery.interpreter.rete.index.DualInputNode
Should be called only once, when node is initialized.
connectToParents(List<Supplier>) - Method in class tools.refinery.interpreter.rete.eval.RelationEvaluatorNode
 
consider(int) - Method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
constant - Variable in class tools.refinery.interpreter.rete.misc.ConstantNode
 
ConstantNode - Class in tools.refinery.interpreter.rete.misc
Node that always contains a single constant Tuple
ConstantNode(ReteContainer, Tuple) - Constructor for class tools.refinery.interpreter.rete.misc.ConstantNode
 
CONSTRAINT_COMPARATOR - Static variable in class tools.refinery.interpreter.rete.construction.quasitree.TieBreaker
 
CONSTRAINT_LIST_COMPARATOR - Static variable in class tools.refinery.interpreter.rete.construction.quasitree.TieBreaker
 
constructIndex(TupleMask, TraceInfo...) - Method in class tools.refinery.interpreter.rete.network.StandardNode
 
constructIndex(TupleMask, TraceInfo...) - Method in interface tools.refinery.interpreter.rete.network.Supplier
Instantiates (or reuses, depending on implementation) an index according to the given mask.
constructIndex(TupleMask, TraceInfo...) - Method in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
constructionWrapper(Callable<T>) - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
constructPath(V, V, Set<V>, IGraphDataSource<V>) - Static method in class tools.refinery.interpreter.rete.itc.alg.misc.GraphHelper
Constructs a path between source and target in the given graph.
consumerThread - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
container - Variable in class tools.refinery.interpreter.rete.network.delayed.DelayedCommand
 
container - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
container - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
container - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
container - Variable in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
containers - Variable in class tools.refinery.interpreter.rete.network.Network
 
contains(Object) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
contains(Tuple) - Method in class tools.refinery.interpreter.rete.index.IdentityIndexer
 
containsAll(Collection<?>) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
containsKey(Object) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
containsTuple(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
Returns true if a (source, target) node is present in the transitive closure relation, false otherwise.
containsValue(Object) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
contents - Variable in class tools.refinery.interpreter.rete.misc.Bag
 
context - Variable in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
convertVariablesTuple(EnumerablePConstraint) - Static method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper
Extracts the variable list representation of the variables tuple.
convertVariablesTuple(Tuple) - Static method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper
Extracts the variable list representation of the variables tuple.
core - Variable in class tools.refinery.interpreter.rete.eval.AbstractEvaluatorNode
 
coreMask - Variable in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.PosetTriplet
 
coreMask - Variable in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
OPTIONAL ELEMENT - ONLY PRESENT IF MONOTONICITY INFO WAS AVAILABLE
count(Object[], boolean[]) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
Counts the number of occurrences of the pattern that match inputMapping on positions where fixed is true.
count(TupleMask, ITuple) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
Counts the number of occurrences of the pattern that match inputMapping on positions where fixed is true.
CountingAlg<V> - Class in tools.refinery.interpreter.rete.itc.alg.counting
This class is the optimized implementation of the Counting algorithm.
CountingAlg(IGraphDataSource<V>) - Constructor for class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
Constructs a new Counting algorithm and initializes the transitive closure relation with the given graph data source.
CountingListener<V> - Class in tools.refinery.interpreter.rete.itc.alg.incscc
 
CountingListener(IncSCCAlg<V>) - Constructor for class tools.refinery.interpreter.rete.itc.alg.incscc.CountingListener
 
CountingTcRelation<V> - Class in tools.refinery.interpreter.rete.itc.alg.counting
Transitive closure relation implementation for the Counting algorithm.
CountingTcRelation(boolean) - Constructor for class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
countMatches(Object[]) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
countMatches(TupleMask, ITuple) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
CountNode - Class in tools.refinery.interpreter.rete.aggregation
An aggregation node that simply counts the number of tuples conforming to the signature.
CountNode(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.aggregation.CountNode
 
create() - Method in interface tools.refinery.interpreter.rete.network.mailbox.MessageIndexerFactory
 
create(IQueryBackendContext) - Method in class tools.refinery.interpreter.rete.matcher.DRedReteBackendFactory
 
create(IQueryBackendContext) - Method in class tools.refinery.interpreter.rete.matcher.ReteBackendFactory
 
create(IQueryBackendContext) - Method in class tools.refinery.interpreter.rete.matcher.TimelyReteBackendFactory
 
create(IQueryBackendContext, boolean, TimelyConfiguration) - Method in class tools.refinery.interpreter.rete.matcher.ReteBackendFactory
 
create(Graph<T>) - Method in interface tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm.Factory
 
createAndStoreGroup(Node, int) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
createFrom(IBiDirectionalGraphDataSource<V>) - Static method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
createGroup(Node, int) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
createGroup(Node, int) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.TimelessCommunicationTracker
 
createGroup(Node, int) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationTracker
 
createLogic() - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer
 
createLogic() - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIndexer
 
createLogic() - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
createLogic() - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
createLogic() - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
createTimelessLogic() - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
createTimelessLogic() - Method in class tools.refinery.interpreter.rete.index.ExistenceNode
 
createTimelessLogic() - Method in class tools.refinery.interpreter.rete.index.JoinNode
 
createTimelyLogic() - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
createTimelyLogic() - Method in class tools.refinery.interpreter.rete.index.ExistenceNode
 
createTimelyLogic() - Method in class tools.refinery.interpreter.rete.index.JoinNode
 
CumulativeAggregate() - Constructor for class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode.CumulativeAggregate
 
CumulativeAggregate() - Constructor for class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode.CumulativeAggregate
 
currentGroup - Variable in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
currentGroup - Variable in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 

D

deactivate(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
DEFAULT - Enum constant in enum class tools.refinery.interpreter.rete.network.communication.PhasedSelector
No special distinguishing feature
DefaultDeltaMonitor - Class in tools.refinery.interpreter.rete.misc
Default configuration for DeltaMonitor.
DefaultDeltaMonitor(Network) - Constructor for class tools.refinery.interpreter.rete.misc.DefaultDeltaMonitor
 
DefaultDeltaMonitor(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.misc.DefaultDeltaMonitor
 
DefaultIndexerListener - Class in tools.refinery.interpreter.rete.index
 
DefaultIndexerListener(Node) - Constructor for class tools.refinery.interpreter.rete.index.DefaultIndexerListener
 
DefaultMailbox - Class in tools.refinery.interpreter.rete.network.mailbox.timeless
Default mailbox implementation.
DefaultMailbox(Receiver, ReteContainer) - Constructor for class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
DefaultMessageIndexer - Class in tools.refinery.interpreter.rete.network.indexer
 
DefaultMessageIndexer() - Constructor for class tools.refinery.interpreter.rete.network.indexer.DefaultMessageIndexer
 
DefaultProductionNode - Class in tools.refinery.interpreter.rete.single
Default implementation of the Production node, based on UniquenessEnforcerNode
DefaultProductionNode(ReteContainer, Map<String, Integer>, boolean) - Constructor for class tools.refinery.interpreter.rete.single.DefaultProductionNode
 
DefaultProductionNode(ReteContainer, Map<String, Integer>, boolean, TupleMask, TupleMask, IPosetComparator) - Constructor for class tools.refinery.interpreter.rete.single.DefaultProductionNode
 
DelayedCommand - Class in tools.refinery.interpreter.rete.network.delayed
Instances of this class are responsible for initializing a Receiver with the contents of a Supplier.
DelayedCommand(Supplier, Receiver, Direction, ReteContainer) - Constructor for class tools.refinery.interpreter.rete.network.delayed.DelayedCommand
 
delayedCommandBuffer - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
delayedCommandQueue - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
DelayedConnectCommand - Class in tools.refinery.interpreter.rete.network.delayed
 
DelayedConnectCommand(Supplier, Receiver, ReteContainer) - Constructor for class tools.refinery.interpreter.rete.network.delayed.DelayedConnectCommand
 
DelayedDisconnectCommand - Class in tools.refinery.interpreter.rete.network.delayed
 
DelayedDisconnectCommand(Supplier, Receiver, ReteContainer, boolean) - Constructor for class tools.refinery.interpreter.rete.network.delayed.DelayedDisconnectCommand
 
delete(Tuple) - Method in class tools.refinery.interpreter.rete.network.indexer.DefaultMessageIndexer
 
delete(Tuple) - Method in class tools.refinery.interpreter.rete.network.indexer.GroupBasedMessageIndexer
 
delete(Tuple) - Method in interface tools.refinery.interpreter.rete.network.indexer.MessageIndexer
 
deleteAndRederiveEvaluation - Variable in class tools.refinery.interpreter.rete.construction.plancompiler.ReteRecipeCompiler
 
deleteAndRederiveEvaluation - Variable in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
deleteEdge(V, V) - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
Deprecated.
use explicitly Graph.deleteEdgeThatExists(Object, Object) or Graph.deleteEdgeIfExists(Object, Object) instead. To preserve backwards compatibility, this method delegates to the latter.
deleteEdgeIfExists(V, V) - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
No-op if trying to delete edge that does not exist
deleteEdgeThatExists(V, V) - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
 
deleteNode(V) - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
Deletes the given node AND all of the edges going in and out from the node.
deleteRederiveEvaluation - Variable in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
deleteRederiveEvaluation - Variable in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
deleteRederiveEvaluation - Static variable in class tools.refinery.interpreter.rete.util.ReteHintOptions
Deprecated.
Use DRedReteBackendFactory instead of setting this option to true.
deleteTupleEnd(V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
deliverAll(MessageSelector) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
deliverAll(MessageSelector) - Method in interface tools.refinery.interpreter.rete.network.mailbox.Mailbox
Delivers all messages according to the given selector from this mailbox.
deliverAll(MessageSelector) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
deliverAll(MessageSelector) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
deliverAll(MessageSelector) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.PosetAwareMailbox
 
deliverAll(MessageSelector) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.UpdateSplittingMailbox
 
deliverAll(MessageSelector) - Method in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
delivering - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
deliveringAntiMonotone - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
deliveringMonotone - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
deliverMessages() - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
deliverMessages() - Method in class tools.refinery.interpreter.rete.network.communication.timeless.RecursiveCommunicationGroup
 
deliverMessages() - Method in class tools.refinery.interpreter.rete.network.communication.timeless.SingletonCommunicationGroup
 
deliverMessages() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationGroup
 
deliverMessagesSingleThreaded() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Sends out all pending messages to their receivers.
delta - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode.FoldingState
 
delta - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode.FoldingState
 
DeltaMonitor<MatchType> - Class in tools.refinery.interpreter.rete.misc
A monitoring object that connects to the rete network as a receiver to reflect changes since an arbitrary state acknowledged by the client.
DeltaMonitor(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.misc.DeltaMonitor
 
dependencyGraph - Variable in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
The dependency graph of the communications in the RETE network
detachListener(IndexerListener) - Method in interface tools.refinery.interpreter.rete.index.Indexer
 
detachListener(IndexerListener) - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer
 
detachListener(IndexerListener) - Method in class tools.refinery.interpreter.rete.index.StandardIndexer
 
detachObserver(IGraphObserver<V>) - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
 
detachObserver(IGraphObserver<V>) - Method in class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
detachObserver(IGraphObserver<V>) - Method in interface tools.refinery.interpreter.rete.itc.igraph.IGraphDataSource
Detaches an already registered graph observer from this graph data source.
detachObserver(ITcObserver<V>) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
detachObserver(ITcObserver<V>) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
detachObserver(ITcObserver<V>) - Method in interface tools.refinery.interpreter.rete.itc.igraph.ITcDataSource
Detach a transitive closure relation observer.
DFSPathFinder<V> - Class in tools.refinery.interpreter.rete.itc.alg.misc
A depth-first search implementation of the IGraphPathFinder.
DFSPathFinder(IGraphDataSource<V>, ITcDataSource<V>) - Constructor for class tools.refinery.interpreter.rete.itc.alg.misc.DFSPathFinder
 
difference(Set<V>, Set<V>) - Static method in class tools.refinery.interpreter.rete.itc.alg.util.CollectionHelper
Returns the difference of two sets (S1\S2).
direction - Variable in class tools.refinery.interpreter.rete.network.delayed.DelayedCommand
 
disconnect() - Method in interface tools.refinery.interpreter.rete.boundary.Disconnectable
Disconnects this rete engine component from the underlying model.
disconnect() - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
disconnect() - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputStatelessFilterNode
 
disconnect(Receiver) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
Disconnects a child node.
disconnect(Supplier, Receiver) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Disconnects a receiver from a supplier
Disconnectable - Interface in tools.refinery.interpreter.rete.boundary
For objects that connect a RETE implementation to the underlying model.
disconnectables - Variable in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
disconnectAndDesynchronize(Supplier, Receiver) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Disconnects a receiver from a supplier
disconnectByTag(Object) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
Disconnects the child node that was connected by specifying the given tag.
disconnectFromNetwork() - Method in class tools.refinery.interpreter.rete.misc.SimpleReceiver
Disconnects this node from the network.
disconnectRemoteNodes(Address<? extends Supplier>, Address<? extends Receiver>, boolean) - Method in class tools.refinery.interpreter.rete.network.Network
Severs connection between a supplier and a receiver node, regardless which container they are in.
disconnectRemoteNodes(Address<? extends Supplier>, Address<? extends Receiver>, boolean) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Severs connection between a supplier and a receiver node, regardless which container they are in.
disconnectRemoteSupplier(Address<? extends Supplier>, Receiver, boolean) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Severs connection between a remote supplier and a local receiver node.
DiscriminatorBucketNode - Class in tools.refinery.interpreter.rete.single
A bucket holds a filtered set of tuples of its parent DiscriminatorDispatcherNode.
DiscriminatorBucketNode(ReteContainer, Object) - Constructor for class tools.refinery.interpreter.rete.single.DiscriminatorBucketNode
 
DiscriminatorDispatcherNode - Class in tools.refinery.interpreter.rete.single
Node that sends tuples off to different buckets (attached as children of type DiscriminatorBucketNode), based on the value of a given column.
DiscriminatorDispatcherNode(ReteContainer, int) - Constructor for class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
dispose() - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
dispose() - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
dispose() - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
dispose() - Method in interface tools.refinery.interpreter.rete.itc.igraph.ITcDataSource
Call this method to properly dispose the data structures of a transitive closure algorithm.
dispose() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
doCompare() - Method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
doFoldingStep(Tuple, FoldingState, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
doFoldingStep(Tuple, FaithfulParallelTimelyColumnAggregatorNode.FoldingState<Domain>, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode
 
doFoldingStep(Tuple, FaithfulSequentialTimelyColumnAggregatorNode.FoldingState<Domain, AggregateResult>, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode
 
dontCare() - Static method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
DotGenerator - Class in tools.refinery.interpreter.rete.itc.graphimpl
This class contains utility methods to generate dot representations for Graph instances.
DRedReteBackendFactory - Class in tools.refinery.interpreter.rete.matcher
A ReteBackendFactory implementation that creates ReteEngines that use delete and re-derive evaluation.
DRedReteBackendFactory() - Constructor for class tools.refinery.interpreter.rete.matcher.DRedReteBackendFactory
 
DualInputNode - Class in tools.refinery.interpreter.rete.index
Abstract superclass for nodes with two inputs that are matched against each other.
DualInputNode(ReteContainer, TupleMask) - Constructor for class tools.refinery.interpreter.rete.index.DualInputNode
 
DualInputNode.NetworkStructureChangeSensitiveLogic - Class in tools.refinery.interpreter.rete.index
 
DualInputNode.Side - Enum Class in tools.refinery.interpreter.rete.index
 

E

EAGER - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.InjectivityStrategy
 
Edge<V> - Class in tools.refinery.interpreter.rete.itc.alg.misc
 
Edge(V, V) - Constructor for class tools.refinery.interpreter.rete.itc.alg.misc.Edge
 
EDGE_LABEL_FUNCTION - Static variable in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationTracker
This static field is used for debug purposes in the DotGenerator.
edgeDeleted(T, T) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.StronglyConnectedComponentAlgorithm
 
edgeDeleted(T, T) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.WeaklyConnectedComponentAlgorithm
 
edgeDeleted(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
edgeDeleted(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
edgeDeleted(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.PKAlg
 
edgeDeleted(V, V) - Method in class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
edgeDeleted(V, V) - Method in interface tools.refinery.interpreter.rete.itc.igraph.IGraphObserver
Used to notify when an edge is deleted from the graph.
edgeInserted(T, T) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.StronglyConnectedComponentAlgorithm
 
edgeInserted(T, T) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.WeaklyConnectedComponentAlgorithm
 
edgeInserted(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
edgeInserted(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
edgeInserted(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.PKAlg
 
edgeInserted(V, V) - Method in class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
edgeInserted(V, V) - Method in interface tools.refinery.interpreter.rete.itc.igraph.IGraphObserver
Used to notify when an edge is inserted into the graph.
employTrivialIndexers - Static variable in class tools.refinery.interpreter.rete.util.Options
 
emptySet - Static variable in class tools.refinery.interpreter.rete.index.NullIndexer
 
enableInheritance - Static variable in class tools.refinery.interpreter.rete.util.Options
 
engine - Variable in class tools.refinery.interpreter.rete.boundary.ReteBoundary
 
engine - Variable in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
entrySet() - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
entrySet() - Method in class tools.refinery.interpreter.rete.network.communication.Timestamp.AllZeroMap
 
EqualityFilterNode - Class in tools.refinery.interpreter.rete.single
 
EqualityFilterNode(ReteContainer, int[]) - Constructor for class tools.refinery.interpreter.rete.single.EqualityFilterNode
 
equals(Object) - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer.ListenerSubscription
 
equals(Object) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
equals(Object) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.Tuple
 
equals(Object) - Method in class tools.refinery.interpreter.rete.matcher.DRedReteBackendFactory
 
equals(Object) - Method in class tools.refinery.interpreter.rete.matcher.ReteBackendFactory
 
equals(Object) - Method in class tools.refinery.interpreter.rete.matcher.TimelyReteBackendFactory
 
equals(Object) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
equals(Object) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyIndexerListenerProxy
 
equals(Object) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
equals(Object) - Method in class tools.refinery.interpreter.rete.network.communication.Timestamp
 
equals(Object) - Method in class tools.refinery.interpreter.rete.remote.Address
 
errorResult() - Method in class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
estimateCardinality(TupleMask, Accuracy) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
evaluateTerm(Tuple) - Method in class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
evaluationKind() - Method in class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
evaluationKind() - Method in class tools.refinery.interpreter.rete.eval.EvaluatorCore.FunctionEvaluatorCore
 
evaluationKind() - Method in class tools.refinery.interpreter.rete.eval.EvaluatorCore.PredicateEvaluatorCore
 
evaluator - Variable in class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
EvaluatorCore - Class in tools.refinery.interpreter.rete.eval
An instance of this class performs the evaluation of Java expressions.
EvaluatorCore(Logger, IExpressionEvaluator, Map<String, Integer>, int) - Constructor for class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
EvaluatorCore.FunctionEvaluatorCore - Class in tools.refinery.interpreter.rete.eval
 
EvaluatorCore.PredicateEvaluatorCore - Class in tools.refinery.interpreter.rete.eval
 
evaluatorNode - Variable in class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
executeDelayedCommands() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
executeDelayedCommands() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
executingDelayedCommands - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
ExistenceNode - Class in tools.refinery.interpreter.rete.index
Propagates all substitutions arriving at the PRIMARY slot if and only if (a matching substitution on the SECONDARY is present) xor (NEGATIVE).
ExistenceNode(ReteContainer, boolean) - Constructor for class tools.refinery.interpreter.rete.index.ExistenceNode
 
expandWeakenedAlternativeConstraints - Static variable in class tools.refinery.interpreter.rete.util.ReteHintOptions
This hint allows the query planner to take advantage of "weakened alternative" suggestions of the meta context.
ExternalInputEnumeratorNode - Class in tools.refinery.interpreter.rete.boundary
An input node representing an enumerable extensional input relation and receiving external updates.
ExternalInputEnumeratorNode(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
ExternalInputStatelessFilterNode - Class in tools.refinery.interpreter.rete.boundary
A filter node representing a (stateless, typically non-enumerable) extensional input relation.
ExternalInputStatelessFilterNode(ReteContainer, TupleMask) - Constructor for class tools.refinery.interpreter.rete.boundary.ExternalInputStatelessFilterNode
 
externalMessageLock - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
externalMessageQueue - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 

F

FAITHFUL - Enum constant in enum class tools.refinery.interpreter.rete.matcher.TimelyConfiguration.TimelineRepresentation
Complete timeline (series of appearance invalid input: '&' disappearance) is maintained per tuple.
FAITHFUL_PARALLEL - Static variable in class tools.refinery.interpreter.rete.matcher.TimelyReteBackendFactory
 
FAITHFUL_SEQUENTIAL - Static variable in class tools.refinery.interpreter.rete.matcher.TimelyReteBackendFactory
 
FaithfulParallelTimelyColumnAggregatorNode<Domain,Accumulator,AggregateResult> - Class in tools.refinery.interpreter.rete.aggregation.timely
Faithful column aggregator with parallel aggregation architecture.
FaithfulParallelTimelyColumnAggregatorNode(ReteContainer, IMultisetAggregationOperator<Domain, Accumulator, AggregateResult>, TupleMask, int) - Constructor for class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode
 
FaithfulParallelTimelyColumnAggregatorNode(ReteContainer, IMultisetAggregationOperator<Domain, Accumulator, AggregateResult>, TupleMask, TupleMask) - Constructor for class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode
 
FaithfulParallelTimelyColumnAggregatorNode.CumulativeAggregate<Domain,Accumulator> - Class in tools.refinery.interpreter.rete.aggregation.timely
 
FaithfulParallelTimelyColumnAggregatorNode.FoldingState<Domain> - Class in tools.refinery.interpreter.rete.aggregation.timely
 
FaithfulSequentialTimelyColumnAggregatorNode<Domain,Accumulator,AggregateResult> - Class in tools.refinery.interpreter.rete.aggregation.timely
Faithful column aggregator with sequential aggregation architecture.
FaithfulSequentialTimelyColumnAggregatorNode(ReteContainer, IMultisetAggregationOperator<Domain, Accumulator, AggregateResult>, TupleMask, TupleMask) - Constructor for class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode
 
FaithfulSequentialTimelyColumnAggregatorNode.CumulativeAggregate<Domain,Accumulator,AggregateResult> - Class in tools.refinery.interpreter.rete.aggregation.timely
 
FaithfulSequentialTimelyColumnAggregatorNode.FoldingState<Domain,AggregateResult> - Class in tools.refinery.interpreter.rete.aggregation.timely
 
FaithfulTimelyColumnAggregatorNode<Domain,Accumulator,AggregateResult,CumulativeAggregate,FoldingState> - Class in tools.refinery.interpreter.rete.aggregation.timely
Faithful timely implementation of the column aggregator node.
FaithfulTimelyColumnAggregatorNode(ReteContainer, IMultisetAggregationOperator<Domain, Accumulator, AggregateResult>, TupleMask, TupleMask) - Constructor for class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
FaithfulTimelyColumnAggregatorNode.MergeableFoldingState<T> - Interface in tools.refinery.interpreter.rete.aggregation.timely
 
fallThrough - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
fallThrough - Variable in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
FallThroughCapableMailbox - Interface in tools.refinery.interpreter.rete.network.mailbox
A fall through capable mailbox can directly call the update method of its Receiver instead of using the standard post-deliver mailbox semantics.
FilterNode - Class in tools.refinery.interpreter.rete.single
This node implements a simple filter.
FilterNode(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.single.FilterNode
 
FIRST_ONLY - Enum constant in enum class tools.refinery.interpreter.rete.matcher.TimelyConfiguration.TimelineRepresentation
Only the first moment (timestamp) of appearance is maintained per tuple.
FIRST_ONLY_PARALLEL - Static variable in class tools.refinery.interpreter.rete.matcher.TimelyReteBackendFactory
 
FIRST_ONLY_SEQUENTIAL - Static variable in class tools.refinery.interpreter.rete.matcher.TimelyReteBackendFactory
 
firstFreeContainer - Static variable in class tools.refinery.interpreter.rete.util.Options
 
FirstOnlyParallelTimelyColumnAggregatorNode<Domain,Accumulator,AggregateResult> - Class in tools.refinery.interpreter.rete.aggregation.timely
First-only column aggregator with parallel aggregation architecture.
FirstOnlyParallelTimelyColumnAggregatorNode(ReteContainer, IMultisetAggregationOperator<Domain, Accumulator, AggregateResult>, TupleMask, TupleMask) - Constructor for class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyParallelTimelyColumnAggregatorNode
 
FirstOnlySequentialTimelyColumnAggregatorNode<Domain,Accumulator,AggregateResult> - Class in tools.refinery.interpreter.rete.aggregation.timely
First-only column aggregator with sequential aggregation architecture.
FirstOnlySequentialTimelyColumnAggregatorNode(ReteContainer, IMultisetAggregationOperator<Domain, Accumulator, AggregateResult>, TupleMask, TupleMask) - Constructor for class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlySequentialTimelyColumnAggregatorNode
 
FirstOnlyTimelyColumnAggregatorNode<Domain,Accumulator,AggregateResult> - Class in tools.refinery.interpreter.rete.aggregation.timely
First-only timely implementation of the column aggregator node.
FirstOnlyTimelyColumnAggregatorNode(ReteContainer, IMultisetAggregationOperator<Domain, Accumulator, AggregateResult>, TupleMask, TupleMask) - Constructor for class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
FirstOnlyTimelyColumnAggregatorNode.CumulativeAggregate<Accumulator,AggregateResult> - Class in tools.refinery.interpreter.rete.aggregation.timely
 
flushUpdates() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
flushUpdates() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Finalises all update sequences and returns.
foldingState - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
FoldingState() - Constructor for class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode.FoldingState
 
FoldingState() - Constructor for class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode.FoldingState
 
functionalDependencyOption - Static variable in class tools.refinery.interpreter.rete.util.Options
 
FunctionEvaluatorCore(Logger, IExpressionEvaluator, Map<String, Integer>, int) - Constructor for class tools.refinery.interpreter.rete.eval.EvaluatorCore.FunctionEvaluatorCore
 
FunctionEvaluatorCore(Logger, IExpressionEvaluator, Map<String, Integer>, int, boolean) - Constructor for class tools.refinery.interpreter.rete.eval.EvaluatorCore.FunctionEvaluatorCore
 

G

gcAggregates(CumulativeAggregate, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
Garbage collects the counter of the given group and timestamp if the bag of aggregands is empty.
gcAggregates(FaithfulParallelTimelyColumnAggregatorNode.CumulativeAggregate<Domain, Accumulator>, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode
Garbage collects the counter of the given group and timestamp if the bag of aggregands is empty.
gcAggregates(FaithfulSequentialTimelyColumnAggregatorNode.CumulativeAggregate<Domain, Accumulator, AggregateResult>, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode
 
gds - Variable in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
generateDot(Graph<V>) - Static method in class tools.refinery.interpreter.rete.itc.graphimpl.DotGenerator
Generates the dot representation for the given graph.
generateDot(Graph<V>, boolean, Function<V, String>, Function<V, String>, Function<V, Function<V, String>>) - Static method in class tools.refinery.interpreter.rete.itc.graphimpl.DotGenerator
Generates the dot representation for the given graph.
generateJoinCandidates() - Method in class tools.refinery.interpreter.rete.construction.quasitree.QuasiTreeLayout.Scaffold
 
GenericProjectionIndexer - Class in tools.refinery.interpreter.rete.index
A generic Indexer capable of indexing along any valid TupleMask.
GenericProjectionIndexer(ReteContainer, TupleMask) - Constructor for class tools.refinery.interpreter.rete.index.GenericProjectionIndexer
 
get(Object) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
get(Object) - Method in class tools.refinery.interpreter.rete.network.communication.Timestamp.AllZeroMap
 
get(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer
 
get(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIndexer
 
get(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.NetworkStructureChangeSensitiveLogic
 
get(Tuple) - Method in class tools.refinery.interpreter.rete.index.GenericProjectionIndexer
 
get(Tuple) - Method in class tools.refinery.interpreter.rete.index.IdentityIndexer
 
get(Tuple) - Method in interface tools.refinery.interpreter.rete.index.Indexer
 
get(Tuple) - Method in class tools.refinery.interpreter.rete.index.NullIndexer
 
get(Tuple) - Method in class tools.refinery.interpreter.rete.index.OnetimeIndexer
 
get(Tuple) - Method in class tools.refinery.interpreter.rete.index.TransitiveClosureNodeIndexer
 
getAccumulator(Tuple, Map<Tuple, Accumulator>) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
getAccumulator(Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyParallelTimelyColumnAggregatorNode
 
getAccumulator(Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlySequentialTimelyColumnAggregatorNode
 
getAccumulator(Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
Returns the aggregation architecture-specific accumulator at the specified timestamp for the given group.
getActiveAntiMonotoneQueue() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
getActiveMonotoneQueue() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
getActiveNode() - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer
 
getActiveNode() - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIndexer
 
getActiveNode() - Method in class tools.refinery.interpreter.rete.index.GenericProjectionIndexer
 
getActiveNode() - Method in interface tools.refinery.interpreter.rete.index.Indexer
This indexer will be updated whenever a Rete update is sent to the active node (or an equivalent time slot allotted to it).
getActiveNode() - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer
 
getActiveNode() - Method in class tools.refinery.interpreter.rete.index.TransitiveClosureNodeIndexer
 
getActiveQueue() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
getActiveQueue() - Method in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
getAdapter() - Method in interface tools.refinery.interpreter.rete.network.mailbox.AdaptableMailbox
 
getAdapter() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
getAdapter() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.UpdateSplittingMailbox
 
getAddress(SubPlan) - Method in class tools.refinery.interpreter.rete.boundary.ReteBoundary
 
getAggregate(Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode
On-demand initializes and returns the aggregate for the given group and timestamp.
getAggregate(Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode
 
getAggregate(Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
On-demand initializes and returns the aggregate for the given group and timestamp.
getAggregateResult(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
getAggregateResult(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
getAggregateResult(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode
 
getAggregateResult(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode
 
getAggregateResult(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
getAggregateResultTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
getAggregateResultTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
getAggregateResultTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
getAggregateResultTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
getAggregateTuple(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
getAggregateTuple(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
getAggregateTuple(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
getAggregateTuple(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
getAggregateTupleTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
getAggregateTupleTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
getAggregateTupleTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
getAggregateTupleTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
getAggregatorArchitecture() - Method in class tools.refinery.interpreter.rete.matcher.TimelyConfiguration
 
getAggregatorOuterIdentityIndexer(int) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
getAggregatorOuterIdentityIndexer(int) - Method in interface tools.refinery.interpreter.rete.aggregation.IAggregatorNode
 
getAggregatorOuterIdentityIndexer(int) - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
 
getAggregatorOuterIndexer() - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
getAggregatorOuterIndexer() - Method in interface tools.refinery.interpreter.rete.aggregation.IAggregatorNode
 
getAggregatorOuterIndexer() - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
 
getAllExternalInputNodes() - Method in class tools.refinery.interpreter.rete.boundary.InputConnector
 
getAllExternalInputNodesForKey(IInputKey) - Method in class tools.refinery.interpreter.rete.boundary.InputConnector
 
getAllMatches(Object[]) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
getAllMatches(TupleMask, ITuple) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
getAllNodes() - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
 
getAllNodes() - Method in class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
getAllNodes() - Method in interface tools.refinery.interpreter.rete.itc.igraph.IGraphDataSource
Returns the complete set of nodes in the graph data source.
getAllNodes() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Access all the Rete nodes inside this container.
getAllPaths(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.DFSPathFinder
 
getAllPaths(V, V) - Method in interface tools.refinery.interpreter.rete.itc.alg.misc.IGraphPathFinder
Returns the collection of paths from the source node to the target node (if such exists).
getAllPathsToTargets(V, Set<V>) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.DFSPathFinder
 
getAllPathsToTargets(V, Set<V>) - Method in interface tools.refinery.interpreter.rete.itc.alg.misc.IGraphPathFinder
Returns the collection of paths from the source node to any of the target nodes (if such exists).
getAllProductionNodes() - Method in class tools.refinery.interpreter.rete.boundary.ReteBoundary
 
getAllReachableSources(V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
getAllReachableSources(V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
getAllReachableSources(V) - Method in interface tools.refinery.interpreter.rete.itc.igraph.ITcDataSource
Returns all nodes from which the target node is reachable.
getAllReachableTargets(V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
getAllReachableTargets(V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
getAllReachableTargets(V) - Method in interface tools.refinery.interpreter.rete.itc.igraph.ITcDataSource
Returns all nodes which are reachable from the source node.
getAndRemoveFirstGroup() - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
getAverageEdgeCount() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCResult
 
getAverageNodeCount() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCResult
 
getBackendClass() - Method in class tools.refinery.interpreter.rete.matcher.ReteBackendFactory
 
getBackendContext() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
getBiggestSCCSize() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCResult
 
getBoundary() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
getBucketCount() - Method in class tools.refinery.interpreter.rete.index.GenericProjectionIndexer
 
getBucketCount() - Method in class tools.refinery.interpreter.rete.index.IdentityIndexer
 
getBucketCount() - Method in interface tools.refinery.interpreter.rete.index.IterableIndexer
 
getBucketCount() - Method in class tools.refinery.interpreter.rete.index.NullIndexer
 
getBucketCount() - Method in class tools.refinery.interpreter.rete.index.TransitiveClosureNodeIndexer
 
getBucketKey() - Method in class tools.refinery.interpreter.rete.single.DiscriminatorBucketNode
 
getBucketMailboxes() - Method in class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
getCachedCompiledQueries() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.ReteRecipeCompiler
Returns an unmodifiable view of currently cached compiled queries.
getCachedQueryPlans() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.ReteRecipeCompiler
Returns an unmodifiable view of currently cached query plans.
getChildMailboxes() - Method in class tools.refinery.interpreter.rete.network.StandardNode
 
getCommunicationTracker() - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
getCommunicationTracker() - Method in interface tools.refinery.interpreter.rete.network.Node
 
getCommunicationTracker() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
getCommunicationTracker() - Method in class tools.refinery.interpreter.rete.single.SingleInputNode
 
getCompiledForm(SubPlan) - Method in class tools.refinery.interpreter.rete.construction.plancompiler.ReteRecipeCompiler
Returns a CompiledSubPlan compiled from a query plan
getCompiledForm(PQuery) - Method in class tools.refinery.interpreter.rete.construction.plancompiler.ReteRecipeCompiler
Returns a CompiledQuery compiled from a query
getCompiledFormOfParents(SubPlan) - Method in class tools.refinery.interpreter.rete.construction.plancompiler.ReteRecipeCompiler
 
getCompiledQuery() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.RecursionCutoffPoint
 
getCompiler() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
getComplementerMask() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.JoinHelper
 
getComponent(T) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
getComponents() - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
getConnectionFactory() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
getContainer() - Method in class tools.refinery.interpreter.rete.index.StandardIndexer
 
getContainer() - Method in class tools.refinery.interpreter.rete.network.BaseNode
 
getContainer() - Method in interface tools.refinery.interpreter.rete.network.Node
 
getContainer() - Method in class tools.refinery.interpreter.rete.remote.Address
 
getContainers() - Method in class tools.refinery.interpreter.rete.network.Network
 
getCoreMask() - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
getCoreMask() - Method in interface tools.refinery.interpreter.rete.network.PosetAwareReceiver
 
getCoreMask() - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
getCount(Tuple) - Method in class tools.refinery.interpreter.rete.network.indexer.DefaultMessageIndexer
 
getCount(Tuple) - Method in class tools.refinery.interpreter.rete.network.indexer.GroupBasedMessageIndexer
 
getCount(Tuple) - Method in interface tools.refinery.interpreter.rete.network.indexer.MessageIndexer
 
getCount(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
getCurrentGroup() - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
getCurrentGroup() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
getCurrentGroup() - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
getCurrentGroup() - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
getCurrentGroup() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
getCurrentGroup() - Method in interface tools.refinery.interpreter.rete.network.IGroupable
 
getCurrentGroup() - Method in interface tools.refinery.interpreter.rete.network.mailbox.Mailbox
Returns the CommunicationGroup of the receiver of this mailbox.
getCurrentGroup() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
getCurrentGroup() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
getCurrentGroup() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
getCurrentGroup() - Method in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
getCurrentGroup() - Method in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
getCurrentGroup() - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
getDefaultTuple(ITuple) - Method in class tools.refinery.interpreter.rete.aggregation.LeftJoinNode
 
getDelayedCommandQueue() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
getDependencyGraph() - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
getDiscriminationColumnIndex() - Method in class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
getDispatcher() - Method in class tools.refinery.interpreter.rete.single.DiscriminatorBucketNode
 
getEdgeCount(V, IGraphDataSource<V>) - Static method in class tools.refinery.interpreter.rete.itc.alg.misc.GraphHelper
Returns the number of self-loop edges for the given node.
getEdgeCount(V, V, IGraphDataSource<V>) - Static method in class tools.refinery.interpreter.rete.itc.alg.misc.GraphHelper
Returns the number of edges between the given source and target nodes.
getEngine() - Method in class tools.refinery.interpreter.rete.network.Network
 
getExistingNodeByRecipe(ReteNodeRecipe) - Method in class tools.refinery.interpreter.rete.network.Network
 
getExternalInputNode(IInputKey, Tuple) - Method in class tools.refinery.interpreter.rete.boundary.InputConnector
 
getExternalInputNodeForKeyUnseeded(IInputKey) - Method in class tools.refinery.interpreter.rete.boundary.InputConnector
 
getFactory() - Method in class tools.refinery.interpreter.rete.matcher.ReteBackendFactoryProvider
 
getFactory() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
getGlobalSeed() - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
getGroup(Node) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
getGroups() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
getGroups() - Method in class tools.refinery.interpreter.rete.network.indexer.GroupBasedMessageIndexer
 
getHeadContainer() - Method in class tools.refinery.interpreter.rete.boundary.ReteBoundary
 
getHeadContainer() - Method in class tools.refinery.interpreter.rete.network.Network
Returns the head container, that is guaranteed to reside in the same JVM as the Network object.
getHintConfiguration() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
getIdentityIndexer() - Method in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
getIdentityIndexer() - Method in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
getIdentityIndexer() - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
getInactiveRecipeTrace() - Method in class tools.refinery.interpreter.rete.traceability.ActiveNodeConflictTrace
 
getIndex() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCProperty
 
getIndexer() - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer.ListenerSubscription
 
getInitialTimeline(AggregateResult) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
getInputConnectionFactory() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
getInputConnector() - Method in class tools.refinery.interpreter.rete.network.Network
 
getInputKey() - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
getInternalIndexer(TupleMask) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
getLastResult(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
getLastTimestamp(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
getListener() - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer.ListenerSubscription
 
getListeners() - Method in interface tools.refinery.interpreter.rete.index.Indexer
 
getListeners() - Method in class tools.refinery.interpreter.rete.index.StandardIndexer
 
getLogger() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
getLowlink() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCProperty
 
getMailbox() - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
getMailbox() - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
getMailbox() - Method in class tools.refinery.interpreter.rete.misc.SimpleReceiver
 
getMailbox() - Method in interface tools.refinery.interpreter.rete.network.Receiver
Returns the Mailbox of this receiver.
getMailbox() - Method in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
getMailbox() - Method in class tools.refinery.interpreter.rete.single.SingleInputNode
 
getMailboxes() - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
getMailboxes() - Method in class tools.refinery.interpreter.rete.network.communication.timeless.RecursiveCommunicationGroup
 
getMailboxes() - Method in class tools.refinery.interpreter.rete.network.communication.timeless.SingletonCommunicationGroup
 
getMailboxes() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationGroup
 
getMainAccumulator(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
getMask() - Method in interface tools.refinery.interpreter.rete.index.Indexer
 
getMask() - Method in class tools.refinery.interpreter.rete.index.StandardIndexer
 
getMask() - Method in class tools.refinery.interpreter.rete.single.TrimmerNode
 
getMemory() - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
getNameShortener(int) - Static method in class tools.refinery.interpreter.rete.itc.graphimpl.DotGenerator
Returns a simple name shortener function that can be used in the graphviz visualization to help with readability.
getNaturalJoinRecipe() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.JoinHelper
 
getNaturalJoinVariablesTuple() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.JoinHelper
 
getNetwork() - Method in class tools.refinery.interpreter.rete.boundary.InputConnector
 
getNetwork() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
getNextContainer() - Method in class tools.refinery.interpreter.rete.network.Network
Returns the next container in round-robin fashion.
getNode() - Method in class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
 
getNode() - Method in interface tools.refinery.interpreter.rete.traceability.TraceInfo
 
getNodeByRecipeIfExists(ReteNodeRecipe) - Method in class tools.refinery.interpreter.rete.network.Network
 
getNodeCache() - Method in class tools.refinery.interpreter.rete.remote.Address
 
getNodeFactory() - Method in class tools.refinery.interpreter.rete.network.Network
 
getNodeFactory() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
getNodeId() - Method in class tools.refinery.interpreter.rete.network.BaseNode
 
getNodeId() - Method in interface tools.refinery.interpreter.rete.network.Node
 
getNodeId() - Method in class tools.refinery.interpreter.rete.remote.Address
 
getNullIndexer() - Method in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
getNullIndexer() - Method in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
getNullIndexer() - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
getOneArbitraryMatch(Object[]) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
getOneArbitraryMatch(TupleMask, ITuple) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
getOrCreateNodeByRecipe(RecipeTraceInfo) - Method in class tools.refinery.interpreter.rete.network.NodeProvisioner
 
getOuterIndexer() - Method in class tools.refinery.interpreter.rete.aggregation.LeftJoinNode
 
getOwner() - Method in class tools.refinery.interpreter.rete.index.DefaultIndexerListener
 
getOwner() - Method in interface tools.refinery.interpreter.rete.index.IndexerListener
 
getOwner() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyIndexerListenerProxy
 
getParent() - Method in interface tools.refinery.interpreter.rete.index.Indexer
 
getParent() - Method in class tools.refinery.interpreter.rete.index.StandardIndexer
 
getParentRecipeTraces() - Method in class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
For cloning in case of recursion cut-off points, use RecipeTraceInfo.getParentRecipeTracesForCloning() instead.
getParentRecipeTracesForCloning() - Method in class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
Directly return the underlying collection so that changes to it will be transparent.
getParentRecipeTracesPerBody() - Method in class tools.refinery.interpreter.rete.traceability.CompiledQuery
 
getParents() - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
getParents() - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
getParents() - Method in class tools.refinery.interpreter.rete.misc.SimpleReceiver
 
getParents() - Method in interface tools.refinery.interpreter.rete.network.Receiver
access active parent
getParents() - Method in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
getParents() - Method in class tools.refinery.interpreter.rete.single.SingleInputNode
 
getPartition(Node) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
getPartition(Node) - Method in class tools.refinery.interpreter.rete.network.communication.NetworkComponentDetector
 
getPath(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.DFSPathFinder
 
getPath(V, V) - Method in interface tools.refinery.interpreter.rete.itc.alg.misc.IGraphPathFinder
Returns an arbitrary path from the source node to the target node (if such exists).
getPathFinder() - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
getPathFinder() - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
getPathFinder() - Method in interface tools.refinery.interpreter.rete.itc.igraph.ITcDataSource
The returned IGraphPathFinder can be used to retrieve paths between nodes using transitive reachability.
getPaths(List<Deque<V>>, Deque<V>, Set<V>) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.DFSPathFinder
 
getPatternName() - Method in class tools.refinery.interpreter.rete.traceability.CompiledQuery
 
getPatternName() - Method in class tools.refinery.interpreter.rete.traceability.ParameterProjectionTrace
 
getPatternName() - Method in interface tools.refinery.interpreter.rete.traceability.PatternTraceInfo
 
getPatternName() - Method in class tools.refinery.interpreter.rete.traceability.PlanningTrace
 
getPlan(PBody) - Method in class tools.refinery.interpreter.rete.construction.plancompiler.ReteRecipeCompiler
 
getPosetComparator() - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
getPosetComparator() - Method in interface tools.refinery.interpreter.rete.network.PosetAwareReceiver
 
getPosetComparator() - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
getPosetMask() - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
getPosetMask() - Method in interface tools.refinery.interpreter.rete.network.PosetAwareReceiver
 
getPosetMask() - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
getPosMapping() - Method in interface tools.refinery.interpreter.rete.network.ProductionNode
 
getPosMapping() - Method in class tools.refinery.interpreter.rete.single.DefaultProductionNode
 
getPosMapping() - Method in class tools.refinery.interpreter.rete.single.TimelyProductionNode
 
getPosMapping() - Method in class tools.refinery.interpreter.rete.traceability.PlanningTrace
 
getPreprocessor(Node, Node) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationTracker
 
getPrimaryIndexer() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.JoinHelper
 
getPrimaryMask() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.JoinHelper
 
getPrimarySlot() - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
getProductionNode() - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
getProvisioner() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
getPulledContents() - Method in interface tools.refinery.interpreter.rete.network.Supplier
 
getPulledContents(boolean) - Method in class tools.refinery.interpreter.rete.aggregation.LeftJoinNode
 
getPulledContents(boolean) - Method in class tools.refinery.interpreter.rete.network.StandardNode
 
getPulledContents(boolean) - Method in interface tools.refinery.interpreter.rete.network.Supplier
Returns the contents of this object in this particular moment.
getQuery() - Method in class tools.refinery.interpreter.rete.traceability.CompiledQuery
 
getQueryBackend() - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
getReachabilityPath(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
getReceiver() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
getReceiver() - Method in interface tools.refinery.interpreter.rete.network.mailbox.Mailbox
Returns the Receiver of this mailbox.
getReceiver() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
getReceiver() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
getReceiver() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
getReceiver() - Method in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
getReceivers() - Method in class tools.refinery.interpreter.rete.network.StandardNode
 
getReceivers() - Method in interface tools.refinery.interpreter.rete.network.Supplier
lists receivers
getRecipe() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.RecursionCutoffPoint
 
getRecipe() - Method in class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
 
getRecipeTraces() - Method in class tools.refinery.interpreter.rete.network.Network
 
getRederivableAccumulator(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
getRederivables() - Method in class tools.refinery.interpreter.rete.network.communication.timeless.RecursiveCommunicationGroup
 
getReducedGraph() - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
The graph of SCCs; each SCC is represented by its representative node (see IncSCCAlg.getRepresentative(Object))
getReducedGraph() - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
getReducedGraph() - Method in class tools.refinery.interpreter.rete.network.communication.NetworkComponentDetector
 
getRepresentative() - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
getRepresentative(T) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
getRepresentative(Node) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
getRepresentative(Node) - Method in class tools.refinery.interpreter.rete.network.communication.NetworkComponentDetector
 
getRepresentative(V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
Returns the node that is selected as the representative of the SCC containing the argument.
getResult(Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
getResult(Tuple, Timestamp, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
getResultProvider(PQuery) - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
getResultProvider(PQuery, QueryEvaluationHint) - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
getResultRaw(Tuple, Timestamp, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode
 
getResultRaw(Tuple, Timestamp, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
getResumableTimestamp() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
getResumableTimestamp() - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
getResumableTimestamp() - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
getResumableTimestamp() - Method in interface tools.refinery.interpreter.rete.network.communication.timely.ResumableNode
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.rete.single.TimelyUniquenessEnforcerNode
 
getReteContainer() - Method in class tools.refinery.interpreter.rete.eval.AbstractEvaluatorNode
 
getReteContainer() - Method in interface tools.refinery.interpreter.rete.eval.IEvaluatorNode
 
getReteNet() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
getRuntimeContext() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
getSCCCount() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCResult
 
getSccs() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCResult
 
getSecondaryIndexer() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.JoinHelper
 
getSecondaryMask() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.JoinHelper
 
getSecondarySlot() - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
getShadowedRecipe() - Method in class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
Get original recipe shadowed by an equivalent
getShortestPaths(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.DFSPathFinder
 
getShortestPaths(V, V) - Method in interface tools.refinery.interpreter.rete.itc.alg.misc.IGraphPathFinder
Returns the collection of shortest paths from the source node to the target node (if such exists).
getSignatures() - Method in class tools.refinery.interpreter.rete.index.GenericProjectionIndexer
 
getSignatures() - Method in class tools.refinery.interpreter.rete.index.IdentityIndexer
 
getSignatures() - Method in interface tools.refinery.interpreter.rete.index.IterableIndexer
A view consisting of exactly those signatures whose tuple group is not empty
getSignatures() - Method in class tools.refinery.interpreter.rete.index.NullIndexer
 
getSignatures() - Method in class tools.refinery.interpreter.rete.index.TransitiveClosureNodeIndexer
 
getSlot(DualInputNode.Side) - Method in class tools.refinery.interpreter.rete.index.DualInputNode
Retrieves the slot corresponding to the specified side.
getSource() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.Edge
 
getSource() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.Tuple
 
getSourceNodes(V) - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
 
getSourceNodes(V) - Method in interface tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalGraphDataSource
Returns the source nodes for the given target node.
getSourceNodes(V) - Method in class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
getStructuralChangeLock() - Method in class tools.refinery.interpreter.rete.network.Network
 
getSubGraph(Collection<V>, IBiDirectionalGraphDataSource<V>) - Static method in class tools.refinery.interpreter.rete.itc.alg.misc.GraphHelper
Returns the subgraph from the given IBiDirectionalGraphDataSource which contains the given set of nodes.
getSubPlan() - Method in class tools.refinery.interpreter.rete.traceability.PlanningTrace
 
getSubscriptions() - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer
 
getSumOfSquares() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCResult
 
getTag() - Method in class tools.refinery.interpreter.rete.network.BaseNode
 
getTag() - Method in interface tools.refinery.interpreter.rete.network.Node
 
getTarget() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.Edge
 
getTarget() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.Tuple
 
getTargetNodes(V) - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
 
getTargetNodes(V) - Method in class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
getTargetNodes(V) - Method in interface tools.refinery.interpreter.rete.itc.igraph.IGraphDataSource
Returns the target nodes for the given source node.
getTcRelation() - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
getTcRelation() - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
getTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer
 
getTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIndexer
 
getTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.NetworkStructureChangeSensitiveLogic
 
getTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.index.GenericProjectionIndexer
 
getTimeline(Tuple) - Method in interface tools.refinery.interpreter.rete.index.Indexer
 
getTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.index.timely.TimelyMemoryIdentityIndexer
 
getTimeline(Tuple) - Method in class tools.refinery.interpreter.rete.index.timely.TimelyMemoryNullIndexer
 
getTimeline(Tuple, Indexer) - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
getTimelineRepresentation() - Method in class tools.refinery.interpreter.rete.matcher.TimelyConfiguration
 
getTimelyConfiguration() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
getTimelyConfiguration() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
getTraceInfoPatternsEnumerated() - Method in class tools.refinery.interpreter.rete.network.BaseNode
Descendants should use this in e.g.
getTraceInfos() - Method in class tools.refinery.interpreter.rete.network.BaseNode
 
getTraceInfos() - Method in interface tools.refinery.interpreter.rete.network.Node
 
getTupleEnds(V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
getTupleEnds(V) - Method in interface tools.refinery.interpreter.rete.itc.alg.misc.ITcRelation
Returns the set of nodes that are reachable from the given node.
getTuples() - Method in class tools.refinery.interpreter.rete.index.IdentityIndexer
 
getTuples() - Method in class tools.refinery.interpreter.rete.index.MemoryIdentityIndexer
 
getTuples() - Method in class tools.refinery.interpreter.rete.index.MemoryNullIndexer
 
getTuples() - Method in class tools.refinery.interpreter.rete.index.NullIndexer
 
getTuples() - Method in class tools.refinery.interpreter.rete.index.timely.TimelyMemoryIdentityIndexer
 
getTuples() - Method in class tools.refinery.interpreter.rete.index.timely.TimelyMemoryNullIndexer
 
getTuples() - Method in class tools.refinery.interpreter.rete.network.indexer.DefaultMessageIndexer
 
getTuples() - Method in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
getTuples() - Method in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
getTuples() - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
getTuplesByGroup(Tuple) - Method in class tools.refinery.interpreter.rete.network.indexer.GroupBasedMessageIndexer
 
getTuplesInternal() - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
getTupleStarts() - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
getTupleStarts() - Method in interface tools.refinery.interpreter.rete.itc.alg.misc.ITcRelation
Returns the starting nodes from a transitive closure relation.
getTupleStarts(V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
Returns the set of nodes from which the target node is reachable, if already computed.
getValue() - Method in class tools.refinery.interpreter.rete.network.communication.Timestamp
 
getVariablesTuple() - Method in class tools.refinery.interpreter.rete.traceability.PlanningTrace
 
getWrappedIndexerListener() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyIndexerListenerProxy
 
getWrappedMailbox() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
globalTerminationCriteria - Variable in class tools.refinery.interpreter.rete.network.Network
 
graph - Variable in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
Graph<V> - Class in tools.refinery.interpreter.rete.itc.graphimpl
 
Graph() - Constructor for class tools.refinery.interpreter.rete.itc.graphimpl.Graph
 
GraphHelper - Class in tools.refinery.interpreter.rete.itc.alg.misc
Utility class for graph related operations.
group - Variable in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
group - Variable in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
group - Variable in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
group - Variable in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
group - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
group - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
group - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
group - Variable in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
group - Variable in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
GroupBasedMessageIndexer - Class in tools.refinery.interpreter.rete.network.indexer
 
GroupBasedMessageIndexer(TupleMask) - Constructor for class tools.refinery.interpreter.rete.network.indexer.GroupBasedMessageIndexer
 
GroupedMap<GroupedKeyType,ValueType> - Class in tools.refinery.interpreter.rete.aggregation
An optimized Map implementation where each key is produced by joining together a group tuple and some other object (via left inheritance).
GroupedMap(Tuple, Map<GroupedKeyType, ValueType>, IQueryRuntimeContext) - Constructor for class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
GroupedSet<GroupingValueType,GroupedKeyType,WholeKeyType> - Class in tools.refinery.interpreter.rete.aggregation
An optimized Set implementation where each contained value is produced by combining together a grouping value and some other (key) object.
GroupedSet(GroupingValueType, Collection<GroupedKeyType>, BiFunction<GroupingValueType, GroupedKeyType, WholeKeyType>) - Constructor for class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
groupMap - Variable in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
Precomputed node -> communication group map
groupMask - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
groupMask - Variable in class tools.refinery.interpreter.rete.network.indexer.GroupBasedMessageIndexer
 
groupMask - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.PosetAwareMailbox
 
groupQueue - Variable in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
Priority queue of active communication groups

H

hashCode() - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer.ListenerSubscription
 
hashCode() - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
hashCode() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.Tuple
 
hashCode() - Method in class tools.refinery.interpreter.rete.matcher.DRedReteBackendFactory
 
hashCode() - Method in class tools.refinery.interpreter.rete.matcher.ReteBackendFactory
 
hashCode() - Method in class tools.refinery.interpreter.rete.matcher.TimelyReteBackendFactory
 
hashCode() - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
hashCode() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyIndexerListenerProxy
 
hashCode() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
hashCode() - Method in class tools.refinery.interpreter.rete.network.communication.Timestamp
 
hashCode() - Method in class tools.refinery.interpreter.rete.remote.Address
 
hasIncomingEdges(V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
Returns true if the SCC represented by the given root node has incoming edges in the reduced graph, false otherwise (if this SCC is a source in the reduced graph).
hasMatch(Object[]) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
hasMatch(TupleMask, ITuple) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
hasOutgoingEdges(Node) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
hasOutgoingEdges(Node) - Method in class tools.refinery.interpreter.rete.network.communication.NetworkComponentDetector
 
hasOutgoingEdges(V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
Returns true if the SCC represented by the given root node has outgoing edges in the reduced graph, false otherwise (if this SCC is a sink in the reduced graph).
headContainer - Variable in class tools.refinery.interpreter.rete.boundary.ReteBoundary
 

I

IAggregatorNode - Interface in tools.refinery.interpreter.rete.aggregation
Expresses that aggregators expose specialized non-enumerable indexers for outer joining.
IBiDirectionalGraphDataSource<V> - Interface in tools.refinery.interpreter.rete.itc.igraph
A bi-directional graph data source supports all operations that an IGraphDataSource does, but it also makes it possible to query the incoming edges of nodes, not only the outgoing edges.
IBiDirectionalWrapper<V> - Class in tools.refinery.interpreter.rete.itc.igraph
This class can be used to wrap an IGraphDataSource into an IBiDirectionalGraphDataSource.
IBiDirectionalWrapper(IGraphDataSource<V>) - Constructor for class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
identifier - Variable in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
May be changed during bumping in
invalid reference
CommunicationTracker.registerDependency
IdentityIndexer - Class in tools.refinery.interpreter.rete.index
Defines an abstract trivial indexer that identically projects the contents of some stateful node, and can therefore save space.
IdentityIndexer(ReteContainer, int, Supplier, Node, List<SpecializedProjectionIndexer.ListenerSubscription>) - Constructor for class tools.refinery.interpreter.rete.index.IdentityIndexer
 
identityMask - Variable in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
IEvaluatorNode - Interface in tools.refinery.interpreter.rete.eval
This interface is required for the communication between the evaluation core end the evaluator node.
IGraphDataSource<V> - Interface in tools.refinery.interpreter.rete.itc.igraph
The interface prescribes the set of operations that a graph data source must support.
IGraphObserver<V> - Interface in tools.refinery.interpreter.rete.itc.igraph
Interface GraphObserver is used to observ the changes in a graph; edge and node insertion/deleteion.
IGraphPathFinder<V> - Interface in tools.refinery.interpreter.rete.itc.alg.misc
The path finder provides methods for retrieving paths in a graph between a source node and one or more target nodes.
IGroupable - Interface in tools.refinery.interpreter.rete.network
 
INCREMENT - Enum constant in enum class tools.refinery.interpreter.rete.network.communication.timely.TimestampTransformation
 
IncrementalMatcherCapability - Class in tools.refinery.interpreter.rete.matcher
 
IncrementalMatcherCapability() - Constructor for class tools.refinery.interpreter.rete.matcher.IncrementalMatcherCapability
 
IncSCCAlg<V> - Class in tools.refinery.interpreter.rete.itc.alg.incscc
Incremental SCC maintenance + counting algorithm.
IncSCCAlg(IGraphDataSource<V>) - Constructor for class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
indexer - Variable in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer.ListenerSubscription
 
indexer - Variable in class tools.refinery.interpreter.rete.network.indexer.DefaultMessageIndexer
 
indexer - Variable in class tools.refinery.interpreter.rete.network.indexer.GroupBasedMessageIndexer
 
Indexer - Interface in tools.refinery.interpreter.rete.index
A node that indexes incoming Tuples by their signatures as specified by a TupleMask.
INDEXER_AND_REMOTEPROXY - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.NodeSharingOption
 
IndexerBasedAggregatorNode - Class in tools.refinery.interpreter.rete.aggregation
A special node depending on a projection indexer to aggregate tuple groups with the same projection.
IndexerBasedAggregatorNode(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
MUST call initializeWith() afterwards!
indexerGroupCache - Variable in class tools.refinery.interpreter.rete.index.DualInputNode
This map caches the result of a CommunicationTracker.areInSameGroup(indexer, this) call.
IndexerListener - Interface in tools.refinery.interpreter.rete.index
A listener for update events concerning an Indexer.
IndexerWithMemory - Class in tools.refinery.interpreter.rete.index
 
IndexerWithMemory(ReteContainer, TupleMask) - Constructor for class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
IndexerWithMemory.NetworkStructureChangeSensitiveLogic - Class in tools.refinery.interpreter.rete.index
 
InequalityFilterNode - Class in tools.refinery.interpreter.rete.single
This node filters patterns according to equalities and inequalities of elements.
InequalityFilterNode(ReteContainer, int, TupleMask) - Constructor for class tools.refinery.interpreter.rete.single.InequalityFilterNode
 
init(IEvaluatorNode) - Method in class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
initializeComponents() - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
initializeComponents() - Method in class tools.refinery.interpreter.rete.itc.alg.representative.StronglyConnectedComponentAlgorithm
 
initializeComponents() - Method in class tools.refinery.interpreter.rete.itc.alg.representative.WeaklyConnectedComponentAlgorithm
 
initializeSet(Set<T>) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
initializeWith(ProjectionIndexer) - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
 
initializeWith(ProjectionIndexer) - Method in class tools.refinery.interpreter.rete.aggregation.LeftJoinNode
 
injectivityStrategy - Static variable in class tools.refinery.interpreter.rete.util.Options
 
inputConnector - Variable in class tools.refinery.interpreter.rete.boundary.ReteBoundary
 
inputConnector - Variable in class tools.refinery.interpreter.rete.network.Network
 
InputConnector - Class in tools.refinery.interpreter.rete.boundary
A class responsible for connecting input nodes to the runtime context.
InputConnector(Network) - Constructor for class tools.refinery.interpreter.rete.boundary.InputConnector
 
insert(Tuple) - Method in class tools.refinery.interpreter.rete.network.indexer.DefaultMessageIndexer
 
insert(Tuple) - Method in class tools.refinery.interpreter.rete.network.indexer.GroupBasedMessageIndexer
 
insert(Tuple) - Method in interface tools.refinery.interpreter.rete.network.indexer.MessageIndexer
 
INSERT_AT_ZERO_TIMELINE - Static variable in class tools.refinery.interpreter.rete.network.communication.Timestamp
 
insertEdge(V, V) - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
 
insertNode(V) - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
Insert the given node into the graph.
INSTANCE - Static variable in class tools.refinery.interpreter.rete.matcher.DRedReteBackendFactory
 
INSTANCE - Static variable in class tools.refinery.interpreter.rete.matcher.ReteBackendFactory
 
instantiateMailbox() - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
instantiateMailbox() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
instantiateMailbox() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
instantiateMailbox() - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
Instantiates the Mailbox of this receiver.
instantiateMailbox() - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
Instantiates the Mailbox of this receiver.
instantiateMailbox() - Method in class tools.refinery.interpreter.rete.misc.SimpleReceiver
Instantiates the Mailbox of this receiver.
instantiateMailbox() - Method in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
instantiateMailbox() - Method in class tools.refinery.interpreter.rete.single.SingleInputNode
Instantiates the Mailbox of this receiver.
instantiateMailbox() - Method in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
instantiateMailbox() - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
internalMessageQueue - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
intersection(Set<V>, Set<V>) - Static method in class tools.refinery.interpreter.rete.itc.alg.util.CollectionHelper
Returns the intersection of two sets.
isCaching() - Method in class tools.refinery.interpreter.rete.matcher.ReteBackendFactory
 
isCaching() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
isDeleteAndRederiveEvaluation() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
isDisposedOrUninitialized() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
isEmpty() - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
isEmpty() - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
isEmpty() - Method in class tools.refinery.interpreter.rete.index.NullIndexer
 
isEmpty() - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
isEmpty() - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
isEmpty() - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
isEmpty() - Method in class tools.refinery.interpreter.rete.network.communication.timeless.RecursiveCommunicationGroup
 
isEmpty() - Method in class tools.refinery.interpreter.rete.network.communication.timeless.SingletonCommunicationGroup
 
isEmpty() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationGroup
 
isEmpty() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
isEmpty() - Method in class tools.refinery.interpreter.rete.network.indexer.DefaultMessageIndexer
 
isEmpty() - Method in class tools.refinery.interpreter.rete.network.indexer.GroupBasedMessageIndexer
 
isEmpty() - Method in interface tools.refinery.interpreter.rete.network.indexer.MessageIndexer
 
isEmpty() - Method in interface tools.refinery.interpreter.rete.network.mailbox.Mailbox
Returns true if this mailbox is empty.
isEmpty() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
isEmpty() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
isEmpty() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
isEmpty() - Method in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
isEnqueued - Variable in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
Marker for the CommunicationTracker
isExecutingDelayedCommands() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
isFallThrough() - Method in interface tools.refinery.interpreter.rete.network.mailbox.FallThroughCapableMailbox
 
isFallThrough() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
isInDRedMode() - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
isInDRedMode() - Method in interface tools.refinery.interpreter.rete.network.RederivableNode
Returns true if this node actually runs in DRed mode (not necessarily).
isInDRedMode() - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
isInRecursiveGroup(Node) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
Returns true if the given Node is in a recursive CommunicationGroup, false otherwise.
isIsolated(V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
isLocal(Address<? extends Node>) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Checks whether a certain address points to a node at this container.
isParallelExecutionEnabled() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
isReachable(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
isReachable(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
isReachable(V, V) - Method in interface tools.refinery.interpreter.rete.itc.igraph.ITcDataSource
Returns true if the target node is reachable from the source node.
isReachable(V, V, IGraphDataSource<V>) - Static method in class tools.refinery.interpreter.rete.itc.alg.misc.bfs.BFS
Performs a breadth first search on the given graph to determine whether source is reachable from target.
isRecursionCutPoint(Node, Node) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
Returns true if the given source-target edge in the communication network acts as a recursion cut point.
isRecursive() - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
isRecursive() - Method in class tools.refinery.interpreter.rete.network.communication.timeless.RecursiveCommunicationGroup
 
isRecursive() - Method in class tools.refinery.interpreter.rete.network.communication.timeless.SingletonCommunicationGroup
 
isRecursive() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationGroup
 
isRecursiveAggregation - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode
 
isSingleElement() - Method in class tools.refinery.interpreter.rete.index.NullIndexer
 
isSingleton(Node) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
 
issueError(String, Exception) - Method in class tools.refinery.interpreter.rete.network.StandardNode
 
isSystemDefaultCachingBackend() - Method in class tools.refinery.interpreter.rete.matcher.ReteBackendFactoryProvider
 
isSystemDefaultEngine() - Method in class tools.refinery.interpreter.rete.matcher.ReteBackendFactoryProvider
 
isTimelyEvaluation() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
isTimestampAware() - Method in class tools.refinery.interpreter.rete.network.delayed.DelayedCommand
 
isTimestampAware() - Method in class tools.refinery.interpreter.rete.network.delayed.DelayedConnectCommand
 
isTimestampAware() - Method in class tools.refinery.interpreter.rete.network.delayed.DelayedDisconnectCommand
 
isUnknown() - Method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
isUnwinding - Variable in class tools.refinery.interpreter.rete.eval.EvaluatorCore.FunctionEvaluatorCore
 
ITcDataSource<V> - Interface in tools.refinery.interpreter.rete.itc.igraph
This interface defines those methods that a transitive reachability data source should provide.
ITcObserver<V> - Interface in tools.refinery.interpreter.rete.itc.igraph
Interface ITcObserver is used to observe the changes in a transitive closure relation; tuple insertion/deletion.
ITcRelation<V> - Interface in tools.refinery.interpreter.rete.itc.alg.misc
 
IterableIndexer - Interface in tools.refinery.interpreter.rete.index
An indexer that allows the iteration of all retrievable tuple groups (or reduced groups).
iterator() - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
iterator() - Method in class tools.refinery.interpreter.rete.index.GenericProjectionIndexer
 
iterator() - Method in class tools.refinery.interpreter.rete.index.IdentityIndexer
 
iterator() - Method in class tools.refinery.interpreter.rete.index.NullIndexer
 
iterator() - Method in class tools.refinery.interpreter.rete.index.TransitiveClosureNodeIndexer
 
iterator() - Method in class tools.refinery.interpreter.rete.single.DefaultProductionNode
 
iterator() - Method in class tools.refinery.interpreter.rete.single.TimelyProductionNode
 

J

JoinHelper(SubPlan, PlanningTrace, PlanningTrace) - Constructor for class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.JoinHelper
 
JoinNode - Class in tools.refinery.interpreter.rete.index
 
JoinNode(ReteContainer, TupleMask) - Constructor for class tools.refinery.interpreter.rete.index.JoinNode
 
JoinOrderingHeuristics - Class in tools.refinery.interpreter.rete.construction.quasitree
 
JoinOrderingHeuristics() - Constructor for class tools.refinery.interpreter.rete.construction.quasitree.JoinOrderingHeuristics
 

K

keySet() - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
keySet() - Method in class tools.refinery.interpreter.rete.network.communication.Timestamp.AllZeroMap
 
kill() - Method in class tools.refinery.interpreter.rete.network.Network
Kills this Network along with all containers and message consumption cycles.
kill() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Stops this container.
killed - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
killEngine() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
Deconstructs the engine to get rid of it finally

L

layoutStrategy(IQueryBackendContext, IQueryBackendHintProvider) - Method in enum class tools.refinery.interpreter.rete.util.Options.BuilderMethod
 
LAZY - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.InjectivityStrategy
 
LeftJoinNode - Class in tools.refinery.interpreter.rete.aggregation
 
LeftJoinNode(ReteContainer, Object) - Constructor for class tools.refinery.interpreter.rete.aggregation.LeftJoinNode
 
LEGACY - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.BuilderMethod
 
LexicographicComparator<T> - Class in tools.refinery.interpreter.rete.util
A comparator that compares two iterables based on the lexicographic sorting induced by a comparator on elements.
LexicographicComparator(Comparator<T>) - Constructor for class tools.refinery.interpreter.rete.util.LexicographicComparator
 
listener - Variable in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer.ListenerSubscription
 
ListenerSubscription(SpecializedProjectionIndexer, IndexerListener) - Constructor for class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer.ListenerSubscription
 
logger - Variable in class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
logger - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
logic - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer
 
logic - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIndexer
 
logic - Variable in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
logic - Variable in class tools.refinery.interpreter.rete.index.DualInputNode
 
logic - Variable in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 

M

mailbox - Variable in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
mailbox - Variable in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
mailbox - Variable in class tools.refinery.interpreter.rete.misc.SimpleReceiver
 
mailbox - Variable in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
mailbox - Variable in class tools.refinery.interpreter.rete.single.SingleInputNode
 
Mailbox - Interface in tools.refinery.interpreter.rete.network.mailbox
A mailbox is associated with every Receiver.
makeAddress(N) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Provides an external address for the selected node.
makeIndexerTrace(SubPlan, PlanningTrace, TupleMask) - Static method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper
Returns a compiled indexer trace according to a mask
makeProjectionMask(PlanningTrace, Iterable<PVariable>) - Static method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper
 
makeQueryTrace(PQuery, Map<PBody, RecipeTraceInfo>, Collection<ReteNodeRecipe>, QueryEvaluationHint, IQueryMetaContext, boolean, TimelyConfiguration) - Static method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper
Creates a recipe for a production node and the corresponding trace.
makeTrimmerRecipe(PlanningTrace, List<PVariable>) - Static method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper
Creates a trimmer that keeps selected variables only.
mappings - Variable in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
mapPlanToAddress(SubPlan, Address<? extends Supplier>) - Method in class tools.refinery.interpreter.rete.boundary.ReteBoundary
 
mask - Variable in class tools.refinery.interpreter.rete.index.StandardIndexer
 
mask - Variable in class tools.refinery.interpreter.rete.single.TrimmerNode
 
matchAll(Object[], boolean[]) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
matchAll(TupleMask, ITuple) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
matchers - Variable in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
matchFoundEvents - Variable in class tools.refinery.interpreter.rete.misc.DeltaMonitor
matches that are newly found
matchLostEvents - Variable in class tools.refinery.interpreter.rete.misc.DeltaMonitor
matches that are newly lost
matchOne(Object[], boolean[]) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
matchOne(TupleMask, ITuple) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
max(Timestamp) - Method in class tools.refinery.interpreter.rete.network.communication.Timestamp
 
maxGroupId - Variable in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
The maximum group id assigned so far
memory - Variable in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
memory - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
memory - Variable in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
Maps input tuples to timestamps.
memory - Variable in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
memory - Variable in class tools.refinery.interpreter.rete.index.MemoryIdentityIndexer
 
memory - Variable in class tools.refinery.interpreter.rete.index.timely.TimelyMemoryIdentityIndexer
 
memory - Variable in class tools.refinery.interpreter.rete.index.timely.TimelyMemoryNullIndexer
 
memory - Variable in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
memory - Variable in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
memoryIdentityIndexer - Variable in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
MemoryIdentityIndexer - Class in tools.refinery.interpreter.rete.index
Defines a trivial indexer that identically projects the contents of a memory-equipped node, and can therefore save space.
MemoryIdentityIndexer(ReteContainer, int, Collection<Tuple>, Supplier, Receiver, List<SpecializedProjectionIndexer.ListenerSubscription>) - Constructor for class tools.refinery.interpreter.rete.index.MemoryIdentityIndexer
 
MemorylessEvaluatorNode - Class in tools.refinery.interpreter.rete.eval
 
MemorylessEvaluatorNode(ReteContainer, EvaluatorCore) - Constructor for class tools.refinery.interpreter.rete.eval.MemorylessEvaluatorNode
 
memoryNullIndexer - Variable in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
MemoryNullIndexer - Class in tools.refinery.interpreter.rete.index
Defines a trivial indexer that projects the contents of a memory-equipped node to the empty tuple, and can therefore save space.
MemoryNullIndexer(ReteContainer, int, Collection<Tuple>, Supplier, Receiver, List<SpecializedProjectionIndexer.ListenerSubscription>) - Constructor for class tools.refinery.interpreter.rete.index.MemoryNullIndexer
 
mend(CompiledQuery) - Method in class tools.refinery.interpreter.rete.construction.plancompiler.RecursionCutoffPoint
Signals that compilation of the recursive query has terminated, culminating into the given compiled form.
merge(Set<T>) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
merge(T) - Method in interface tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode.MergeableFoldingState
 
merge(FaithfulParallelTimelyColumnAggregatorNode.FoldingState<Domain>) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode.FoldingState
The returned result will never be null, even if the resulting delta set is empty.
merge(FaithfulSequentialTimelyColumnAggregatorNode.FoldingState<Domain, AggregateResult>) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode.FoldingState
The returned result will never be null, even if the resulting delta set is empty.
merge(T, T) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
MessageIndexer - Interface in tools.refinery.interpreter.rete.network.indexer
A message indexer is used by Mailboxes to index their contents.
MessageIndexerFactory<I> - Interface in tools.refinery.interpreter.rete.network.mailbox
A factory used to create message indexers for Mailboxes.
MessageSelector - Interface in tools.refinery.interpreter.rete.network.communication
Subclasses of this interface represent meta data of update messages in Rete.
min(Timestamp) - Method in class tools.refinery.interpreter.rete.network.communication.Timestamp
 
minGroupId - Variable in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
The minimum group id assigned so far
MONITOR_VIOLATION_OF_DIFFERENTIAL_DATAFLOW_TIMESTAMPS - Static variable in class tools.refinery.interpreter.rete.util.Options
Enable for internal debugging of message delivery in TimelyCommunicationGroups; catches cases when there is a violation of increasing timestamps during message delivery within a group.
MONITOR_VIOLATION_OF_RETE_NODEGROUP_TOPOLOGICAL_SORTING - Static variable in class tools.refinery.interpreter.rete.util.Options
Enable for internal debugging of Rete communication scheme; catches cases where the topological sort is violated by a message sent "backwards"
MONOTONE - Enum constant in enum class tools.refinery.interpreter.rete.network.communication.PhasedSelector
Inserts and delete-insert monotone change pairs
monotoneBuffer - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
monotoneQueue - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 

N

NAME_MAPPER - Static variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
negative - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode.CumulativeAggregate
 
negative - Variable in class tools.refinery.interpreter.rete.index.ExistenceNode
 
network - Variable in class tools.refinery.interpreter.rete.boundary.ReteBoundary
 
network - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
Network - Class in tools.refinery.interpreter.rete.network
 
Network(int, ReteEngine) - Constructor for class tools.refinery.interpreter.rete.network.Network
 
NetworkComponentDetector - Class in tools.refinery.interpreter.rete.network.communication
 
NetworkComponentDetector(Logger, Graph<Node>) - Constructor for class tools.refinery.interpreter.rete.network.communication.NetworkComponentDetector
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIndexer
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.aggregation.LeftJoinNode
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.eval.RelationEvaluatorNode
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.index.ExistenceNode
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.index.StandardIndexer
 
networkStructureChanged() - Method in interface tools.refinery.interpreter.rete.network.NetworkStructureChangeSensitiveNode
At the time of the invocation, the dependency graph has already been updated.
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.network.StandardNode
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.single.RepresentativeElectionNode
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
networkStructureChanged() - Method in class tools.refinery.interpreter.rete.single.TransitiveClosureNode
 
NetworkStructureChangeSensitiveLogic() - Constructor for class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.NetworkStructureChangeSensitiveLogic
 
NetworkStructureChangeSensitiveLogic() - Constructor for class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode.NetworkStructureChangeSensitiveLogic
 
NetworkStructureChangeSensitiveLogic() - Constructor for class tools.refinery.interpreter.rete.index.DualInputNode.NetworkStructureChangeSensitiveLogic
 
NetworkStructureChangeSensitiveLogic() - Constructor for class tools.refinery.interpreter.rete.index.IndexerWithMemory.NetworkStructureChangeSensitiveLogic
 
NetworkStructureChangeSensitiveNode - Interface in tools.refinery.interpreter.rete.network
Nodes implementing this interface are sensitive to changes in the dependency graph maintained by the CommunicationTracker.
NEUTRAL - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
NEUTRAL_INITIAL_TIMELINE - Static variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
NEVER - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.NodeSharingOption
 
newResult - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode.FoldingState
 
nextId - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
Node - Interface in tools.refinery.interpreter.rete.network
A node of a rete network, should be uniquely identified by network and nodeId.
NodeComparator - Class in tools.refinery.interpreter.rete.network.communication
 
NodeComparator(Map<Node, Integer>) - Constructor for class tools.refinery.interpreter.rete.network.communication.NodeComparator
 
nodeDeleted(T) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
nodeDeleted(V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
nodeDeleted(V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
nodeDeleted(V) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.PKAlg
 
nodeDeleted(V) - Method in class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
nodeDeleted(V) - Method in interface tools.refinery.interpreter.rete.itc.igraph.IGraphObserver
Used to notify when a node is deleted from the graph.
nodeFactory - Variable in class tools.refinery.interpreter.rete.network.Network
 
nodeId - Variable in class tools.refinery.interpreter.rete.network.BaseNode
 
nodeInserted(T) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
nodeInserted(V) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
nodeInserted(V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
nodeInserted(V) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.PKAlg
 
nodeInserted(V) - Method in class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
nodeInserted(V) - Method in interface tools.refinery.interpreter.rete.itc.igraph.IGraphObserver
Used to notify when a node is inserted into the graph.
nodeMap - Variable in class tools.refinery.interpreter.rete.network.communication.NodeComparator
 
nodeProvisioner - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
NodeProvisioner - Class in tools.refinery.interpreter.rete.network
Stores the internal parts of a rete network.
NodeProvisioner(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.network.NodeProvisioner
PRE: NodeFactory, ConnectionFactory must exist
nodesById - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
nodeSharingOption - Static variable in class tools.refinery.interpreter.rete.util.Options
 
NON_NEUTRAL_INITIAL_TIMELINE - Static variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
notifyEvaluator(Address<? extends Receiver>, Tuple) - Method in class tools.refinery.interpreter.rete.boundary.ReteBoundary
 
notifyHasMessage(Mailbox, MessageSelector) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
notifyHasMessage(Mailbox, MessageSelector) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.RecursiveCommunicationGroup
 
notifyHasMessage(Mailbox, MessageSelector) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.SingletonCommunicationGroup
 
notifyHasMessage(Mailbox, MessageSelector) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationGroup
 
notifyIndexerUpdate(Direction, Tuple, Tuple, boolean, Timestamp) - Method in interface tools.refinery.interpreter.rete.index.IndexerListener
Notifies recipient that the indexer has just received an update.
notifyIndexerUpdate(Direction, Tuple, Tuple, boolean, Timestamp) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyIndexerListenerProxy
 
notifyLostAllMessages(Mailbox, MessageSelector) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
notifyLostAllMessages(Mailbox, MessageSelector) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.RecursiveCommunicationGroup
 
notifyLostAllMessages(Mailbox, MessageSelector) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.SingletonCommunicationGroup
 
notifyLostAllMessages(Mailbox, MessageSelector) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationGroup
 
notifyTcObservers(Set<V>, Set<V>, Direction) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
Call this method to notify the observers of the transitive closure relation.
notifyToObservers(T, T, T) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
notifyToObservers(T, T, Direction) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
notifyUpdate(DualInputNode.Side, Direction, Tuple, Tuple, boolean, Timestamp) - Method in class tools.refinery.interpreter.rete.index.DualInputNode.NetworkStructureChangeSensitiveLogic
Abstract handler for update event.
NullIndexer - Class in tools.refinery.interpreter.rete.index
Defines an abstract trivial indexer that projects the contents of some stateful node to the empty tuple, and can therefore save space.
NullIndexer(ReteContainer, int, Supplier, Node, List<SpecializedProjectionIndexer.ListenerSubscription>) - Constructor for class tools.refinery.interpreter.rete.index.NullIndexer
 
nullMask - Variable in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
nullSignature - Static variable in class tools.refinery.interpreter.rete.index.NullIndexer
 
nullSingleton - Static variable in class tools.refinery.interpreter.rete.index.NullIndexer
 
numberOfLocalContainers - Static variable in class tools.refinery.interpreter.rete.util.Options
 

O

of(N) - Static method in class tools.refinery.interpreter.rete.remote.Address
Address of local node (use only for containers in the same VM!)
OFF - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.FunctionalDependencyOption
 
OFF - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.PlanTrimOption
 
oldResult - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode.FoldingState
 
OnetimeIndexer - Class in tools.refinery.interpreter.rete.index
 
OnetimeIndexer(ReteContainer, TupleMask) - Constructor for class tools.refinery.interpreter.rete.index.OnetimeIndexer
 
operator - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
OPPORTUNISTIC - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.FunctionalDependencyOption
 
OPPORTUNISTIC - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.PlanTrimOption
 
opposite() - Method in enum class tools.refinery.interpreter.rete.index.DualInputNode.Side
 
Options - Class in tools.refinery.interpreter.rete.util
Feature switches.
Options() - Constructor for class tools.refinery.interpreter.rete.util.Options
 
Options.BuilderMethod - Enum Class in tools.refinery.interpreter.rete.util
 
Options.FunctionalDependencyOption - Enum Class in tools.refinery.interpreter.rete.util
 
Options.InjectivityStrategy - Enum Class in tools.refinery.interpreter.rete.util
 
Options.NodeSharingOption - Enum Class in tools.refinery.interpreter.rete.util
 
Options.PlanTrimOption - Enum Class in tools.refinery.interpreter.rete.util
 
OrderingCompareAgent<T> - Class in tools.refinery.interpreter.rete.util
Comparing agent for an ordering.
OrderingCompareAgent(T, T) - Constructor for class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
OrderingHeuristics - Class in tools.refinery.interpreter.rete.construction.basiclinear
 
OrderingHeuristics(SubPlan, IQueryMetaContext) - Constructor for class tools.refinery.interpreter.rete.construction.basiclinear.OrderingHeuristics
 
outputCache - Variable in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
OutputCachingEvaluatorNode - Class in tools.refinery.interpreter.rete.eval
An evaluator node that caches the evaluation result.
OutputCachingEvaluatorNode(ReteContainer, EvaluatorCore) - Constructor for class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
OutputCachingEvaluatorNode.NetworkStructureChangeSensitiveLogic - Class in tools.refinery.interpreter.rete.eval
 

P

packResult(Tuple, Object) - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
 
PARALLEL - Enum constant in enum class tools.refinery.interpreter.rete.matcher.TimelyConfiguration.AggregatorArchitecture
Aggregands are copied over from lower timestamps to higher timestamps.
parallelExecutionEnabled - Variable in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
ParameterProjectionTrace - Class in tools.refinery.interpreter.rete.traceability
The recipe projects the finished results of a PBody onto the list of parameters.
ParameterProjectionTrace(PBody, ReteNodeRecipe, Collection<? extends RecipeTraceInfo>) - Constructor for class tools.refinery.interpreter.rete.traceability.ParameterProjectionTrace
 
ParameterProjectionTrace(PBody, ReteNodeRecipe, RecipeTraceInfo...) - Constructor for class tools.refinery.interpreter.rete.traceability.ParameterProjectionTrace
 
parent - Variable in class tools.refinery.interpreter.rete.index.StandardIndexer
 
parent - Variable in class tools.refinery.interpreter.rete.misc.SimpleReceiver
 
parent - Variable in class tools.refinery.interpreter.rete.single.SingleInputNode
 
parentPlansOfReceiver - Variable in class tools.refinery.interpreter.rete.boundary.ReteBoundary
SubPlans of parent nodes that have the key node as their child.
parents - Variable in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
PatternTraceInfo - Interface in tools.refinery.interpreter.rete.traceability
One kind of trace marker that merely establishes the pattern for which the node was built.
peekExistingResultProvider(PQuery) - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
peekProjectionIndexer(RecipeTraceInfo, TupleMask) - Method in class tools.refinery.interpreter.rete.network.NodeProvisioner
 
performEvaluation(Tuple) - Method in class tools.refinery.interpreter.rete.eval.EvaluatorCore.FunctionEvaluatorCore
 
performEvaluation(Tuple) - Method in class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
performEvaluation(Tuple) - Method in class tools.refinery.interpreter.rete.eval.EvaluatorCore.PredicateEvaluatorCore
 
PhasedSelector - Enum Class in tools.refinery.interpreter.rete.network.communication
A default message selector that can be used to associate phases to messages.
PKAlg<V> - Class in tools.refinery.interpreter.rete.itc.alg.misc.scc
 
PKAlg(IGraphDataSource<V>) - Constructor for class tools.refinery.interpreter.rete.itc.alg.misc.scc.PKAlg
 
plan(PBody, Logger, IQueryMetaContext) - Method in class tools.refinery.interpreter.rete.construction.basiclinear.BasicLinearLayout
 
plan(PBody, Logger, IQueryMetaContext) - Method in class tools.refinery.interpreter.rete.construction.quasitree.QuasiTreeLayout
 
PlanningTrace - Class in tools.refinery.interpreter.rete.traceability
A trace marker associating a Rete recipe with a query SubPlan.
PlanningTrace(SubPlan, List<PVariable>, ReteNodeRecipe, Collection<? extends RecipeTraceInfo>) - Constructor for class tools.refinery.interpreter.rete.traceability.PlanningTrace
 
PlanningTrace(SubPlan, List<PVariable>, ReteNodeRecipe, RecipeTraceInfo...) - Constructor for class tools.refinery.interpreter.rete.traceability.PlanningTrace
 
planTrimOption - Static variable in class tools.refinery.interpreter.rete.util.Options
 
PosetAwareMailbox - Class in tools.refinery.interpreter.rete.network.mailbox.timeless
A monotonicity aware mailbox implementation.
PosetAwareMailbox(PosetAwareReceiver, ReteContainer) - Constructor for class tools.refinery.interpreter.rete.network.mailbox.timeless.PosetAwareMailbox
 
PosetAwareReceiver - Interface in tools.refinery.interpreter.rete.network
 
posetComparator - Variable in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
posetComparator - Variable in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
OPTIONAL ELEMENTS - ONLY PRESENT IF MONOTONICITY INFO WAS AVAILABLE
posetMask - Variable in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.PosetTriplet
 
posetMask - Variable in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
OPTIONAL ELEMENTS - ONLY PRESENT IF MONOTONICITY INFO WAS AVAILABLE
PosetTriplet() - Constructor for class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper.PosetTriplet
 
positive - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode.CumulativeAggregate
 
posMapping - Variable in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
posMapping - Variable in class tools.refinery.interpreter.rete.single.DefaultProductionNode
 
posMapping - Variable in class tools.refinery.interpreter.rete.single.TimelyProductionNode
 
posMapping - Variable in class tools.refinery.interpreter.rete.traceability.PlanningTrace
 
postMessage(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
postMessage(Direction, Tuple, Timestamp) - Method in interface tools.refinery.interpreter.rete.network.mailbox.Mailbox
Posts a new message to this mailbox.
postMessage(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
postMessage(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
postMessage(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.PosetAwareMailbox
 
postMessage(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.UpdateSplittingMailbox
 
postMessage(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
postProcessGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
This hook allows concrete tracker implementations to perform tracker-specific post processing on groups.
postProcessGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.TimelessCommunicationTracker
 
postProcessGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationTracker
 
postProcessNode(Node) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
This hook allows concrete tracker implementations to perform tracker-specific post processing on nodes (cf.
postProcessNode(Node) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.TimelessCommunicationTracker
 
postProcessNode(Node) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationTracker
 
PredicateEvaluatorCore(Logger, IExpressionEvaluator, Map<String, Integer>, int) - Constructor for class tools.refinery.interpreter.rete.eval.EvaluatorCore.PredicateEvaluatorCore
 
preferFalse(boolean, boolean) - Static method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
preferLess(Comparable<U>, U) - Static method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
preferLess(U, U, Comparator<U>) - Static method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
preferMore(Comparable<U>, U) - Static method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
preferMore(U, U, Comparator<U>) - Static method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
preferTrue(boolean, boolean) - Static method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
preprocessor - Variable in class tools.refinery.interpreter.rete.network.communication.timely.TimelyIndexerListenerProxy
 
preprocessor - Variable in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
prettyPrintTraceInfoPatternList() - Method in class tools.refinery.interpreter.rete.eval.AbstractEvaluatorNode
 
prettyPrintTraceInfoPatternList() - Method in interface tools.refinery.interpreter.rete.eval.IEvaluatorNode
 
prettyPrintTuple(Tuple) - Method in class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
PRIMARY - Enum constant in enum class tools.refinery.interpreter.rete.index.DualInputNode.Side
 
primarySlot - Variable in class tools.refinery.interpreter.rete.index.DualInputNode
Holds the primary input slot of this node.
printPaths(List<Deque<V>>) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.DFSPathFinder
 
prioritizeConstantFiltering - Static variable in class tools.refinery.interpreter.rete.util.ReteHintOptions
 
process(Timestamp) - Method in enum class tools.refinery.interpreter.rete.network.communication.timely.TimestampTransformation
 
productionNode - Variable in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
ProductionNode - Interface in tools.refinery.interpreter.rete.network
Interface intended for nodes containing complete matches.
productionNodeTrace - Variable in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
ProjectionIndexer - Interface in tools.refinery.interpreter.rete.index
An iterable indexer that receives updates from a node, and groups received tuples intact, i.e.
projectionSize(TupleMask) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
Counts the number of distinct tuples attainable from the match set by projecting match tuples according to the given mask.
propagate(Direction, Tuple, boolean) - Method in class tools.refinery.interpreter.rete.index.TransitiveClosureNodeIndexer
 
propagate(Direction, Tuple, AggregateResult, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
propagate(Direction, Tuple, Tuple, boolean, Timestamp) - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer
 
propagate(Direction, Tuple, Tuple, boolean, Timestamp) - Method in class tools.refinery.interpreter.rete.index.StandardIndexer
 
propagate(Direction, Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer
 
propagate(Direction, Tuple, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIndexer
 
propagate(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer.ListenerSubscription
Call this from parent node.
propagate(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
propagateAggregateResultUpdate(Tuple, AggregateResult, AggregateResult, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
propagateFromIndexerToSupplierParent() - Method in class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
 
propagateFromIndexerToSupplierParent() - Method in interface tools.refinery.interpreter.rete.traceability.TraceInfo
 
propagateFromStandardNodeToSupplierParent() - Method in class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
 
propagateFromStandardNodeToSupplierParent() - Method in interface tools.refinery.interpreter.rete.traceability.TraceInfo
 
propagateIterableUpdate(Direction, Iterable<Tuple>, Timestamp) - Method in class tools.refinery.interpreter.rete.eval.AbstractEvaluatorNode
 
propagatePullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.single.SingleInputNode
To be called by derived classes and ReteContainer.
propagatePullIntoWithTimestamp(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.single.SingleInputNode
To be called by derived classes and ReteContainer.
propagateToIndexerParent() - Method in class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
 
propagateToIndexerParent() - Method in interface tools.refinery.interpreter.rete.traceability.TraceInfo
 
propagateToListener(IndexerListener, Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.index.IdentityIndexer
 
propagateToListener(IndexerListener, Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.index.NullIndexer
 
propagateToListener(IndexerListener, Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer
 
propagateToProductionNodeParentAlso() - Method in class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
 
propagateToProductionNodeParentAlso() - Method in interface tools.refinery.interpreter.rete.traceability.TraceInfo
 
propagateUpdate(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.network.StandardNode
 
propagateWithChecks(Tuple, Timestamp, AggregateResult, AggregateResult, AggregateResult, AggregateResult) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
proxifyIndexerListener(Node, IndexerListener) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
Creates a proxy for the given IndexerListener for the given requester Node.
proxifyIndexerListener(Node, IndexerListener) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.TimelessCommunicationTracker
 
proxifyIndexerListener(Node, IndexerListener) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationTracker
 
proxifyMailbox(Node, Mailbox) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
Creates a proxy for the given Mailbox for the given requester Node.
proxifyMailbox(Node, Mailbox) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.TimelessCommunicationTracker
 
proxifyMailbox(Node, Mailbox) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationTracker
 
pruneResult - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer
 
PSYSTEM_BASIC_LINEAR - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.BuilderMethod
 
PSYSTEM_QUASITREE - Enum constant in enum class tools.refinery.interpreter.rete.util.Options.BuilderMethod
 
pullContents(Supplier, boolean) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Retrieves a safe copy of the contents of a supplier.
pullContentsWithTimeline(Supplier, boolean) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.LeftJoinNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.eval.MemorylessEvaluatorNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode.NetworkStructureChangeSensitiveLogic
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.eval.RelationEvaluatorNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.index.DualInputNode.NetworkStructureChangeSensitiveLogic
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.misc.ConstantNode
 
pullInto(Collection<Tuple>, boolean) - Method in interface tools.refinery.interpreter.rete.network.Supplier
Pulls the contents of this object in this particular moment into a target collection.
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.remote.RemoteReceiver
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.remote.RemoteSupplier
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.single.DiscriminatorBucketNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.single.FilterNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.single.RepresentativeElectionNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.single.TransformerNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.single.TransitiveClosureNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.single.TransparentNode
 
pullInto(Collection<Tuple>, boolean) - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
pullIntoFiltered(Collection<Tuple>, Object, boolean) - Method in class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.IndexerBasedAggregatorNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.LeftJoinNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.eval.MemorylessEvaluatorNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode.NetworkStructureChangeSensitiveLogic
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.eval.RelationEvaluatorNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.index.DualInputNode.NetworkStructureChangeSensitiveLogic
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.misc.ConstantNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in interface tools.refinery.interpreter.rete.network.Supplier
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.remote.RemoteReceiver
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.remote.RemoteSupplier
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.single.DiscriminatorBucketNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.single.FilterNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.single.RepresentativeElectionNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.single.TransformerNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.single.TransitiveClosureNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.single.TransparentNode
 
pullIntoWithTimeline(Map<Tuple, Timeline<Timestamp>>, boolean) - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
pullIntoWithTimestampFiltered(Map<Tuple, Timeline<Timestamp>>, Object, boolean) - Method in class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
pullPropagatedContents(SingleInputNode, boolean) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Retrieves the contents of a SingleInputNode's parentage.
pullPropagatedContentsWithTimestamp(SingleInputNode, boolean) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Retrieves the timestamp-aware contents of a SingleInputNode's parentage.
put(Tuple, ValueType) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
putAll(Map<? extends Tuple, ? extends ValueType>) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 

Q

QuasiTreeLayout - Class in tools.refinery.interpreter.rete.construction.quasitree
Layout ideas: see https://bugs.eclipse.org/bugs/show_bug.cgi?id=398763
QuasiTreeLayout(IQueryBackendContext) - Constructor for class tools.refinery.interpreter.rete.construction.quasitree.QuasiTreeLayout
 
QuasiTreeLayout(IQueryBackendContext, IQueryBackendHintProvider) - Constructor for class tools.refinery.interpreter.rete.construction.quasitree.QuasiTreeLayout
 
QuasiTreeLayout.Scaffold - Class in tools.refinery.interpreter.rete.construction.quasitree
 
queue - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
queue - Variable in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 

R

reachableSources(IBiDirectionalGraphDataSource<V>, V) - Static method in class tools.refinery.interpreter.rete.itc.alg.misc.bfs.BFS
 
reachableTargets(IGraphDataSource<V>, V) - Static method in class tools.refinery.interpreter.rete.itc.alg.misc.bfs.BFS
 
receiver - Variable in class tools.refinery.interpreter.rete.network.delayed.DelayedCommand
 
receiver - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
receiver - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
receiver - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
receiver - Variable in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
Receiver - Interface in tools.refinery.interpreter.rete.network
ALL METHODS: FOR INTERNAL USE ONLY; ONLY INVOKE FROM ReteContainer
RecipeTraceInfo - Class in tools.refinery.interpreter.rete.traceability
A trace marker that indicates the recipe for which the node was built.
RecipeTraceInfo(ReteNodeRecipe, Collection<? extends RecipeTraceInfo>) - Constructor for class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
 
RecipeTraceInfo(ReteNodeRecipe, RecipeTraceInfo...) - Constructor for class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
 
reconstructQueueContents(Set<CommunicationGroup>) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
This method is responsible for reconstructing the active queue contents after the network structure has changed.
reconstructQueueContents(Set<CommunicationGroup>) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.TimelessCommunicationTracker
 
reconstructQueueContents(Set<CommunicationGroup>) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationTracker
 
RecursionCutoffPoint - Class in tools.refinery.interpreter.rete.construction.plancompiler
In a recursive query structure, query composition references can be cut off so that the remaining structure is DAG.
RecursionCutoffPoint(PQuery, QueryEvaluationHint, IQueryMetaContext, boolean, TimelyConfiguration) - Constructor for class tools.refinery.interpreter.rete.construction.plancompiler.RecursionCutoffPoint
 
RecursiveCommunicationGroup - Class in tools.refinery.interpreter.rete.network.communication.timeless
A communication group representing either a single node where the node is a monotonicity aware one or a set of nodes that form an SCC.
RecursiveCommunicationGroup(CommunicationTracker, Node, int) - Constructor for class tools.refinery.interpreter.rete.network.communication.timeless.RecursiveCommunicationGroup
 
rederivableMemory - Variable in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
rederivableMemory - Variable in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
RederivableNode - Interface in tools.refinery.interpreter.rete.network
A rederivable node can potentially re-derive tuples after the Rete network has finished the delivery of messages.
rederiveOne() - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
rederiveOne() - Method in interface tools.refinery.interpreter.rete.network.RederivableNode
The method is called by the ReteContainer to re-derive tuples after the normal messages have been delivered and consumed.
rederiveOne() - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
refreshIndexerGroupCache() - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
registerClearable(Clearable) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Registers a pattern memory into the rete network.
registerDependency(Node, Node) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
Registers the dependency that the target Node depends on the source Node.
registerNode(Node) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Registers a node into the rete network (should be called by constructor).
ReinitializedNode - Interface in tools.refinery.interpreter.rete.network
 
reinitializeWith(Collection<Tuple>) - Method in interface tools.refinery.interpreter.rete.network.ReinitializedNode
 
reinitializeWith(Collection<Tuple>) - Method in class tools.refinery.interpreter.rete.single.RepresentativeElectionNode
 
reinitializeWith(Collection<Tuple>) - Method in class tools.refinery.interpreter.rete.single.TransitiveClosureNode
Initializes the graph data source with the given collection of tuples.
RelationEvaluatorNode - Class in tools.refinery.interpreter.rete.eval
A node that operates in batch-style (see
invalid reference
Receiver#doesProcessUpdatesInBatch()
and evaluates arbitrary Java logic represented by an IRelationEvaluator on the input relations.
RelationEvaluatorNode(ReteContainer, IRelationEvaluator) - Constructor for class tools.refinery.interpreter.rete.eval.RelationEvaluatorNode
 
RelationEvaluatorNode.BatchingReceiver - Class in tools.refinery.interpreter.rete.eval
 
releaseOnetimeIndexers - Static variable in class tools.refinery.interpreter.rete.util.Options
 
remotePosMapping(Address<? extends ProductionNode>) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Proxies for the getPosMapping() of Production nodes.
remotePull(boolean) - Method in class tools.refinery.interpreter.rete.remote.RemoteReceiver
 
remotePull(Address<? extends Supplier>, boolean) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Retrieves the contents of a supplier for a remote caller.
RemoteReceiver - Class in tools.refinery.interpreter.rete.remote
This node delivers updates to a remote recipient; no updates are propagated further in this network.
RemoteReceiver(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.remote.RemoteReceiver
 
RemoteSupplier - Class in tools.refinery.interpreter.rete.remote
This node receives updates from a remote supplier; no local updates are expected.
RemoteSupplier(ReteContainer, RemoteReceiver) - Constructor for class tools.refinery.interpreter.rete.remote.RemoteSupplier
 
remove(Object) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
remove(Object) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
removeAll(Collection<?>) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
removeChild(Receiver) - Method in class tools.refinery.interpreter.rete.network.StandardNode
 
removeChild(Receiver) - Method in interface tools.refinery.interpreter.rete.network.Supplier
removes a receiver
removeChild(Receiver) - Method in class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
removeParent(Supplier) - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
removeParent(Supplier) - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
removeParent(Supplier) - Method in class tools.refinery.interpreter.rete.misc.SimpleReceiver
 
removeParent(Supplier) - Method in interface tools.refinery.interpreter.rete.network.Receiver
removes a parent
removeParent(Supplier) - Method in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
removeParent(Supplier) - Method in class tools.refinery.interpreter.rete.single.SingleInputNode
 
removeRederivable(RederivableNode) - Method in class tools.refinery.interpreter.rete.network.communication.timeless.RecursiveCommunicationGroup
 
removeUpdateListener(Object) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
reorderMask - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer
 
reportedClocks - Variable in class tools.refinery.interpreter.rete.network.Network
 
representative - Variable in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
RepresentativeElectionAlgorithm<T> - Class in tools.refinery.interpreter.rete.itc.alg.representative
 
RepresentativeElectionAlgorithm(Graph<T>) - Constructor for class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
RepresentativeElectionAlgorithm.Factory - Interface in tools.refinery.interpreter.rete.itc.alg.representative
 
RepresentativeElectionNode - Class in tools.refinery.interpreter.rete.single
 
RepresentativeElectionNode(ReteContainer, RepresentativeElectionAlgorithm.Factory) - Constructor for class tools.refinery.interpreter.rete.single.RepresentativeElectionNode
 
RepresentativeObserver<T> - Interface in tools.refinery.interpreter.rete.itc.alg.representative
 
representatives - Variable in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
reset() - Method in class tools.refinery.interpreter.rete.construction.plancompiler.ReteRecipeCompiler
Clears internal state
reset() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
Resets the engine to an after-initialization phase
RESET - Enum constant in enum class tools.refinery.interpreter.rete.network.communication.timely.TimestampTransformation
 
resolveLocal(Address<N>) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Returns an addressed node at this container.
result - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode.CumulativeAggregate
 
resultPositionInSignature - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode.AggregatorOuterIdentityIndexer
 
ResumableNode - Interface in tools.refinery.interpreter.rete.network.communication.timely
Nodes that implement this interface can resume folding of their states when instructed during timely evaluation.
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode.NetworkStructureChangeSensitiveLogic
 
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory.NetworkStructureChangeSensitiveLogic
 
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
resumeAt(Timestamp) - Method in interface tools.refinery.interpreter.rete.network.communication.timely.ResumableNode
When called, the folding of the state shall be resumed at the given timestamp.
resumeAt(Timestamp) - Method in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
retainAll(Collection<?>) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
ReteBackendFactory - Class in tools.refinery.interpreter.rete.matcher
 
ReteBackendFactory() - Constructor for class tools.refinery.interpreter.rete.matcher.ReteBackendFactory
Deprecated.
Use the static ReteBackendFactory.INSTANCE field instead
ReteBackendFactoryProvider - Class in tools.refinery.interpreter.rete.matcher
 
ReteBackendFactoryProvider() - Constructor for class tools.refinery.interpreter.rete.matcher.ReteBackendFactoryProvider
 
ReteBoundary - Class in tools.refinery.interpreter.rete.boundary
Responsible for the storage, maintenance and communication of the nodes of the network that are accessible form the outside for various reasons.
ReteBoundary(ReteEngine) - Constructor for class tools.refinery.interpreter.rete.boundary.ReteBoundary
Prerequisite: engine has its network and framework fields initialized
reteContainer - Variable in class tools.refinery.interpreter.rete.network.BaseNode
 
ReteContainer - Class in tools.refinery.interpreter.rete.network
 
ReteContainer(Network, boolean) - Constructor for class tools.refinery.interpreter.rete.network.ReteContainer
 
ReteEngine - Class in tools.refinery.interpreter.rete.matcher
 
ReteEngine(IQueryBackendContext, int) - Constructor for class tools.refinery.interpreter.rete.matcher.ReteEngine
 
ReteEngine(IQueryBackendContext, int, boolean, TimelyConfiguration) - Constructor for class tools.refinery.interpreter.rete.matcher.ReteEngine
 
ReteHintOptions - Class in tools.refinery.interpreter.rete.util
Provides key objects (of type QueryHintOption) for QueryEvaluationHints.
reteNet - Variable in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
RetePatternBuildException - Exception Class in tools.refinery.interpreter.rete.construction
A problem has occurred during the construction of the RETE net.
RetePatternBuildException(String, String[], String, Object) - Constructor for exception class tools.refinery.interpreter.rete.construction.RetePatternBuildException
 
RetePatternBuildException(String, String[], String, Object, Throwable) - Constructor for exception class tools.refinery.interpreter.rete.construction.RetePatternBuildException
 
RetePatternMatcher - Class in tools.refinery.interpreter.rete.matcher
 
RetePatternMatcher(ReteEngine, RecipeTraceInfo) - Constructor for class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
ReteRecipeCompiler - Class in tools.refinery.interpreter.rete.construction.plancompiler
Compiles queries and query plans into Rete recipes, traced by respectively a CompiledQuery or CompiledSubPlan.
ReteRecipeCompiler(IQueryPlannerStrategy, Logger, IQueryMetaContext, IQueryCacheContext, IQueryBackendHintProvider, QueryAnalyzer) - Constructor for class tools.refinery.interpreter.rete.construction.plancompiler.ReteRecipeCompiler
 
ReteRecipeCompiler(IQueryPlannerStrategy, Logger, IQueryMetaContext, IQueryCacheContext, IQueryBackendHintProvider, QueryAnalyzer, boolean, TimelyConfiguration) - Constructor for class tools.refinery.interpreter.rete.construction.plancompiler.ReteRecipeCompiler
 
reteThreads - Static variable in class tools.refinery.interpreter.rete.matcher.ReteBackendFactory
EXPERIMENTAL
reteThreads - Variable in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
retrieveOpposites(DualInputNode.Side, Tuple) - Method in class tools.refinery.interpreter.rete.index.DualInputNode
Helper: retrieves all stored substitutions from the opposite side memory.
run() - Method in class tools.refinery.interpreter.rete.construction.quasitree.QuasiTreeLayout.Scaffold
 
run() - Method in class tools.refinery.interpreter.rete.network.delayed.DelayedCommand
 
runtimeContext - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
runtimeContext - Variable in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
runtimeContext - Variable in class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
runtimeContext - Variable in class tools.refinery.interpreter.rete.matcher.ReteEngine
 

S

SCC<V> - Class in tools.refinery.interpreter.rete.itc.alg.misc.scc
Efficient algorithms to compute the Strongly Connected Components in a directed graph.
sccId - Static variable in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCC
 
SCCProperty - Class in tools.refinery.interpreter.rete.itc.alg.misc.scc
 
SCCProperty(int, int) - Constructor for class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCProperty
 
SCCResult<V> - Class in tools.refinery.interpreter.rete.itc.alg.misc.scc
 
SCCResult(Set<Set<V>>, IGraphDataSource<V>) - Constructor for class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCResult
 
sccs - Variable in class tools.refinery.interpreter.rete.itc.alg.incscc.IncSCCAlg
 
SECONDARY - Enum constant in enum class tools.refinery.interpreter.rete.index.DualInputNode.Side
 
secondarySlot - Variable in class tools.refinery.interpreter.rete.index.DualInputNode
Holds the secondary input slot of this node.
sendConstructionUpdate(Address<? extends Receiver>, Direction, Tuple) - Method in class tools.refinery.interpreter.rete.network.Network
Sends an update message to the receiver node, indicating a newly found or lost partial matching.
sendConstructionUpdates(Address<? extends Receiver>, Direction, Collection<Tuple>) - Method in class tools.refinery.interpreter.rete.network.Network
Sends multiple update messages atomically to the receiver node, indicating a newly found or lost partial matching.
sendExternalUpdate(Address<? extends Receiver>, Direction, Tuple) - Method in class tools.refinery.interpreter.rete.network.Network
Sends an update message to the receiver node, indicating a newly found or lost partial matching.
sendUpdateToRemoteAddress(Address<? extends Receiver>, Direction, Tuple) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Sends an update message to a node in a different container.
SEQUENTIAL - Enum constant in enum class tools.refinery.interpreter.rete.matcher.TimelyConfiguration.AggregatorArchitecture
Aggregands are only present at the timestamp where they are inserted at.
setAdapter(Mailbox) - Method in interface tools.refinery.interpreter.rete.network.mailbox.AdaptableMailbox
 
setAdapter(Mailbox) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
setAdapter(Mailbox) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.UpdateSplittingMailbox
 
setComparatorAndReorderMailboxes(Comparator<Node>) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationGroup
Sets the Comparator to be used to order the Mailboxes at a given Timestamp in the mailbox queue.
setCompiler(ReteRecipeCompiler) - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
setComplementerSecondaryMask(TupleMask) - Method in class tools.refinery.interpreter.rete.index.DualInputNode
 
setContainer(ReteContainer) - Method in class tools.refinery.interpreter.rete.remote.Address
 
setCurrentGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
setCurrentGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
setCurrentGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
setCurrentGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
setCurrentGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
setCurrentGroup(CommunicationGroup) - Method in interface tools.refinery.interpreter.rete.network.IGroupable
Sets the current group of the mailbox
setCurrentGroup(CommunicationGroup) - Method in interface tools.refinery.interpreter.rete.network.mailbox.Mailbox
Sets the CommunicationGroup that the receiver of this mailbox is associated with.
setCurrentGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
setCurrentGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
setCurrentGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
setCurrentGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
setCurrentGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
setCurrentGroup(CommunicationGroup) - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
setFallThrough(boolean) - Method in interface tools.refinery.interpreter.rete.network.mailbox.FallThroughCapableMailbox
 
setFallThrough(boolean) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
setIndex(int) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCProperty
 
setLowlink(int) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.scc.SCCProperty
 
setMask(TupleMask) - Method in class tools.refinery.interpreter.rete.single.TrimmerNode
 
setNodeCache(T) - Method in class tools.refinery.interpreter.rete.remote.Address
 
setNodeId(Long) - Method in class tools.refinery.interpreter.rete.remote.Address
 
setObserver(RepresentativeObserver<? super T>) - Method in class tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeElectionAlgorithm
 
setSource(V) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.Edge
 
setSource(V) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.Tuple
 
setSplitFlag(boolean) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
setTag(Object) - Method in class tools.refinery.interpreter.rete.network.BaseNode
 
setTag(Object) - Method in interface tools.refinery.interpreter.rete.network.Node
Assigns a descriptive tag to the node
setTarget(V) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.Edge
 
setTarget(V) - Method in class tools.refinery.interpreter.rete.itc.alg.misc.Tuple
 
setTcRelation(CountingTcRelation<V>) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingAlg
 
settle() - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
Waits until the pattern matcher is in a steady state and output can be retrieved.
settle(Runnable) - Method in class tools.refinery.interpreter.rete.matcher.ReteEngine
Waits until the pattern matcher is in a steady state and output can be retrieved.
shadowWithEquivalentRecipe(ReteNodeRecipe) - Method in class tools.refinery.interpreter.rete.traceability.RecipeTraceInfo
 
SimpleReceiver - Class in tools.refinery.interpreter.rete.misc
 
SimpleReceiver(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.misc.SimpleReceiver
 
SingleInputNode - Class in tools.refinery.interpreter.rete.single
 
SingleInputNode(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.single.SingleInputNode
 
SingletonCommunicationGroup - Class in tools.refinery.interpreter.rete.network.communication.timeless
A communication group containing only a single node with a single default mailbox.
SingletonCommunicationGroup(CommunicationTracker, Node, int) - Constructor for class tools.refinery.interpreter.rete.network.communication.timeless.SingletonCommunicationGroup
 
size() - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
size() - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
sourceTupleWidth - Variable in class tools.refinery.interpreter.rete.eval.EvaluatorCore
 
sourceWidth - Variable in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
specializedListeners - Variable in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 
SpecializedProjectionIndexer - Class in tools.refinery.interpreter.rete.index
A specialized projection indexer that can be memory-less (relying on an external source of information).
SpecializedProjectionIndexer(ReteContainer, TupleMask, Supplier, Node, List<SpecializedProjectionIndexer.ListenerSubscription>) - Constructor for class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer
 
SpecializedProjectionIndexer.ListenerSubscription - Class in tools.refinery.interpreter.rete.index
Infrastructure to share subscriptions between specialized indexers of the same parent node.
split - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
StandardIndexer - Class in tools.refinery.interpreter.rete.index
An abstract standard implementation of the Indexer interface, providing common bookkeeping functionality.
StandardIndexer(ReteContainer, TupleMask) - Constructor for class tools.refinery.interpreter.rete.index.StandardIndexer
 
StandardNode - Class in tools.refinery.interpreter.rete.network
Base implementation for a supplier node.
StandardNode(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.network.StandardNode
 
statelessConvert(Tuple) - Method in class tools.refinery.interpreter.rete.misc.DefaultDeltaMonitor
 
statelessConvert(Tuple) - Method in class tools.refinery.interpreter.rete.misc.DeltaMonitor
 
statelessFilter(Tuple) - Method in class tools.refinery.interpreter.rete.misc.DeltaMonitor
Override this method to provide a lightweight, stateless filter on the tuples
storeIfNotNeutral(Tuple, Accumulator, AggregateResult, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyTimelyColumnAggregatorNode
 
storeIfNotNeutral(Tuple, Accumulator, Map<Tuple, Accumulator>) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
Returns true if the accumulator was stored, false otherwise.
StronglyConnectedComponentAlgorithm<T> - Class in tools.refinery.interpreter.rete.itc.alg.representative
 
StronglyConnectedComponentAlgorithm(Graph<T>) - Constructor for class tools.refinery.interpreter.rete.itc.alg.representative.StronglyConnectedComponentAlgorithm
 
structuralChangeLock - Variable in class tools.refinery.interpreter.rete.network.Network
 
subPlan - Variable in class tools.refinery.interpreter.rete.traceability.PlanningTrace
 
subplanToAddressMapping - Variable in class tools.refinery.interpreter.rete.boundary.ReteBoundary
 
subscriptions - Variable in class tools.refinery.interpreter.rete.index.SpecializedProjectionIndexer
 
supplier - Variable in class tools.refinery.interpreter.rete.network.delayed.DelayedCommand
 
Supplier - Interface in tools.refinery.interpreter.rete.network
 
swallowBoolean(boolean) - Method in class tools.refinery.interpreter.rete.util.OrderingCompareAgent
 
swapAndClearAntiMonotone() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 
swapAndClearMonotone() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.AbstractUpdateSplittingMailbox
 

T

tag - Variable in class tools.refinery.interpreter.rete.network.BaseNode
 
taggedChildren - Variable in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
terminationCriteria - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
TieBreaker - Class in tools.refinery.interpreter.rete.construction.quasitree
Class providing comparators for breaking ties somewhat more deterministically.
TimelessCommunicationTracker - Class in tools.refinery.interpreter.rete.network.communication.timeless
Timeless implementation of the communication tracker.
TimelessCommunicationTracker(Logger) - Constructor for class tools.refinery.interpreter.rete.network.communication.timeless.TimelessCommunicationTracker
 
timelines - Variable in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
 
TimelyCommunicationGroup - Class in tools.refinery.interpreter.rete.network.communication.timely
A timely communication group implementation.
TimelyCommunicationGroup(TimelyCommunicationTracker, Node, int, boolean) - Constructor for class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationGroup
 
TimelyCommunicationTracker - Class in tools.refinery.interpreter.rete.network.communication.timely
Timely (DDF) implementation of the CommunicationTracker.
TimelyCommunicationTracker(Logger, TimelyConfiguration) - Constructor for class tools.refinery.interpreter.rete.network.communication.timely.TimelyCommunicationTracker
 
timelyConfiguration - Variable in class tools.refinery.interpreter.rete.matcher.ReteEngine
 
timelyConfiguration - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
TimelyConfiguration - Class in tools.refinery.interpreter.rete.matcher
Configuration of timely evaluation.
TimelyConfiguration(TimelyConfiguration.TimelineRepresentation, TimelyConfiguration.AggregatorArchitecture) - Constructor for class tools.refinery.interpreter.rete.matcher.TimelyConfiguration
 
TimelyConfiguration.AggregatorArchitecture - Enum Class in tools.refinery.interpreter.rete.matcher
 
TimelyConfiguration.TimelineRepresentation - Enum Class in tools.refinery.interpreter.rete.matcher
 
timelyEvaluation - Variable in class tools.refinery.interpreter.rete.construction.plancompiler.ReteRecipeCompiler
 
TimelyIndexerListenerProxy - Class in tools.refinery.interpreter.rete.network.communication.timely
A timely proxy for another IndexerListener, which performs some preprocessing on the differential timestamps before passing it on to the real recipient.
TimelyIndexerListenerProxy(IndexerListener, TimestampTransformation) - Constructor for class tools.refinery.interpreter.rete.network.communication.timely.TimelyIndexerListenerProxy
 
TimelyMailbox - Class in tools.refinery.interpreter.rete.network.mailbox.timely
 
TimelyMailbox(Receiver, ReteContainer) - Constructor for class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
TimelyMailboxProxy - Class in tools.refinery.interpreter.rete.network.communication.timely
A timely proxy for another Mailbox, which performs some preprocessing on the differential timestamps before passing it on to the real recipient.
TimelyMailboxProxy(Mailbox, TimestampTransformation) - Constructor for class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
TimelyMemoryIdentityIndexer - Class in tools.refinery.interpreter.rete.index.timely
 
TimelyMemoryIdentityIndexer(ReteContainer, int, TimelyMemory<Timestamp>, Supplier, Receiver, List<SpecializedProjectionIndexer.ListenerSubscription>) - Constructor for class tools.refinery.interpreter.rete.index.timely.TimelyMemoryIdentityIndexer
 
TimelyMemoryNullIndexer - Class in tools.refinery.interpreter.rete.index.timely
 
TimelyMemoryNullIndexer(ReteContainer, int, TimelyMemory<Timestamp>, Supplier, Receiver, List<SpecializedProjectionIndexer.ListenerSubscription>) - Constructor for class tools.refinery.interpreter.rete.index.timely.TimelyMemoryNullIndexer
 
TimelyProductionNode - Class in tools.refinery.interpreter.rete.single
Differential dataflow implementation of the Production node, based on TimelyUniquenessEnforcerNode.
TimelyProductionNode(ReteContainer, Map<String, Integer>) - Constructor for class tools.refinery.interpreter.rete.single.TimelyProductionNode
 
TimelyReteBackendFactory - Class in tools.refinery.interpreter.rete.matcher
A ReteBackendFactory implementation that creates ReteEngines that use non-scattered timely evaluation.
TimelyReteBackendFactory(TimelyConfiguration) - Constructor for class tools.refinery.interpreter.rete.matcher.TimelyReteBackendFactory
 
TimelyUniquenessEnforcerNode - Class in tools.refinery.interpreter.rete.single
Timely uniqueness enforcer node implementation.
TimelyUniquenessEnforcerNode(ReteContainer, int) - Constructor for class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
Timestamp - Class in tools.refinery.interpreter.rete.network.communication
A timestamp associated with update messages in timely evaluation.
Timestamp(int) - Constructor for class tools.refinery.interpreter.rete.network.communication.Timestamp
 
Timestamp.AllZeroMap<T> - Class in tools.refinery.interpreter.rete.network.communication
A Map implementation that associates the zero timestamp with every key.
TimestampTransformation - Enum Class in tools.refinery.interpreter.rete.network.communication.timely
Values of this enum perform different kind of preprocessing on Timestamps.
toArray() - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
toArray(T[]) - Method in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
tools.refinery.interpreter.rete.aggregation - package tools.refinery.interpreter.rete.aggregation
 
tools.refinery.interpreter.rete.aggregation.timely - package tools.refinery.interpreter.rete.aggregation.timely
 
tools.refinery.interpreter.rete.boundary - package tools.refinery.interpreter.rete.boundary
 
tools.refinery.interpreter.rete.construction - package tools.refinery.interpreter.rete.construction
 
tools.refinery.interpreter.rete.construction.basiclinear - package tools.refinery.interpreter.rete.construction.basiclinear
 
tools.refinery.interpreter.rete.construction.plancompiler - package tools.refinery.interpreter.rete.construction.plancompiler
 
tools.refinery.interpreter.rete.construction.quasitree - package tools.refinery.interpreter.rete.construction.quasitree
 
tools.refinery.interpreter.rete.eval - package tools.refinery.interpreter.rete.eval
 
tools.refinery.interpreter.rete.index - package tools.refinery.interpreter.rete.index
 
tools.refinery.interpreter.rete.index.timely - package tools.refinery.interpreter.rete.index.timely
 
tools.refinery.interpreter.rete.itc.alg.counting - package tools.refinery.interpreter.rete.itc.alg.counting
 
tools.refinery.interpreter.rete.itc.alg.incscc - package tools.refinery.interpreter.rete.itc.alg.incscc
 
tools.refinery.interpreter.rete.itc.alg.misc - package tools.refinery.interpreter.rete.itc.alg.misc
 
tools.refinery.interpreter.rete.itc.alg.misc.bfs - package tools.refinery.interpreter.rete.itc.alg.misc.bfs
 
tools.refinery.interpreter.rete.itc.alg.misc.scc - package tools.refinery.interpreter.rete.itc.alg.misc.scc
 
tools.refinery.interpreter.rete.itc.alg.misc.topsort - package tools.refinery.interpreter.rete.itc.alg.misc.topsort
 
tools.refinery.interpreter.rete.itc.alg.representative - package tools.refinery.interpreter.rete.itc.alg.representative
 
tools.refinery.interpreter.rete.itc.alg.util - package tools.refinery.interpreter.rete.itc.alg.util
 
tools.refinery.interpreter.rete.itc.graphimpl - package tools.refinery.interpreter.rete.itc.graphimpl
 
tools.refinery.interpreter.rete.itc.igraph - package tools.refinery.interpreter.rete.itc.igraph
 
tools.refinery.interpreter.rete.matcher - package tools.refinery.interpreter.rete.matcher
 
tools.refinery.interpreter.rete.misc - package tools.refinery.interpreter.rete.misc
 
tools.refinery.interpreter.rete.network - package tools.refinery.interpreter.rete.network
 
tools.refinery.interpreter.rete.network.communication - package tools.refinery.interpreter.rete.network.communication
 
tools.refinery.interpreter.rete.network.communication.timeless - package tools.refinery.interpreter.rete.network.communication.timeless
 
tools.refinery.interpreter.rete.network.communication.timely - package tools.refinery.interpreter.rete.network.communication.timely
 
tools.refinery.interpreter.rete.network.delayed - package tools.refinery.interpreter.rete.network.delayed
 
tools.refinery.interpreter.rete.network.indexer - package tools.refinery.interpreter.rete.network.indexer
 
tools.refinery.interpreter.rete.network.mailbox - package tools.refinery.interpreter.rete.network.mailbox
 
tools.refinery.interpreter.rete.network.mailbox.timeless - package tools.refinery.interpreter.rete.network.mailbox.timeless
 
tools.refinery.interpreter.rete.network.mailbox.timely - package tools.refinery.interpreter.rete.network.mailbox.timely
 
tools.refinery.interpreter.rete.remote - package tools.refinery.interpreter.rete.remote
 
tools.refinery.interpreter.rete.single - package tools.refinery.interpreter.rete.single
 
tools.refinery.interpreter.rete.traceability - package tools.refinery.interpreter.rete.traceability
 
tools.refinery.interpreter.rete.util - package tools.refinery.interpreter.rete.util
 
TopologicalSorting - Class in tools.refinery.interpreter.rete.itc.alg.misc.topsort
 
toRecipeMask(TupleMask) - Static method in class tools.refinery.interpreter.rete.construction.plancompiler.CompilerHelper
 
toString() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode.CumulativeAggregate
 
toString() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode.FoldingState
 
toString() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode.CumulativeAggregate
 
toString() - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode.FoldingState
 
toString() - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
toString() - Method in class tools.refinery.interpreter.rete.itc.alg.misc.Tuple
 
toString() - Method in class tools.refinery.interpreter.rete.itc.graphimpl.Graph
 
toString() - Method in class tools.refinery.interpreter.rete.itc.igraph.IBiDirectionalWrapper
 
toString() - Method in class tools.refinery.interpreter.rete.network.BaseNode
 
toString() - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
toString() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyIndexerListenerProxy
 
toString() - Method in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
toString() - Method in class tools.refinery.interpreter.rete.network.communication.Timestamp.AllZeroMap
 
toString() - Method in class tools.refinery.interpreter.rete.network.communication.Timestamp
 
toString() - Method in class tools.refinery.interpreter.rete.network.delayed.DelayedCommand
 
toString() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 
toString() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.DefaultMailbox
 
toString() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.PosetAwareMailbox
 
toString() - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.UpdateSplittingMailbox
 
toString() - Method in class tools.refinery.interpreter.rete.network.mailbox.timely.TimelyMailbox
 
toString() - Method in class tools.refinery.interpreter.rete.network.ReteContainer
 
toString() - Method in class tools.refinery.interpreter.rete.remote.Address
 
toString() - Method in class tools.refinery.interpreter.rete.single.DefaultProductionNode
 
toString() - Method in class tools.refinery.interpreter.rete.single.TimelyProductionNode
 
toStringCore() - Method in class tools.refinery.interpreter.rete.index.StandardIndexer
 
toStringCore() - Method in class tools.refinery.interpreter.rete.network.BaseNode
clients should override this to append before the tag / trace indicators
toStringCore() - Method in class tools.refinery.interpreter.rete.single.DiscriminatorBucketNode
 
toStringCore() - Method in class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
TraceInfo - Interface in tools.refinery.interpreter.rete.traceability
Traces the node back to a purpose for which the node was built, to explain why the node is there and what it means.
traceInfos - Variable in class tools.refinery.interpreter.rete.network.BaseNode
 
tracker - Variable in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
tracker - Variable in class tools.refinery.interpreter.rete.network.ReteContainer
 
transform(Tuple) - Method in class tools.refinery.interpreter.rete.matcher.RetePatternMatcher
 
transform(Tuple) - Method in class tools.refinery.interpreter.rete.single.TransformerNode
 
transform(Tuple) - Method in class tools.refinery.interpreter.rete.single.TrimmerNode
 
TransformerNode - Class in tools.refinery.interpreter.rete.single
 
TransformerNode(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.single.TransformerNode
 
TransitiveClosureNode - Class in tools.refinery.interpreter.rete.single
This class represents a transitive closure node in the Rete net.
TransitiveClosureNode(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.single.TransitiveClosureNode
Create a new transitive closure rete node.
TransitiveClosureNodeIndexer - Class in tools.refinery.interpreter.rete.index
 
TransitiveClosureNodeIndexer(TupleMask, IncSCCAlg<Object>, TransitiveClosureNode) - Constructor for class tools.refinery.interpreter.rete.index.TransitiveClosureNodeIndexer
 
TransparentNode - Class in tools.refinery.interpreter.rete.single
Simply propagates everything.
TransparentNode(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.single.TransparentNode
 
TrimmerNode - Class in tools.refinery.interpreter.rete.single
Trims the matchings as specified by a mask.
TrimmerNode(ReteContainer) - Constructor for class tools.refinery.interpreter.rete.single.TrimmerNode
 
TrimmerNode(ReteContainer, TupleMask) - Constructor for class tools.refinery.interpreter.rete.single.TrimmerNode
 
tryFindCounterPart(Tuple, boolean, boolean) - Method in class tools.refinery.interpreter.rete.network.mailbox.timeless.PosetAwareMailbox
 
Tunnel - Interface in tools.refinery.interpreter.rete.network
 
Tuple<V> - Class in tools.refinery.interpreter.rete.itc.alg.misc
 
Tuple(V, V) - Constructor for class tools.refinery.interpreter.rete.itc.alg.misc.Tuple
 
tupleChanged(Object, Object, Direction) - Method in class tools.refinery.interpreter.rete.single.RepresentativeElectionNode
 
tupleChanged(Node, Node, Direction) - Method in class tools.refinery.interpreter.rete.network.communication.NetworkComponentDetector
 
tupleChanged(T, T, Direction) - Method in interface tools.refinery.interpreter.rete.itc.alg.representative.RepresentativeObserver
 
tupleDeleted(Object, Object) - Method in class tools.refinery.interpreter.rete.single.TransitiveClosureNode
 
tupleDeleted(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.CountingListener
 
tupleDeleted(V, V) - Method in interface tools.refinery.interpreter.rete.itc.igraph.ITcObserver
Used to notify when a tuple is deleted from the transitive closure relation.
tupleFromAggregateResult(Tuple, AggregateResult) - Method in class tools.refinery.interpreter.rete.aggregation.AbstractColumnAggregatorNode
 
tupleInserted(Object, Object) - Method in class tools.refinery.interpreter.rete.single.TransitiveClosureNode
 
tupleInserted(V, V) - Method in class tools.refinery.interpreter.rete.itc.alg.incscc.CountingListener
 
tupleInserted(V, V) - Method in interface tools.refinery.interpreter.rete.itc.igraph.ITcObserver
Used to notify when a tuple is inserted into the transitive closure relation.
tupleWidth - Variable in class tools.refinery.interpreter.rete.single.AbstractUniquenessEnforcerNode
 

U

unify(Tuple, Tuple) - Method in class tools.refinery.interpreter.rete.index.DualInputNode
Helper: unifies a left and right partial matching.
unify(DualInputNode.Side, Tuple, Tuple) - Method in class tools.refinery.interpreter.rete.index.DualInputNode
Helper: unifies a substitution from the specified side with another substitution from the other side.
union(CountingTcRelation<V>) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
 
UniquenessEnforcerNode - Class in tools.refinery.interpreter.rete.single
Timeless uniqueness enforcer node implementation.
UniquenessEnforcerNode(ReteContainer, int) - Constructor for class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
UniquenessEnforcerNode(ReteContainer, int, boolean) - Constructor for class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
UniquenessEnforcerNode(ReteContainer, int, boolean, TupleMask, TupleMask, IPosetComparator) - Constructor for class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
unregisterClearable(Clearable) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Unregisters a pattern memory from the rete network.
unregisterDependency(Node, Node) - Method in class tools.refinery.interpreter.rete.network.communication.CommunicationTracker
Unregisters a dependency between source and target.
unregisterNode(Node) - Method in class tools.refinery.interpreter.rete.network.ReteContainer
Unregisters a node from the rete network.
UNSUPPORTED_MESSAGE_KIND - Static variable in class tools.refinery.interpreter.rete.network.communication.CommunicationGroup
 
update(IInputKey, Tuple, boolean) - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
update(Tuple, int) - Method in class tools.refinery.interpreter.rete.network.indexer.DefaultMessageIndexer
 
update(Tuple, int) - Method in class tools.refinery.interpreter.rete.network.indexer.GroupBasedMessageIndexer
 
update(Tuple, int) - Method in interface tools.refinery.interpreter.rete.network.indexer.MessageIndexer
 
update(Direction, Tuple, Tuple, boolean, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.LeftJoinNode
 
update(Direction, Tuple, Tuple, boolean, Timestamp) - Method in class tools.refinery.interpreter.rete.index.GenericProjectionIndexer
 
update(Direction, Tuple, Tuple, boolean, Timestamp) - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
Refined version of update
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulParallelTimelyColumnAggregatorNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulSequentialTimelyColumnAggregatorNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlyParallelTimelyColumnAggregatorNode
Accumulator gets modified at the input timestamp and at all higher timestamps.
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FirstOnlySequentialTimelyColumnAggregatorNode
Accumulator gets modified only at the timestamp where the update happened.
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.boundary.ExternalInputEnumeratorNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.eval.MemorylessEvaluatorNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode.NetworkStructureChangeSensitiveLogic
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.eval.OutputCachingEvaluatorNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.eval.RelationEvaluatorNode.BatchingReceiver
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory.NetworkStructureChangeSensitiveLogic
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.index.IndexerWithMemory
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.misc.Bag
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.misc.DeltaMonitor
 
update(Direction, Tuple, Timestamp) - Method in interface tools.refinery.interpreter.rete.network.Receiver
Updates the receiver with a newly found or lost partial matching.
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.remote.RemoteReceiver
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.remote.RemoteSupplier
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.single.CallbackNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.single.DiscriminatorBucketNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.single.DiscriminatorDispatcherNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.single.FilterNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.single.RepresentativeElectionNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.single.TimelyUniquenessEnforcerNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.single.TransformerNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.single.TransitiveClosureNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.single.TransparentNode
 
update(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
updateDefault(Direction, Tuple) - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
updateDefault(Direction, Tuple, Timestamp) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
updateLock - Variable in class tools.refinery.interpreter.rete.network.Network
 
UpdateSplittingMailbox - Class in tools.refinery.interpreter.rete.network.mailbox.timeless
A mailbox implementation that splits updates messages according to the standard subset ordering into anti-monotonic (deletions) and monotonic (insertions) updates.
UpdateSplittingMailbox(Receiver, ReteContainer) - Constructor for class tools.refinery.interpreter.rete.network.mailbox.timeless.UpdateSplittingMailbox
 
updateTimeline(Tuple, Map<AggregateResult, Diff<Timestamp>>) - Method in class tools.refinery.interpreter.rete.aggregation.timely.FaithfulTimelyColumnAggregatorNode
Updates and garbage collects the timeline of the given tuple based on the given diffs.
updateTuple(V, V, boolean) - Method in class tools.refinery.interpreter.rete.itc.alg.counting.CountingTcRelation
Derivation count of the tuple (source,target) is incremented or decremented.
updateWithDeleteAndRederive(Direction, Tuple, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
updateWithDeleteAndRederive(Direction, Tuple, boolean) - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
updateWithPosetInfo(Direction, Tuple, boolean) - Method in class tools.refinery.interpreter.rete.aggregation.ColumnAggregatorNode
 
updateWithPosetInfo(Direction, Tuple, boolean) - Method in interface tools.refinery.interpreter.rete.network.PosetAwareReceiver
Updates the receiver with a newly found or lost partial matching also providing information whether the update is a monotone change or not.
updateWithPosetInfo(Direction, Tuple, boolean) - Method in class tools.refinery.interpreter.rete.single.UniquenessEnforcerNode
 
useDiscriminatorDispatchersForConstantFiltering - Static variable in class tools.refinery.interpreter.rete.util.ReteHintOptions
 
UserRequestTrace - Class in tools.refinery.interpreter.rete.traceability
 
UserRequestTrace(ReteNodeRecipe, Collection<RecipeTraceInfo>) - Constructor for class tools.refinery.interpreter.rete.traceability.UserRequestTrace
 
UserRequestTrace(ReteNodeRecipe, RecipeTraceInfo...) - Constructor for class tools.refinery.interpreter.rete.traceability.UserRequestTrace
 

V

value - Variable in class tools.refinery.interpreter.rete.network.communication.Timestamp
 
ValueBinderFilterNode - Class in tools.refinery.interpreter.rete.single
A filter node that keeps only those tuples that contain a certain value at a certain position.
ValueBinderFilterNode(ReteContainer, int, Object) - Constructor for class tools.refinery.interpreter.rete.single.ValueBinderFilterNode
 
valueFunc - Variable in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
valueOf(String) - Static method in enum class tools.refinery.interpreter.rete.index.DualInputNode.Side
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.rete.matcher.TimelyConfiguration.AggregatorArchitecture
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.rete.matcher.TimelyConfiguration.TimelineRepresentation
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.rete.network.communication.PhasedSelector
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.rete.network.communication.timely.TimestampTransformation
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.rete.util.Options.BuilderMethod
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.rete.util.Options.FunctionalDependencyOption
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.rete.util.Options.InjectivityStrategy
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.rete.util.Options.NodeSharingOption
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class tools.refinery.interpreter.rete.util.Options.PlanTrimOption
Returns the enum constant of this class with the specified name.
values - Variable in class tools.refinery.interpreter.rete.aggregation.GroupedSet
 
values() - Method in class tools.refinery.interpreter.rete.aggregation.GroupedMap
 
values() - Static method in enum class tools.refinery.interpreter.rete.index.DualInputNode.Side
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.rete.matcher.TimelyConfiguration.AggregatorArchitecture
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.rete.matcher.TimelyConfiguration.TimelineRepresentation
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.rete.network.communication.PhasedSelector
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.rete.network.communication.timely.TimestampTransformation
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.rete.util.Options.BuilderMethod
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.rete.util.Options.FunctionalDependencyOption
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.rete.util.Options.InjectivityStrategy
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.rete.util.Options.NodeSharingOption
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.rete.util.Options.PlanTrimOption
Returns an array containing the constants of this enum class, in the order they are declared.
variablesTuple - Variable in class tools.refinery.interpreter.rete.traceability.PlanningTrace
 

W

waitForReteTermination() - Method in class tools.refinery.interpreter.rete.network.Network
Waits until all rete update operations are settled in all containers.
waitForReteTermination(Runnable) - Method in class tools.refinery.interpreter.rete.network.Network
Waits to execute action until all rete update operations are settled in all containers.
wasInSameSCC - Variable in class tools.refinery.interpreter.rete.network.delayed.DelayedDisconnectCommand
 
WeaklyConnectedComponentAlgorithm<T> - Class in tools.refinery.interpreter.rete.itc.alg.representative
 
WeaklyConnectedComponentAlgorithm(Graph<T>) - Constructor for class tools.refinery.interpreter.rete.itc.alg.representative.WeaklyConnectedComponentAlgorithm
 
wrapped - Variable in class tools.refinery.interpreter.rete.network.communication.timely.TimelyIndexerListenerProxy
 
wrapped - Variable in class tools.refinery.interpreter.rete.network.communication.timely.TimelyMailboxProxy
 
wrapped - Variable in class tools.refinery.interpreter.rete.network.mailbox.timeless.BehaviorChangingMailbox
 

Z

ZERO - Static variable in class tools.refinery.interpreter.rete.network.communication.Timestamp
 
A B C D E F G H I J K L M N O P Q R S T U V W Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form