You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@vxquery.apache.org by ti...@apache.org on 2013/12/13 05:53:53 UTC

svn commit: r1550643 [2/19] - in /incubator/vxquery/site: ./ apidocs/ apidocs/org/apache/vxquery/cli/ apidocs/org/apache/vxquery/compiler/rewriter/ apidocs/org/apache/vxquery/compiler/rewriter/rules/ apidocs/org/apache/vxquery/compiler/rewriter/rules/c...

Modified: incubator/vxquery/site/apidocs/index-all.html
URL: http://svn.apache.org/viewvc/incubator/vxquery/site/apidocs/index-all.html?rev=1550643&r1=1550642&r2=1550643&view=diff
==============================================================================
--- incubator/vxquery/site/apidocs/index-all.html (original)
+++ incubator/vxquery/site/apidocs/index-all.html Fri Dec 13 04:53:49 2013
@@ -190,6 +190,14 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/type/AbstractTypeScalarEvaluatorFactory.AbstractTypeScalarEvaluator.html#AbstractTypeScalarEvaluatorFactory.AbstractTypeScalarEvaluator(edu.uci.ics.hyracks.algebricks.runtime.base.IScalarEvaluator[], edu.uci.ics.hyracks.api.context.IHyracksTaskContext)">AbstractTypeScalarEvaluatorFactory.AbstractTypeScalarEvaluator(IScalarEvaluator[], IHyracksTaskContext)</a></span> - Constructor for class org.apache.vxquery.runtime.functions.type.<a href="./org/apache/vxquery/runtime/functions/type/AbstractTypeScalarEvaluatorFactory.AbstractTypeScalarEvaluator.html" title="class in org.apache.vxquery.runtime.functions.type">AbstractTypeScalarEvaluatorFactory.AbstractTypeScalarEvaluator</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules"><span class="strong">AbstractUsedVariablesProcessingRule</span></a> - Class in <a href="./org/apache/vxquery/compiler/rewriter/rules/package-summary.html">org.apache.vxquery.compiler.rewriter.rules</a></dt>
+<dd>
+<div class="block">The AbstractUsedVariablesProcessingRule provides a frame work to track used
+ variables to assist in some rewrite rules that must track used variables in 
+ the above plan.</div>
+</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html#AbstractUsedVariablesProcessingRule()">AbstractUsedVariablesProcessingRule()</a></span> - Constructor for class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">AbstractUsedVariablesProcessingRule</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="./org/apache/vxquery/datamodel/builders/base/AbstractValueBuilder.html" title="class in org.apache.vxquery.datamodel.builders.base"><span class="strong">AbstractValueBuilder</span></a> - Class in <a href="./org/apache/vxquery/datamodel/builders/base/package-summary.html">org.apache.vxquery.datamodel.builders.base</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/datamodel/builders/base/AbstractValueBuilder.html#AbstractValueBuilder()">AbstractValueBuilder()</a></span> - Constructor for class org.apache.vxquery.datamodel.builders.base.<a href="./org/apache/vxquery/datamodel/builders/base/AbstractValueBuilder.html" title="class in org.apache.vxquery.datamodel.builders.base">AbstractValueBuilder</a></dt>
@@ -270,6 +278,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/datamodel/builders/nodes/ElementNodeBuilder.html#addChild(edu.uci.ics.hyracks.data.std.api.IValueReference)">addChild(IValueReference)</a></span> - Method in class org.apache.vxquery.datamodel.builders.nodes.<a href="./org/apache/vxquery/datamodel/builders/nodes/ElementNodeBuilder.html" title="class in org.apache.vxquery.datamodel.builders.nodes">ElementNodeBuilder</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/metadata/VXQueryCollectionDataSource.html#addChildSeq(int)">addChildSeq(int)</a></span> - Method in class org.apache.vxquery.metadata.<a href="./org/apache/vxquery/metadata/VXQueryCollectionDataSource.html" title="class in org.apache.vxquery.metadata">VXQueryCollectionDataSource</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/query/TokenMgrError.html#addEscapes(java.lang.String)">addEscapes(String)</a></span> - Static method in error org.apache.vxquery.xmlquery.query.<a href="./org/apache/vxquery/xmlquery/query/TokenMgrError.html" title="class in org.apache.vxquery.xmlquery.query">TokenMgrError</a></dt>
 <dd>
 <div class="block">Replaces unprintable characters by their escaped (or unicode escaped)
@@ -539,6 +549,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildDataExchangeRuleCollection()">buildDataExchangeRuleCollection()</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.<a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html" title="class in org.apache.vxquery.compiler.rewriter">RewriteRuleset</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildIntroduceProjectRuleCollection()">buildIntroduceProjectRuleCollection()</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.<a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html" title="class in org.apache.vxquery.compiler.rewriter">RewriteRuleset</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildJoinInferenceRuleCollection()">buildJoinInferenceRuleCollection()</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.<a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html" title="class in org.apache.vxquery.compiler.rewriter">RewriteRuleset</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildNestedDataSourceRuleCollection()">buildNestedDataSourceRuleCollection()</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.<a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html" title="class in org.apache.vxquery.compiler.rewriter">RewriteRuleset</a></dt>
@@ -549,6 +561,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildOpPushDownRuleCollection()">buildOpPushDownRuleCollection()</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.<a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html" title="class in org.apache.vxquery.compiler.rewriter">RewriteRuleset</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildPathStepNormalizationRuleCollection()">buildPathStepNormalizationRuleCollection()</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.<a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html" title="class in org.apache.vxquery.compiler.rewriter">RewriteRuleset</a></dt>
+<dd>
+<div class="block">Optimizations specific to XQuery.</div>
+</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildPhysicalRewritesAllLevelsRuleCollection()">buildPhysicalRewritesAllLevelsRuleCollection()</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.<a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html" title="class in org.apache.vxquery.compiler.rewriter">RewriteRuleset</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildPhysicalRewritesTopLevelRuleCollection()">buildPhysicalRewritesTopLevelRuleCollection()</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.<a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html" title="class in org.apache.vxquery.compiler.rewriter">RewriteRuleset</a></dt>
@@ -989,6 +1005,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/functions/BuiltinOperators.html#CHILD_QNAME">CHILD_QNAME</a></span> - Static variable in class org.apache.vxquery.functions.<a href="./org/apache/vxquery/functions/BuiltinOperators.html" title="class in org.apache.vxquery.functions">BuiltinOperators</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="./org/apache/vxquery/runtime/functions/step/ChildPathStep.html" title="class in org.apache.vxquery.runtime.functions.step"><span class="strong">ChildPathStep</span></a> - Class in <a href="./org/apache/vxquery/runtime/functions/step/package-summary.html">org.apache.vxquery.runtime.functions.step</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/ChildPathStep.html#ChildPathStep(edu.uci.ics.hyracks.api.context.IHyracksTaskContext)">ChildPathStep(IHyracksTaskContext)</a></span> - Constructor for class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/ChildPathStep.html" title="class in org.apache.vxquery.runtime.functions.step">ChildPathStep</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="./org/apache/vxquery/runtime/functions/step/ChildPathStepScalarEvaluator.html" title="class in org.apache.vxquery.runtime.functions.step"><span class="strong">ChildPathStepScalarEvaluator</span></a> - Class in <a href="./org/apache/vxquery/runtime/functions/step/package-summary.html">org.apache.vxquery.runtime.functions.step</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/ChildPathStepScalarEvaluator.html#ChildPathStepScalarEvaluator(edu.uci.ics.hyracks.algebricks.runtime.base.IScalarEvaluator[], edu.uci.ics.hyracks.api.context.IHyracksTaskContext)">ChildPathStepScalarEvaluator(IScalarEvaluator[], IHyracksTaskContext)</a></span> - Constructor for class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/ChildPathStepScalarEvaluator.html" title="class in org.apache.vxquery.runtime.functions.step">ChildPathStepScalarEvaluator</a></dt>
@@ -1190,6 +1210,20 @@
 </dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateAssignAggregateRule.html#ConsolidateAssignAggregateRule()">ConsolidateAssignAggregateRule()</a></span> - Constructor for class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateAssignAggregateRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">ConsolidateAssignAggregateRule</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateDataScanUnnestRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules"><span class="strong">ConsolidateDataScanUnnestRule</span></a> - Class in <a href="./org/apache/vxquery/compiler/rewriter/rules/package-summary.html">org.apache.vxquery.compiler.rewriter.rules</a></dt>
+<dd>
+<div class="block">The rule searches for an unnest operator immediately following a data scan
+ operator.</div>
+</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateDataScanUnnestRule.html#ConsolidateDataScanUnnestRule()">ConsolidateDataScanUnnestRule()</a></span> - Constructor for class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateDataScanUnnestRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">ConsolidateDataScanUnnestRule</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateUnnestsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules"><span class="strong">ConsolidateUnnestsRule</span></a> - Class in <a href="./org/apache/vxquery/compiler/rewriter/rules/package-summary.html">org.apache.vxquery.compiler.rewriter.rules</a></dt>
+<dd>
+<div class="block">The rule searches for an unnest operator (1) immediately following an unnest
+ operator (2).</div>
+</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateUnnestsRule.html#ConsolidateUnnestsRule()">ConsolidateUnnestsRule()</a></span> - Constructor for class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateUnnestsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">ConsolidateUnnestsRule</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="./org/apache/vxquery/compiler/rewriter/rules/propagationpolicies/ConstantPropertyPropagationPolicy.html" title="class in org.apache.vxquery.compiler.rewriter.rules.propagationpolicies"><span class="strong">ConstantPropertyPropagationPolicy</span></a>&lt;<a href="./org/apache/vxquery/compiler/rewriter/rules/propagationpolicies/ConstantPropertyPropagationPolicy.html" title="type parameter in ConstantPropertyPropagationPolicy">P</a>&gt; - Class in <a href="./org/apache/vxquery/compiler/rewriter/rules/propagationpolicies/package-summary.html">org.apache.vxquery.compiler.rewriter.rules.propagationpolicies</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/propagationpolicies/ConstantPropertyPropagationPolicy.html#ConstantPropertyPropagationPolicy(P)">ConstantPropertyPropagationPolicy(P)</a></span> - Constructor for class org.apache.vxquery.compiler.rewriter.rules.propagationpolicies.<a href="./org/apache/vxquery/compiler/rewriter/rules/propagationpolicies/ConstantPropertyPropagationPolicy.html" title="class in org.apache.vxquery.compiler.rewriter.rules.propagationpolicies">ConstantPropertyPropagationPolicy</a></dt>
@@ -3575,6 +3609,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/AbstractSinglePathStepScalarEvaluator.html#evaluate(org.apache.vxquery.datamodel.accessors.TaggedValuePointable[], edu.uci.ics.hyracks.data.std.api.IPointable)">evaluate(TaggedValuePointable[], IPointable)</a></span> - Method in class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/AbstractSinglePathStepScalarEvaluator.html" title="class in org.apache.vxquery.runtime.functions.step">AbstractSinglePathStepScalarEvaluator</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/ChildPathStepScalarEvaluator.html#evaluate(org.apache.vxquery.datamodel.accessors.TaggedValuePointable[], edu.uci.ics.hyracks.data.std.api.IPointable)">evaluate(TaggedValuePointable[], IPointable)</a></span> - Method in class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/ChildPathStepScalarEvaluator.html" title="class in org.apache.vxquery.runtime.functions.step">ChildPathStepScalarEvaluator</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/DescendantOrSelfPathStepScalarEvaluator.html#evaluate(org.apache.vxquery.datamodel.accessors.TaggedValuePointable[], edu.uci.ics.hyracks.data.std.api.IPointable)">evaluate(TaggedValuePointable[], IPointable)</a></span> - Method in class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/DescendantOrSelfPathStepScalarEvaluator.html" title="class in org.apache.vxquery.runtime.functions.step">DescendantOrSelfPathStepScalarEvaluator</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/DescendantPathStepScalarEvaluator.html#evaluate(org.apache.vxquery.datamodel.accessors.TaggedValuePointable[], edu.uci.ics.hyracks.data.std.api.IPointable)">evaluate(TaggedValuePointable[], IPointable)</a></span> - Method in class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/DescendantPathStepScalarEvaluator.html" title="class in org.apache.vxquery.runtime.functions.step">DescendantPathStepScalarEvaluator</a></dt>
@@ -3607,6 +3643,10 @@
 <dd>
 <div class="block">Lexical state.</div>
 </dd>
+<dt><a href="./org/apache/vxquery/compiler/rewriter/rules/util/ExpressionToolbox.html" title="class in org.apache.vxquery.compiler.rewriter.rules.util"><span class="strong">ExpressionToolbox</span></a> - Class in <a href="./org/apache/vxquery/compiler/rewriter/rules/util/package-summary.html">org.apache.vxquery.compiler.rewriter.rules.util</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/util/ExpressionToolbox.html#ExpressionToolbox()">ExpressionToolbox()</a></span> - Constructor for class org.apache.vxquery.compiler.rewriter.rules.util.<a href="./org/apache/vxquery/compiler/rewriter/rules/util/ExpressionToolbox.html" title="class in org.apache.vxquery.compiler.rewriter.rules.util">ExpressionToolbox</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="./org/apache/vxquery/xmlquery/ast/ExprNode.html" title="class in org.apache.vxquery.xmlquery.ast"><span class="strong">ExprNode</span></a> - Class in <a href="./org/apache/vxquery/xmlquery/ast/package-summary.html">org.apache.vxquery.xmlquery.ast</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/ast/ExprNode.html#ExprNode(org.apache.vxquery.util.SourceLocation)">ExprNode(SourceLocation)</a></span> - Constructor for class org.apache.vxquery.xmlquery.ast.<a href="./org/apache/vxquery/xmlquery/ast/ExprNode.html" title="class in org.apache.vxquery.xmlquery.ast">ExprNode</a></dt>
@@ -3697,6 +3737,12 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/metadata/VXQueryMetadataProvider.html#findDataSourceIndex(java.lang.String, java.lang.String)">findDataSourceIndex(String, String)</a></span> - Method in class org.apache.vxquery.metadata.<a href="./org/apache/vxquery/metadata/VXQueryMetadataProvider.html" title="class in org.apache.vxquery.metadata">VXQueryMetadataProvider</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/util/ExpressionToolbox.html#findFunctionExpression(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.functions.FunctionIdentifier)">findFunctionExpression(Mutable&lt;ILogicalExpression&gt;, FunctionIdentifier)</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.rules.util.<a href="./org/apache/vxquery/compiler/rewriter/rules/util/ExpressionToolbox.html" title="class in org.apache.vxquery.compiler.rewriter.rules.util">ExpressionToolbox</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/util/OperatorToolbox.html#findLastSubplanOperator(edu.uci.ics.hyracks.algebricks.core.algebra.operators.logical.AbstractLogicalOperator)">findLastSubplanOperator(AbstractLogicalOperator)</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.rules.util.<a href="./org/apache/vxquery/compiler/rewriter/rules/util/OperatorToolbox.html" title="class in org.apache.vxquery.compiler.rewriter.rules.util">OperatorToolbox</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/util/ExpressionToolbox.html#findVariableExpression(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.LogicalVariable)">findVariableExpression(Mutable&lt;ILogicalExpression&gt;, LogicalVariable)</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.rules.util.<a href="./org/apache/vxquery/compiler/rewriter/rules/util/ExpressionToolbox.html" title="class in org.apache.vxquery.compiler.rewriter.rules.util">ExpressionToolbox</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/datamodel/builders/nodes/AbstractNodeBuilder.html#finish()">finish()</a></span> - Method in class org.apache.vxquery.datamodel.builders.nodes.<a href="./org/apache/vxquery/datamodel/builders/nodes/AbstractNodeBuilder.html" title="class in org.apache.vxquery.datamodel.builders.nodes">AbstractNodeBuilder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/datamodel/builders/nodes/AttributeNodeBuilder.html#finish()">finish()</a></span> - Method in class org.apache.vxquery.datamodel.builders.nodes.<a href="./org/apache/vxquery/datamodel/builders/nodes/AttributeNodeBuilder.html" title="class in org.apache.vxquery.datamodel.builders.nodes">AttributeNodeBuilder</a></dt>
@@ -4901,6 +4947,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/context/StaticContextImpl.html#getBoundarySpaceProperty()">getBoundarySpaceProperty()</a></span> - Method in class org.apache.vxquery.context.<a href="./org/apache/vxquery/context/StaticContextImpl.html" title="class in org.apache.vxquery.context">StaticContextImpl</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/util/ExpressionToolbox.html#getBuiltIn(org.apache.commons.lang3.mutable.Mutable)">getBuiltIn(Mutable&lt;ILogicalExpression&gt;)</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.rules.util.<a href="./org/apache/vxquery/compiler/rewriter/rules/util/ExpressionToolbox.html" title="class in org.apache.vxquery.compiler.rewriter.rules.util">ExpressionToolbox</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/types/BuiltinTypeRegistry.html#getBuiltinBaseType(org.apache.vxquery.types.SchemaType)">getBuiltinBaseType(SchemaType)</a></span> - Method in class org.apache.vxquery.types.<a href="./org/apache/vxquery/types/BuiltinTypeRegistry.html" title="class in org.apache.vxquery.types">BuiltinTypeRegistry</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/strings/UTF8StringCharacterIterator.html#getByteOffset()">getByteOffset()</a></span> - Method in class org.apache.vxquery.runtime.functions.strings.<a href="./org/apache/vxquery/runtime/functions/strings/UTF8StringCharacterIterator.html" title="class in org.apache.vxquery.runtime.functions.strings">UTF8StringCharacterIterator</a></dt>
@@ -4913,6 +4961,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/datamodel/accessors/nodes/ElementNodePointable.html#getChildrenSequence(org.apache.vxquery.datamodel.accessors.nodes.NodeTreePointable, org.apache.vxquery.datamodel.accessors.SequencePointable)">getChildrenSequence(NodeTreePointable, SequencePointable)</a></span> - Method in class org.apache.vxquery.datamodel.accessors.nodes.<a href="./org/apache/vxquery/datamodel/accessors/nodes/ElementNodePointable.html" title="class in org.apache.vxquery.datamodel.accessors.nodes">ElementNodePointable</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/metadata/VXQueryCollectionDataSource.html#getChildSeq()">getChildSeq()</a></span> - Method in class org.apache.vxquery.metadata.<a href="./org/apache/vxquery/metadata/VXQueryCollectionDataSource.html" title="class in org.apache.vxquery.metadata">VXQueryCollectionDataSource</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/ast/FLWORExprNode.html#getClauses()">getClauses()</a></span> - Method in class org.apache.vxquery.xmlquery.ast.<a href="./org/apache/vxquery/xmlquery/ast/FLWORExprNode.html" title="class in org.apache.vxquery.xmlquery.ast">FLWORExprNode</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/exceptions/SystemException.html#getCode()">getCode()</a></span> - Method in exception org.apache.vxquery.exceptions.<a href="./org/apache/vxquery/exceptions/SystemException.html" title="class in org.apache.vxquery.exceptions">SystemException</a></dt>
@@ -4947,6 +4997,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xtest/TestCase.html#getConfig()">getConfig()</a></span> - Method in class org.apache.vxquery.xtest.<a href="./org/apache/vxquery/xtest/TestCase.html" title="class in org.apache.vxquery.xtest">TestCase</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/util/ExpressionToolbox.html#getConstantAsPointable(edu.uci.ics.hyracks.algebricks.core.algebra.expressions.ConstantExpression, org.apache.vxquery.datamodel.accessors.TaggedValuePointable)">getConstantAsPointable(ConstantExpression, TaggedValuePointable)</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.rules.util.<a href="./org/apache/vxquery/compiler/rewriter/rules/util/ExpressionToolbox.html" title="class in org.apache.vxquery.compiler.rewriter.rules.util">ExpressionToolbox</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/context/DelegatingStaticContextImpl.html#getConstructionModeProperty()">getConstructionModeProperty()</a></span> - Method in class org.apache.vxquery.context.<a href="./org/apache/vxquery/context/DelegatingStaticContextImpl.html" title="class in org.apache.vxquery.context">DelegatingStaticContextImpl</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/context/StaticContext.html#getConstructionModeProperty()">getConstructionModeProperty()</a></span> - Method in interface org.apache.vxquery.context.<a href="./org/apache/vxquery/context/StaticContext.html" title="interface in org.apache.vxquery.context">StaticContext</a></dt>
@@ -5151,6 +5203,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/ast/ValidateExprNode.html#getExpr()">getExpr()</a></span> - Method in class org.apache.vxquery.xmlquery.ast.<a href="./org/apache/vxquery/xmlquery/ast/ValidateExprNode.html" title="class in org.apache.vxquery.xmlquery.ast">ValidateExprNode</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/util/OperatorToolbox.html#getExpression(org.apache.commons.lang3.mutable.Mutable)">getExpression(Mutable&lt;ILogicalOperator&gt;)</a></span> - Static method in class org.apache.vxquery.compiler.rewriter.rules.util.<a href="./org/apache/vxquery/compiler/rewriter/rules/util/OperatorToolbox.html" title="class in org.apache.vxquery.compiler.rewriter.rules.util">OperatorToolbox</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/ast/EnclosedExprNode.html#getExpression()">getExpression()</a></span> - Method in class org.apache.vxquery.xmlquery.ast.<a href="./org/apache/vxquery/xmlquery/ast/EnclosedExprNode.html" title="class in org.apache.vxquery.xmlquery.ast">EnclosedExprNode</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/ast/OrderSpecNode.html#getExpression()">getExpression()</a></span> - Method in class org.apache.vxquery.xmlquery.ast.<a href="./org/apache/vxquery/xmlquery/ast/OrderSpecNode.html" title="class in org.apache.vxquery.xmlquery.ast">OrderSpecNode</a></dt>
@@ -5597,8 +5651,6 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/AttributePathStepScalarEvaluator.html#getSequence(org.apache.vxquery.datamodel.accessors.nodes.NodeTreePointable, org.apache.vxquery.datamodel.accessors.SequencePointable)">getSequence(NodeTreePointable, SequencePointable)</a></span> - Method in class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/AttributePathStepScalarEvaluator.html" title="class in org.apache.vxquery.runtime.functions.step">AttributePathStepScalarEvaluator</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/ChildPathStepScalarEvaluator.html#getSequence(org.apache.vxquery.datamodel.accessors.nodes.NodeTreePointable, org.apache.vxquery.datamodel.accessors.SequencePointable)">getSequence(NodeTreePointable, SequencePointable)</a></span> - Method in class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/ChildPathStepScalarEvaluator.html" title="class in org.apache.vxquery.runtime.functions.step">ChildPathStepScalarEvaluator</a></dt>
-<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/ast/ForVarDeclNode.html#getSequence()">getSequence()</a></span> - Method in class org.apache.vxquery.xmlquery.ast.<a href="./org/apache/vxquery/xmlquery/ast/ForVarDeclNode.html" title="class in org.apache.vxquery.xmlquery.ast">ForVarDeclNode</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/ast/LetVarDeclNode.html#getSequence()">getSequence()</a></span> - Method in class org.apache.vxquery.xmlquery.ast.<a href="./org/apache/vxquery/xmlquery/ast/LetVarDeclNode.html" title="class in org.apache.vxquery.xmlquery.ast">LetVarDeclNode</a></dt>
@@ -6143,6 +6195,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/types/TextType.html#hashCode()">hashCode()</a></span> - Method in class org.apache.vxquery.types.<a href="./org/apache/vxquery/types/TextType.html" title="class in org.apache.vxquery.types">TextType</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html#hasRun">hasRun</a></span> - Variable in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">AbstractUsedVariablesProcessingRule</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/functions/Function.html#hasScalarEvaluatorFactory()">hasScalarEvaluatorFactory()</a></span> - Method in class org.apache.vxquery.functions.<a href="./org/apache/vxquery/functions/Function.html" title="class in org.apache.vxquery.functions">Function</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/functions/Function.html#hasUnnestingEvaluatorFactory()">hasUnnestingEvaluatorFactory()</a></span> - Method in class org.apache.vxquery.functions.<a href="./org/apache/vxquery/functions/Function.html" title="class in org.apache.vxquery.functions">Function</a></dt>
@@ -6235,6 +6289,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/base/AbstractTaggedValueArgumentUnnestingEvaluator.html#init(org.apache.vxquery.datamodel.accessors.TaggedValuePointable[])">init(TaggedValuePointable[])</a></span> - Method in class org.apache.vxquery.runtime.functions.base.<a href="./org/apache/vxquery/runtime/functions/base/AbstractTaggedValueArgumentUnnestingEvaluator.html" title="class in org.apache.vxquery.runtime.functions.base">AbstractTaggedValueArgumentUnnestingEvaluator</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/ChildPathStep.html#init(org.apache.vxquery.datamodel.accessors.TaggedValuePointable, java.util.List)">init(TaggedValuePointable, List&lt;Integer&gt;)</a></span> - Method in class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/ChildPathStep.html" title="class in org.apache.vxquery.runtime.functions.step">ChildPathStep</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/ChildPathStep.html#init(org.apache.vxquery.datamodel.accessors.TaggedValuePointable[])">init(TaggedValuePointable[])</a></span> - Method in class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/ChildPathStep.html" title="class in org.apache.vxquery.runtime.functions.step">ChildPathStep</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/serializer/XMLSerializer.html#init()">init()</a></span> - Method in class org.apache.vxquery.serializer.<a href="./org/apache/vxquery/serializer/XMLSerializer.html" title="class in org.apache.vxquery.serializer">XMLSerializer</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/query/XMLQueryTokenManager.html#input_stream">input_stream</a></span> - Variable in class org.apache.vxquery.xmlquery.query.<a href="./org/apache/vxquery/xmlquery/query/XMLQueryTokenManager.html" title="class in org.apache.vxquery.xmlquery.query">XMLQueryTokenManager</a></dt>
@@ -6375,6 +6433,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/algebricks/VXQueryConstantValue.html#isFalse()">isFalse()</a></span> - Method in class org.apache.vxquery.compiler.algebricks.<a href="./org/apache/vxquery/compiler/algebricks/VXQueryConstantValue.html" title="class in org.apache.vxquery.compiler.algebricks">VXQueryConstantValue</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/functions/Function.html#isFunctional()">isFunctional()</a></span> - Method in class org.apache.vxquery.functions.<a href="./org/apache/vxquery/functions/Function.html" title="class in org.apache.vxquery.functions">Function</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/datamodel/util/DateTime.html#isLeapYear(long)">isLeapYear(long)</a></span> - Static method in class org.apache.vxquery.datamodel.util.<a href="./org/apache/vxquery/datamodel/util/DateTime.html" title="class in org.apache.vxquery.datamodel.util">DateTime</a></dt>
 <dd>
 <div class="block">Check whether a given year is a leap year.</div>
@@ -6695,7 +6755,9 @@
 <h2 class="title">M</h2>
 <dl>
 <dt><span class="strong"><a href="./org/apache/vxquery/cli/VXQuery.html#main(java.lang.String[])">main(String[])</a></span> - Static method in class org.apache.vxquery.cli.<a href="./org/apache/vxquery/cli/VXQuery.html" title="class in org.apache.vxquery.cli">VXQuery</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block">Main method to get command line options and execute query process.</div>
+</dd>
 <dt><a href="./org/apache/vxquery/xtest/Main.html" title="class in org.apache.vxquery.xtest"><span class="strong">Main</span></a> - Class in <a href="./org/apache/vxquery/xtest/package-summary.html">org.apache.vxquery.xtest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xtest/Main.html#Main()">Main()</a></span> - Constructor for class org.apache.vxquery.xtest.<a href="./org/apache/vxquery/xtest/Main.html" title="class in org.apache.vxquery.xtest">Main</a></dt>
@@ -8187,6 +8249,12 @@
 <dd>
 <div class="block">Lexical state.</div>
 </dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/functions/BuiltinOperators.html#OPERATOR_COLLECTION">OPERATOR_COLLECTION</a></span> - Static variable in class org.apache.vxquery.functions.<a href="./org/apache/vxquery/functions/BuiltinOperators.html" title="class in org.apache.vxquery.functions">BuiltinOperators</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="./org/apache/vxquery/compiler/rewriter/rules/util/OperatorToolbox.html" title="class in org.apache.vxquery.compiler.rewriter.rules.util"><span class="strong">OperatorToolbox</span></a> - Class in <a href="./org/apache/vxquery/compiler/rewriter/rules/util/package-summary.html">org.apache.vxquery.compiler.rewriter.rules.util</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/util/OperatorToolbox.html#OperatorToolbox()">OperatorToolbox()</a></span> - Constructor for class org.apache.vxquery.compiler.rewriter.rules.util.<a href="./org/apache/vxquery/compiler/rewriter/rules/util/OperatorToolbox.html" title="class in org.apache.vxquery.compiler.rewriter.rules.util">OperatorToolbox</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/query/XQueryConstants.html#OPEXT_NSURI">OPEXT_NSURI</a></span> - Static variable in class org.apache.vxquery.xmlquery.query.<a href="./org/apache/vxquery/xmlquery/query/XQueryConstants.html" title="class in org.apache.vxquery.xmlquery.query">XQueryConstants</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/query/XQueryConstants.html#OPEXT_PREFIX">OPEXT_PREFIX</a></span> - Static variable in class org.apache.vxquery.xmlquery.query.<a href="./org/apache/vxquery/xmlquery/query/XQueryConstants.html" title="class in org.apache.vxquery.xmlquery.query">XQueryConstants</a></dt>
@@ -8575,6 +8643,14 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/types/ProcessingInstructionType.html#ProcessingInstructionType(byte[])">ProcessingInstructionType(byte[])</a></span> - Constructor for class org.apache.vxquery.types.<a href="./org/apache/vxquery/types/ProcessingInstructionType.html" title="class in org.apache.vxquery.types">ProcessingInstructionType</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/AbstractSinglePathStepScalarEvaluator.html#processNodeTree()">processNodeTree()</a></span> - Method in class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/AbstractSinglePathStepScalarEvaluator.html" title="class in org.apache.vxquery.runtime.functions.step">AbstractSinglePathStepScalarEvaluator</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html#processOperator(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">processOperator(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">AbstractUsedVariablesProcessingRule</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateDataScanUnnestRule.html#processOperator(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">processOperator(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateDataScanUnnestRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">ConsolidateDataScanUnnestRule</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateUnnestsRule.html#processOperator(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">processOperator(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateUnnestsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">ConsolidateUnnestsRule</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/types/Quantifier.html#product(org.apache.vxquery.types.Quantifier, org.apache.vxquery.types.Quantifier)">product(Quantifier, Quantifier)</a></span> - Static method in enum org.apache.vxquery.types.<a href="./org/apache/vxquery/types/Quantifier.html" title="enum in org.apache.vxquery.types">Quantifier</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/ast/ModuleNode.html#prolog">prolog</a></span> - Variable in class org.apache.vxquery.xmlquery.ast.<a href="./org/apache/vxquery/xmlquery/ast/ModuleNode.html" title="class in org.apache.vxquery.xmlquery.ast">ModuleNode</a></dt>
@@ -8620,7 +8696,9 @@
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/propagationpolicies/IPropertyPropagationPolicy.html#propagate(java.util.List)">propagate(List&lt;P&gt;)</a></span> - Method in interface org.apache.vxquery.compiler.rewriter.rules.propagationpolicies.<a href="./org/apache/vxquery/compiler/rewriter/rules/propagationpolicies/IPropertyPropagationPolicy.html" title="interface in org.apache.vxquery.compiler.rewriter.rules.propagationpolicies">IPropertyPropagationPolicy</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="./org/apache/vxquery/compiler/rewriter/rules/PushMapOperatorDownThroughProductRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules"><span class="strong">PushMapOperatorDownThroughProductRule</span></a> - Class in <a href="./org/apache/vxquery/compiler/rewriter/rules/package-summary.html">org.apache.vxquery.compiler.rewriter.rules</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block">The rule searches for an inner join operator followed by a map operator.</div>
+</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/PushMapOperatorDownThroughProductRule.html#PushMapOperatorDownThroughProductRule()">PushMapOperatorDownThroughProductRule()</a></span> - Constructor for class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/PushMapOperatorDownThroughProductRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">PushMapOperatorDownThroughProductRule</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/VXQueryOptimizationContext.html#putCardinalityOperatorMap(edu.uci.ics.hyracks.algebricks.core.algebra.base.ILogicalOperator, org.apache.vxquery.compiler.rewriter.rules.propagationpolicies.cardinality.Cardinality)">putCardinalityOperatorMap(ILogicalOperator, Cardinality)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.<a href="./org/apache/vxquery/compiler/rewriter/VXQueryOptimizationContext.html" title="class in org.apache.vxquery.compiler.rewriter">VXQueryOptimizationContext</a></dt>
@@ -8885,6 +8963,18 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/ast/RelativePathExprNode.html#RelativePathExprNode(org.apache.vxquery.util.SourceLocation)">RelativePathExprNode(SourceLocation)</a></span> - Constructor for class org.apache.vxquery.xmlquery.ast.<a href="./org/apache/vxquery/xmlquery/ast/RelativePathExprNode.html" title="class in org.apache.vxquery.xmlquery.ast">RelativePathExprNode</a></dt>
 <dd>&nbsp;</dd>
+<dt><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantPromoteExpressionsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules"><span class="strong">RemoveRedundantPromoteExpressionsRule</span></a> - Class in <a href="./org/apache/vxquery/compiler/rewriter/rules/package-summary.html">org.apache.vxquery.compiler.rewriter.rules</a></dt>
+<dd>
+<div class="block">The rule searches for where the xquery promote function is used.</div>
+</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantPromoteExpressionsRule.html#RemoveRedundantPromoteExpressionsRule()">RemoveRedundantPromoteExpressionsRule()</a></span> - Constructor for class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantPromoteExpressionsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">RemoveRedundantPromoteExpressionsRule</a></dt>
+<dd>&nbsp;</dd>
+<dt><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantTreatExpressionsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules"><span class="strong">RemoveRedundantTreatExpressionsRule</span></a> - Class in <a href="./org/apache/vxquery/compiler/rewriter/rules/package-summary.html">org.apache.vxquery.compiler.rewriter.rules</a></dt>
+<dd>
+<div class="block">The rule searches for where the xquery treat function is used.</div>
+</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantTreatExpressionsRule.html#RemoveRedundantTreatExpressionsRule()">RemoveRedundantTreatExpressionsRule()</a></span> - Constructor for class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantTreatExpressionsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">RemoveRedundantTreatExpressionsRule</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveUnusedSortDistinctNodesRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules"><span class="strong">RemoveUnusedSortDistinctNodesRule</span></a> - Class in <a href="./org/apache/vxquery/compiler/rewriter/rules/package-summary.html">org.apache.vxquery.compiler.rewriter.rules</a></dt>
 <dd>
 <div class="block">The rule searches for where the xquery sort distinct function is used and
@@ -8963,6 +9053,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractCollectionRule.html#rewritePost(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePost(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractCollectionRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">AbstractCollectionRule</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html#rewritePost(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePost(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">AbstractUsedVariablesProcessingRule</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateAssignAggregateRule.html#rewritePost(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePost(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateAssignAggregateRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">ConsolidateAssignAggregateRule</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/ConvertAssignSortDistinctNodesToOperatorsRule.html#rewritePost(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePost(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/ConvertAssignSortDistinctNodesToOperatorsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">ConvertAssignSortDistinctNodesToOperatorsRule</a></dt>
@@ -8983,12 +9075,18 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/PushMapOperatorDownThroughProductRule.html#rewritePost(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePost(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/PushMapOperatorDownThroughProductRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">PushMapOperatorDownThroughProductRule</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantPromoteExpressionsRule.html#rewritePost(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePost(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantPromoteExpressionsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">RemoveRedundantPromoteExpressionsRule</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantTreatExpressionsRule.html#rewritePost(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePost(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantTreatExpressionsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">RemoveRedundantTreatExpressionsRule</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveUnusedSortDistinctNodesRule.html#rewritePost(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePost(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveUnusedSortDistinctNodesRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">RemoveUnusedSortDistinctNodesRule</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveUnusedTreatRule.html#rewritePost(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePost(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveUnusedTreatRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">RemoveUnusedTreatRule</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/SetVariableIdContextRule.html#rewritePost(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePost(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/SetVariableIdContextRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">SetVariableIdContextRule</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html#rewritePre(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePre(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">AbstractUsedVariablesProcessingRule</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateAssignAggregateRule.html#rewritePre(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePre(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/ConsolidateAssignAggregateRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">ConsolidateAssignAggregateRule</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/ConvertAssignSortDistinctNodesToOperatorsRule.html#rewritePre(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePre(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/ConvertAssignSortDistinctNodesToOperatorsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">ConvertAssignSortDistinctNodesToOperatorsRule</a></dt>
@@ -9011,6 +9109,10 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/PushMapOperatorDownThroughProductRule.html#rewritePre(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePre(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/PushMapOperatorDownThroughProductRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">PushMapOperatorDownThroughProductRule</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantPromoteExpressionsRule.html#rewritePre(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePre(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantPromoteExpressionsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">RemoveRedundantPromoteExpressionsRule</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantTreatExpressionsRule.html#rewritePre(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePre(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveRedundantTreatExpressionsRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">RemoveRedundantTreatExpressionsRule</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveUnusedSortDistinctNodesRule.html#rewritePre(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePre(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveUnusedSortDistinctNodesRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">RemoveUnusedSortDistinctNodesRule</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveUnusedTreatRule.html#rewritePre(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePre(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/RemoveUnusedTreatRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">RemoveUnusedTreatRule</a></dt>
@@ -9019,6 +9121,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/SetVariableIdContextRule.html#rewritePre(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePre(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/SetVariableIdContextRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">SetVariableIdContextRule</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html#rewritePreOnePass(org.apache.commons.lang3.mutable.Mutable, edu.uci.ics.hyracks.algebricks.core.algebra.base.IOptimizationContext)">rewritePreOnePass(Mutable&lt;ILogicalOperator&gt;, IOptimizationContext)</a></span> - Method in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">AbstractUsedVariablesProcessingRule</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html" title="class in org.apache.vxquery.compiler.rewriter"><span class="strong">RewriteRuleset</span></a> - Class in <a href="./org/apache/vxquery/compiler/rewriter/package-summary.html">org.apache.vxquery.compiler.rewriter</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#RewriteRuleset()">RewriteRuleset()</a></span> - Constructor for class org.apache.vxquery.compiler.rewriter.<a href="./org/apache/vxquery/compiler/rewriter/RewriteRuleset.html" title="class in org.apache.vxquery.compiler.rewriter">RewriteRuleset</a></dt>
@@ -9245,6 +9349,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/context/DynamicContextImpl.html#setCurrentDateTime(edu.uci.ics.hyracks.data.std.api.IValueReference)">setCurrentDateTime(IValueReference)</a></span> - Method in class org.apache.vxquery.context.<a href="./org/apache/vxquery/context/DynamicContextImpl.html" title="class in org.apache.vxquery.context">DynamicContextImpl</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/datamodel/accessors/atomic/XSDateTimePointable.html#setCurrentDateTime()">setCurrentDateTime()</a></span> - Method in class org.apache.vxquery.datamodel.accessors.atomic.<a href="./org/apache/vxquery/datamodel/accessors/atomic/XSDateTimePointable.html" title="class in org.apache.vxquery.datamodel.accessors.atomic">XSDateTimePointable</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/datamodel/accessors/atomic/XSDatePointable.html#setDate(long, long, long, long, long)">setDate(long, long, long, long, long)</a></span> - Method in class org.apache.vxquery.datamodel.accessors.atomic.<a href="./org/apache/vxquery/datamodel/accessors/atomic/XSDatePointable.html" title="class in org.apache.vxquery.datamodel.accessors.atomic">XSDatePointable</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/datamodel/accessors/atomic/XSDatePointable.html#setDate(byte[], int, long, long, long, long, long)">setDate(byte[], int, long, long, long, long, long)</a></span> - Static method in class org.apache.vxquery.datamodel.accessors.atomic.<a href="./org/apache/vxquery/datamodel/accessors/atomic/XSDatePointable.html" title="class in org.apache.vxquery.datamodel.accessors.atomic">XSDatePointable</a></dt>
@@ -9357,6 +9463,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/datamodel/values/XDMConstants.html#setFalse(edu.uci.ics.hyracks.data.std.api.IPointable)">setFalse(IPointable)</a></span> - Static method in class org.apache.vxquery.datamodel.values.<a href="./org/apache/vxquery/datamodel/values/XDMConstants.html" title="class in org.apache.vxquery.datamodel.values">XDMConstants</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/ChildPathStep.html#setFilterCode(int)">setFilterCode(int)</a></span> - Method in class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/ChildPathStep.html" title="class in org.apache.vxquery.runtime.functions.step">ChildPathStep</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xtest/TestCase.html#setFolder(java.lang.String)">setFolder(String)</a></span> - Method in class org.apache.vxquery.xtest.<a href="./org/apache/vxquery/xtest/TestCase.html" title="class in org.apache.vxquery.xtest">TestCase</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/ast/ForVarDeclNode.html#setForVar(org.apache.vxquery.xmlquery.ast.QNameNode)">setForVar(QNameNode)</a></span> - Method in class org.apache.vxquery.xmlquery.ast.<a href="./org/apache/vxquery/xmlquery/ast/ForVarDeclNode.html" title="class in org.apache.vxquery.xmlquery.ast">ForVarDeclNode</a></dt>
@@ -9838,7 +9946,9 @@
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlparser/SAXContentHandler.html#startEntity(java.lang.String)">startEntity(String)</a></span> - Method in class org.apache.vxquery.xmlparser.<a href="./org/apache/vxquery/xmlparser/SAXContentHandler.html" title="class in org.apache.vxquery.xmlparser">SAXContentHandler</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/cli/VXQuery.html#startLocalHyracks()">startLocalHyracks()</a></span> - Method in class org.apache.vxquery.cli.<a href="./org/apache/vxquery/cli/VXQuery.html" title="class in org.apache.vxquery.cli">VXQuery</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block">Start local virtual cluster with cluster controller node and node controller nodes.</div>
+</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/datamodel/builders/nodes/ElementNodeBuilder.html#startNamespaceChunk()">startNamespaceChunk()</a></span> - Method in class org.apache.vxquery.datamodel.builders.nodes.<a href="./org/apache/vxquery/datamodel/builders/nodes/ElementNodeBuilder.html" title="class in org.apache.vxquery.datamodel.builders.nodes">ElementNodeBuilder</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlparser/SAXContentHandler.html#startPrefixMapping(java.lang.String, java.lang.String)">startPrefixMapping(String, String)</a></span> - Method in class org.apache.vxquery.xmlparser.<a href="./org/apache/vxquery/xmlparser/SAXContentHandler.html" title="class in org.apache.vxquery.xmlparser">SAXContentHandler</a></dt>
@@ -9881,10 +9991,14 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/base/AbstractTaggedValueArgumentAggregateEvaluator.html#step(org.apache.vxquery.datamodel.accessors.TaggedValuePointable[])">step(TaggedValuePointable[])</a></span> - Method in class org.apache.vxquery.runtime.functions.base.<a href="./org/apache/vxquery/runtime/functions/base/AbstractTaggedValueArgumentAggregateEvaluator.html" title="class in org.apache.vxquery.runtime.functions.base">AbstractTaggedValueArgumentAggregateEvaluator</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/runtime/functions/step/ChildPathStep.html#step(edu.uci.ics.hyracks.data.std.api.IPointable)">step(IPointable)</a></span> - Method in class org.apache.vxquery.runtime.functions.step.<a href="./org/apache/vxquery/runtime/functions/step/ChildPathStep.html" title="class in org.apache.vxquery.runtime.functions.step">ChildPathStep</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/query/XMLQuery.html#StepExpr()">StepExpr()</a></span> - Method in class org.apache.vxquery.xmlquery.query.<a href="./org/apache/vxquery/xmlquery/query/XMLQuery.html" title="class in org.apache.vxquery.xmlquery.query">XMLQuery</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/cli/VXQuery.html#stopLocalHyracks()">stopLocalHyracks()</a></span> - Method in class org.apache.vxquery.cli.<a href="./org/apache/vxquery/cli/VXQuery.html" title="class in org.apache.vxquery.cli">VXQuery</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block">Shuts down the virtual cluster, alongwith all nodes and node execution, network and queue managers.</div>
+</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/xmlquery/query/XMLQueryConstants.html#StringLiteral">StringLiteral</a></span> - Static variable in interface org.apache.vxquery.xmlquery.query.<a href="./org/apache/vxquery/xmlquery/query/XMLQueryConstants.html" title="interface in org.apache.vxquery.xmlquery.query">XMLQueryConstants</a></dt>
 <dd>
 <div class="block">RegularExpression Id.</div>
@@ -10356,6 +10470,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/functions/UserDefinedXQueryFunction.html#useContextImplicitly()">useContextImplicitly()</a></span> - Method in class org.apache.vxquery.functions.<a href="./org/apache/vxquery/functions/UserDefinedXQueryFunction.html" title="class in org.apache.vxquery.functions">UserDefinedXQueryFunction</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html#usedVariables">usedVariables</a></span> - Variable in class org.apache.vxquery.compiler.rewriter.rules.<a href="./org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules">AbstractUsedVariablesProcessingRule</a></dt>
+<dd>&nbsp;</dd>
 <dt><a href="./org/apache/vxquery/functions/UserDefinedXQueryFunction.html" title="class in org.apache.vxquery.functions"><span class="strong">UserDefinedXQueryFunction</span></a> - Class in <a href="./org/apache/vxquery/functions/package-summary.html">org.apache.vxquery.functions</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/functions/UserDefinedXQueryFunction.html#UserDefinedXQueryFunction(javax.xml.namespace.QName, org.apache.vxquery.functions.Signature, edu.uci.ics.hyracks.algebricks.core.algebra.base.ILogicalPlan)">UserDefinedXQueryFunction(QName, Signature, ILogicalPlan)</a></span> - Constructor for class org.apache.vxquery.functions.<a href="./org/apache/vxquery/functions/UserDefinedXQueryFunction.html" title="class in org.apache.vxquery.functions">UserDefinedXQueryFunction</a></dt>
@@ -10741,7 +10857,9 @@ the order they are declared.</div>
 <dt><a href="./org/apache/vxquery/cli/VXQuery.html" title="class in org.apache.vxquery.cli"><span class="strong">VXQuery</span></a> - Class in <a href="./org/apache/vxquery/cli/package-summary.html">org.apache.vxquery.cli</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/cli/VXQuery.html#VXQuery(org.apache.vxquery.cli.VXQuery.CmdLineOptions)">VXQuery(VXQuery.CmdLineOptions)</a></span> - Constructor for class org.apache.vxquery.cli.<a href="./org/apache/vxquery/cli/VXQuery.html" title="class in org.apache.vxquery.cli">VXQuery</a></dt>
-<dd>&nbsp;</dd>
+<dd>
+<div class="block">Constructor to use command line options passed.</div>
+</dd>
 <dt><a href="./org/apache/vxquery/compiler/algebricks/VXQueryBinaryBooleanInspectorFactory.html" title="class in org.apache.vxquery.compiler.algebricks"><span class="strong">VXQueryBinaryBooleanInspectorFactory</span></a> - Class in <a href="./org/apache/vxquery/compiler/algebricks/package-summary.html">org.apache.vxquery.compiler.algebricks</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="./org/apache/vxquery/compiler/algebricks/VXQueryBinaryBooleanInspectorFactory.html#VXQueryBinaryBooleanInspectorFactory()">VXQueryBinaryBooleanInspectorFactory()</a></span> - Constructor for class org.apache.vxquery.compiler.algebricks.<a href="./org/apache/vxquery/compiler/algebricks/VXQueryBinaryBooleanInspectorFactory.html" title="class in org.apache.vxquery.compiler.algebricks">VXQueryBinaryBooleanInspectorFactory</a></dt>
@@ -10758,7 +10876,7 @@ the order they are declared.</div>
 <dd>&nbsp;</dd>
 <dt><a href="./org/apache/vxquery/metadata/VXQueryCollectionOperatorDescriptor.html" title="class in org.apache.vxquery.metadata"><span class="strong">VXQueryCollectionOperatorDescriptor</span></a> - Class in <a href="./org/apache/vxquery/metadata/package-summary.html">org.apache.vxquery.metadata</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="./org/apache/vxquery/metadata/VXQueryCollectionOperatorDescriptor.html#VXQueryCollectionOperatorDescriptor(edu.uci.ics.hyracks.api.job.IOperatorDescriptorRegistry, java.lang.String, int, int, edu.uci.ics.hyracks.api.dataflow.value.RecordDescriptor)">VXQueryCollectionOperatorDescriptor(IOperatorDescriptorRegistry, String, int, int, RecordDescriptor)</a></span> - Constructor for class org.apache.vxquery.metadata.<a href="./org/apache/vxquery/metadata/VXQueryCollectionOperatorDescriptor.html" title="class in org.apache.vxquery.metadata">VXQueryCollectionOperatorDescriptor</a></dt>
+<dt><span class="strong"><a href="./org/apache/vxquery/metadata/VXQueryCollectionOperatorDescriptor.html#VXQueryCollectionOperatorDescriptor(edu.uci.ics.hyracks.api.job.IOperatorDescriptorRegistry, org.apache.vxquery.metadata.VXQueryCollectionDataSource, edu.uci.ics.hyracks.api.dataflow.value.RecordDescriptor)">VXQueryCollectionOperatorDescriptor(IOperatorDescriptorRegistry, VXQueryCollectionDataSource, RecordDescriptor)</a></span> - Constructor for class org.apache.vxquery.metadata.<a href="./org/apache/vxquery/metadata/VXQueryCollectionOperatorDescriptor.html" title="class in org.apache.vxquery.metadata">VXQueryCollectionOperatorDescriptor</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="./org/apache/vxquery/compiler/algebricks/VXQueryComparatorFactoryProvider.html" title="class in org.apache.vxquery.compiler.algebricks"><span class="strong">VXQueryComparatorFactoryProvider</span></a> - Class in <a href="./org/apache/vxquery/compiler/algebricks/package-summary.html">org.apache.vxquery.compiler.algebricks</a></dt>
 <dd>&nbsp;</dd>

Modified: incubator/vxquery/site/apidocs/org/apache/vxquery/cli/VXQuery.html
URL: http://svn.apache.org/viewvc/incubator/vxquery/site/apidocs/org/apache/vxquery/cli/VXQuery.html?rev=1550643&r1=1550642&r2=1550643&view=diff
==============================================================================
--- incubator/vxquery/site/apidocs/org/apache/vxquery/cli/VXQuery.html (original)
+++ incubator/vxquery/site/apidocs/org/apache/vxquery/cli/VXQuery.html Fri Dec 13 04:53:49 2013
@@ -115,7 +115,9 @@ extends <a href="http://docs.oracle.com/
 <th class="colOne" scope="col">Constructor and Description</th>
 </tr>
 <tr class="altColor">
-<td class="colOne"><code><strong><a href="../../../../org/apache/vxquery/cli/VXQuery.html#VXQuery(org.apache.vxquery.cli.VXQuery.CmdLineOptions)">VXQuery</a></strong>(org.apache.vxquery.cli.VXQuery.CmdLineOptions&nbsp;opts)</code>&nbsp;</td>
+<td class="colOne"><code><strong><a href="../../../../org/apache/vxquery/cli/VXQuery.html#VXQuery(org.apache.vxquery.cli.VXQuery.CmdLineOptions)">VXQuery</a></strong>(org.apache.vxquery.cli.VXQuery.CmdLineOptions&nbsp;opts)</code>
+<div class="block">Constructor to use command line options passed.</div>
+</td>
 </tr>
 </table>
 </li>
@@ -140,15 +142,21 @@ extends <a href="http://docs.oracle.com/
 </tr>
 <tr class="rowColor">
 <td class="colFirst"><code>static void</code></td>
-<td class="colLast"><code><strong><a href="../../../../org/apache/vxquery/cli/VXQuery.html#main(java.lang.String[])">main</a></strong>(<a href="http://docs.oracle.com/javase/6/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;args)</code>&nbsp;</td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/vxquery/cli/VXQuery.html#main(java.lang.String[])">main</a></strong>(<a href="http://docs.oracle.com/javase/6/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;args)</code>
+<div class="block">Main method to get command line options and execute query process.</div>
+</td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><strong><a href="../../../../org/apache/vxquery/cli/VXQuery.html#startLocalHyracks()">startLocalHyracks</a></strong>()</code>&nbsp;</td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/vxquery/cli/VXQuery.html#startLocalHyracks()">startLocalHyracks</a></strong>()</code>
+<div class="block">Start local virtual cluster with cluster controller node and node controller nodes.</div>
+</td>
 </tr>
 <tr class="rowColor">
 <td class="colFirst"><code>void</code></td>
-<td class="colLast"><code><strong><a href="../../../../org/apache/vxquery/cli/VXQuery.html#stopLocalHyracks()">stopLocalHyracks</a></strong>()</code>&nbsp;</td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/vxquery/cli/VXQuery.html#stopLocalHyracks()">stopLocalHyracks</a></strong>()</code>
+<div class="block">Shuts down the virtual cluster, alongwith all nodes and node execution, network and queue managers.</div>
+</td>
 </tr>
 </table>
 <ul class="blockList">
@@ -179,6 +187,8 @@ extends <a href="http://docs.oracle.com/
 <li class="blockList">
 <h4>VXQuery</h4>
 <pre>public&nbsp;VXQuery(org.apache.vxquery.cli.VXQuery.CmdLineOptions&nbsp;opts)</pre>
+<div class="block">Constructor to use command line options passed.</div>
+<dl><dt><span class="strong">Parameters:</span></dt><dd><code>opts</code> - Command line options object</dd></dl>
 </li>
 </ul>
 </li>
@@ -197,7 +207,9 @@ extends <a href="http://docs.oracle.com/
 <h4>main</h4>
 <pre>public static&nbsp;void&nbsp;main(<a href="http://docs.oracle.com/javase/6/docs/api/java/lang/String.html?is-external=true" title="class or interface in java.lang">String</a>[]&nbsp;args)
                  throws <a href="http://docs.oracle.com/javase/6/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
-<dl><dt><span class="strong">Throws:</span></dt>
+<div class="block">Main method to get command line options and execute query process.</div>
+<dl><dt><span class="strong">Parameters:</span></dt><dd><code>args</code> - </dd>
+<dt><span class="strong">Throws:</span></dt>
 <dd><code><a href="http://docs.oracle.com/javase/6/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></code></dd></dl>
 </li>
 </ul>
@@ -209,6 +221,7 @@ extends <a href="http://docs.oracle.com/
 <h4>createResultSetId</h4>
 <pre>protected&nbsp;edu.uci.ics.hyracks.api.dataset.ResultSetId&nbsp;createResultSetId()</pre>
 <div class="block">Create a unique result set id to get the correct query back from the cluster.</div>
+<dl><dt><span class="strong">Returns:</span></dt><dd>Result Set id generated with current system time.</dd></dl>
 </li>
 </ul>
 <a name="startLocalHyracks()">
@@ -219,6 +232,8 @@ extends <a href="http://docs.oracle.com/
 <h4>startLocalHyracks</h4>
 <pre>public&nbsp;void&nbsp;startLocalHyracks()
                        throws <a href="http://docs.oracle.com/javase/6/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
+<div class="block">Start local virtual cluster with cluster controller node and node controller nodes. IP address provided for node controller is localhost. Unassigned ports
+ 39000 and 39001 are used for client and cluster port respectively. Creates a new Hyracks connection with the IP address and client ports.</div>
 <dl><dt><span class="strong">Throws:</span></dt>
 <dd><code><a href="http://docs.oracle.com/javase/6/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></code></dd></dl>
 </li>
@@ -231,6 +246,7 @@ extends <a href="http://docs.oracle.com/
 <h4>stopLocalHyracks</h4>
 <pre>public&nbsp;void&nbsp;stopLocalHyracks()
                       throws <a href="http://docs.oracle.com/javase/6/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></pre>
+<div class="block">Shuts down the virtual cluster, alongwith all nodes and node execution, network and queue managers.</div>
 <dl><dt><span class="strong">Throws:</span></dt>
 <dd><code><a href="http://docs.oracle.com/javase/6/docs/api/java/lang/Exception.html?is-external=true" title="class or interface in java.lang">Exception</a></code></dd></dl>
 </li>

Modified: incubator/vxquery/site/apidocs/org/apache/vxquery/compiler/rewriter/RewriteRuleset.html
URL: http://svn.apache.org/viewvc/incubator/vxquery/site/apidocs/org/apache/vxquery/compiler/rewriter/RewriteRuleset.html?rev=1550643&r1=1550642&r2=1550643&view=diff
==============================================================================
--- incubator/vxquery/site/apidocs/org/apache/vxquery/compiler/rewriter/RewriteRuleset.html (original)
+++ incubator/vxquery/site/apidocs/org/apache/vxquery/compiler/rewriter/RewriteRuleset.html Fri Dec 13 04:53:49 2013
@@ -146,22 +146,32 @@ extends <a href="http://docs.oracle.com/
 </tr>
 <tr class="rowColor">
 <td class="colFirst"><code>static <a href="http://docs.oracle.com/javase/6/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;edu.uci.ics.hyracks.algebricks.core.rewriter.base.IAlgebraicRewriteRule&gt;</code></td>
-<td class="colLast"><code><strong><a href="../../../../../org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildJoinInferenceRuleCollection()">buildJoinInferenceRuleCollection</a></strong>()</code>&nbsp;</td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildIntroduceProjectRuleCollection()">buildIntroduceProjectRuleCollection</a></strong>()</code>&nbsp;</td>
 </tr>
 <tr class="altColor">
 <td class="colFirst"><code>static <a href="http://docs.oracle.com/javase/6/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;edu.uci.ics.hyracks.algebricks.core.rewriter.base.IAlgebraicRewriteRule&gt;</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildJoinInferenceRuleCollection()">buildJoinInferenceRuleCollection</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>static <a href="http://docs.oracle.com/javase/6/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;edu.uci.ics.hyracks.algebricks.core.rewriter.base.IAlgebraicRewriteRule&gt;</code></td>
 <td class="colLast"><code><strong><a href="../../../../../org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildNestedDataSourceRuleCollection()">buildNestedDataSourceRuleCollection</a></strong>()</code>
 <div class="block">When a nested data sources exist, convert the plan to use the join operator.</div>
 </td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code>static <a href="http://docs.oracle.com/javase/6/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;edu.uci.ics.hyracks.algebricks.core.rewriter.base.IAlgebraicRewriteRule&gt;</code></td>
 <td class="colLast"><code><strong><a href="../../../../../org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildNormalizationRuleCollection()">buildNormalizationRuleCollection</a></strong>()</code>&nbsp;</td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>static <a href="http://docs.oracle.com/javase/6/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;edu.uci.ics.hyracks.algebricks.core.rewriter.base.IAlgebraicRewriteRule&gt;</code></td>
 <td class="colLast"><code><strong><a href="../../../../../org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildOpPushDownRuleCollection()">buildOpPushDownRuleCollection</a></strong>()</code>&nbsp;</td>
 </tr>
+<tr class="altColor">
+<td class="colFirst"><code>static <a href="http://docs.oracle.com/javase/6/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;edu.uci.ics.hyracks.algebricks.core.rewriter.base.IAlgebraicRewriteRule&gt;</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildPathStepNormalizationRuleCollection()">buildPathStepNormalizationRuleCollection</a></strong>()</code>
+<div class="block">Optimizations specific to XQuery.</div>
+</td>
+</tr>
 <tr class="rowColor">
 <td class="colFirst"><code>static <a href="http://docs.oracle.com/javase/6/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;edu.uci.ics.hyracks.algebricks.core.rewriter.base.IAlgebraicRewriteRule&gt;</code></td>
 <td class="colLast"><code><strong><a href="../../../../../org/apache/vxquery/compiler/rewriter/RewriteRuleset.html#buildPhysicalRewritesAllLevelsRuleCollection()">buildPhysicalRewritesAllLevelsRuleCollection</a></strong>()</code>&nbsp;</td>
@@ -223,6 +233,16 @@ extends <a href="http://docs.oracle.com/
 <!--   -->
 </a>
 <h3>Method Detail</h3>
+<a name="buildPathStepNormalizationRuleCollection()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>buildPathStepNormalizationRuleCollection</h4>
+<pre>public static final&nbsp;<a href="http://docs.oracle.com/javase/6/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;edu.uci.ics.hyracks.algebricks.core.rewriter.base.IAlgebraicRewriteRule&gt;&nbsp;buildPathStepNormalizationRuleCollection()</pre>
+<div class="block">Optimizations specific to XQuery.</div>
+</li>
+</ul>
 <a name="buildXQueryNormalizationRuleCollection()">
 <!--   -->
 </a>
@@ -288,6 +308,15 @@ extends <a href="http://docs.oracle.com/
 <pre>public static final&nbsp;<a href="http://docs.oracle.com/javase/6/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;edu.uci.ics.hyracks.algebricks.core.rewriter.base.IAlgebraicRewriteRule&gt;&nbsp;buildOpPushDownRuleCollection()</pre>
 </li>
 </ul>
+<a name="buildIntroduceProjectRuleCollection()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>buildIntroduceProjectRuleCollection</h4>
+<pre>public static final&nbsp;<a href="http://docs.oracle.com/javase/6/docs/api/java/util/List.html?is-external=true" title="class or interface in java.util">List</a>&lt;edu.uci.ics.hyracks.algebricks.core.rewriter.base.IAlgebraicRewriteRule&gt;&nbsp;buildIntroduceProjectRuleCollection()</pre>
+</li>
+</ul>
 <a name="buildDataExchangeRuleCollection()">
 <!--   -->
 </a>

Modified: incubator/vxquery/site/apidocs/org/apache/vxquery/compiler/rewriter/rules/AbstractCollectionRule.html
URL: http://svn.apache.org/viewvc/incubator/vxquery/site/apidocs/org/apache/vxquery/compiler/rewriter/rules/AbstractCollectionRule.html?rev=1550643&r1=1550642&r2=1550643&view=diff
==============================================================================
--- incubator/vxquery/site/apidocs/org/apache/vxquery/compiler/rewriter/rules/AbstractCollectionRule.html (original)
+++ incubator/vxquery/site/apidocs/org/apache/vxquery/compiler/rewriter/rules/AbstractCollectionRule.html Fri Dec 13 04:53:49 2013
@@ -36,7 +36,7 @@
 <div class="subNav">
 <ul class="navList">
 <li>Prev Class</li>
-<li><a href="../../../../../../org/apache/vxquery/compiler/rewriter/rules/AbstractVXQueryAggregateRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules"><span class="strong">Next Class</span></a></li>
+<li><a href="../../../../../../org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules"><span class="strong">Next Class</span></a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../../../index.html?org/apache/vxquery/compiler/rewriter/rules/AbstractCollectionRule.html" target="_top">Frames</a></li>
@@ -252,7 +252,7 @@ implements edu.uci.ics.hyracks.algebrick
 <div class="subNav">
 <ul class="navList">
 <li>Prev Class</li>
-<li><a href="../../../../../../org/apache/vxquery/compiler/rewriter/rules/AbstractVXQueryAggregateRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules"><span class="strong">Next Class</span></a></li>
+<li><a href="../../../../../../org/apache/vxquery/compiler/rewriter/rules/AbstractUsedVariablesProcessingRule.html" title="class in org.apache.vxquery.compiler.rewriter.rules"><span class="strong">Next Class</span></a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../../../index.html?org/apache/vxquery/compiler/rewriter/rules/AbstractCollectionRule.html" target="_top">Frames</a></li>