Package | Description |
---|---|
com.bigdata.bop |
This package provides an API for query operators.
|
com.bigdata.bop.bset | |
com.bigdata.bop.constraint |
This package provides implementations for operators which impose constraints
on elements visited by some access path.
|
com.bigdata.bop.join | |
com.bigdata.bop.joinGraph |
This package provides support for join graphs, query optimization,
and generating full query plans from a join graph and the
evaluation order identified by a query optimizer.
|
com.bigdata.bop.joinGraph.rto | |
com.bigdata.bop.solutions |
This package provides distinct, sort, and aggregation operators.
|
com.bigdata.rdf.internal.constraints | |
com.bigdata.rdf.rules | |
com.bigdata.rdf.sparql.ast |
This package contains an Abstract Syntax Tree which provides an intermediate translation
target for SPARQL parsers.
|
com.bigdata.rdf.sparql.ast.eval | |
com.bigdata.relation.rule |
This package includes an abstraction layer for rules.
|
com.bigdata.relation.rule.eval |
This package supports rule evaluation.
|
Modifier and Type | Interface and Description |
---|---|
interface |
IValueExpressionConstraint<X> |
Modifier and Type | Field and Description |
---|---|
static IConstraint[] |
IConstraint.EMPTY
A zero length empty
IConstraint array. |
Modifier and Type | Method and Description |
---|---|
static IConstraint[] |
BOpUtility.concat(IConstraint[] a,
IConstraint[] b)
Combine two arrays of constraints.
|
Modifier and Type | Method and Description |
---|---|
static IBindingSet |
BOpContext.bind(IBindingSet left,
IBindingSet right,
IConstraint[] constraints,
IVariable[] varsToKeep)
Copy the values for variables from the source
IBindingSet to the
destination IBindingSet . |
static boolean |
BOpContext.bind(IPredicate<?> pred,
IConstraint[] constraints,
Object e,
IBindingSet bindings)
Deprecated.
|
static IConstraint[] |
BOpUtility.concat(IConstraint[] a,
IConstraint[] b)
Combine two arrays of constraints.
|
static IConstraint[] |
BOpUtility.concat(IConstraint[] a,
IConstraint[] b)
Combine two arrays of constraints.
|
static long |
BOpUtility.copy(Iterator<IBindingSet[]> source,
IBlockingBuffer<IBindingSet[]> sink,
IBlockingBuffer<IBindingSet[]> sink2,
IBindingSet mergeSolution,
IVariable<?>[] selectVars,
IConstraint[] constraints,
BOpStats stats)
Copy binding sets from the source to the sink(s).
|
static boolean |
BOpUtility.isConsistent(IConstraint[] constraints,
IBindingSet bindingSet)
Check constraints.
|
void |
BOpIdFactory.reserveIds(IConstraint[] constraints)
Reserve ids used by the constraints for some predicate or join graph.
|
Modifier and Type | Method and Description |
---|---|
IConstraint[] |
CopyOp.constraints() |
IConstraint |
ConditionalRoutingOp.getCondition() |
Modifier and Type | Class and Description |
---|---|
class |
Constraint<X>
Constraint wraps a BooleanValueExpression . |
Modifier and Type | Method and Description |
---|---|
static IConstraint |
Constraint.wrap(BooleanValueExpression ve)
Convenience method to generate a constraint from a value expression.
|
Modifier and Type | Field and Description |
---|---|
protected IConstraint[] |
JVMHashJoinUtility.constraints
The join constraints (optional).
|
Modifier and Type | Method and Description |
---|---|
protected IConstraint[] |
DistinctTermScanOp.constraints() |
IConstraint[] |
PipelineJoin.constraints() |
protected IConstraint[] |
FastRangeCountOp.constraints() |
protected IConstraint[] |
NestedLoopJoinOp.constraints() |
IConstraint[] |
IHashJoinUtility.getConstraints()
The join constraints (optional).
|
IConstraint[] |
JVMHashJoinUtility.getConstraints() |
IConstraint[] |
HTreeHashJoinUtility.getConstraints() |
Modifier and Type | Method and Description |
---|---|
long |
HTreePipelinedHashJoinUtility.acceptAndOutputSolutions(UnsyncLocalOutputBuffer<IBindingSet> out,
ICloseableIterator<IBindingSet[]> itr,
NamedSolutionSetStats stats,
IConstraint[] joinConstraints,
PipelineOp subquery,
IBindingSet[] bsFromBindingsSetSource,
IVariable<?>[] projectInVars,
IVariable<?> askVar,
boolean isLastInvocation,
int distinctProjectionBufferThreshold,
int incomingBindingsBufferThreshold,
BOpContext<IBindingSet> context) |
long |
PipelinedHashJoinUtility.acceptAndOutputSolutions(UnsyncLocalOutputBuffer<IBindingSet> out,
ICloseableIterator<IBindingSet[]> itr,
NamedSolutionSetStats stats,
IConstraint[] joinConstraints,
PipelineOp subquery,
IBindingSet[] bsFromBindingsSetSource,
IVariable<?>[] projectInVars,
IVariable<?> askVar,
boolean isLastInvocation,
int distinctProjectionBufferThreshold,
int incomingBindingsBufferThreshold,
BOpContext<IBindingSet> context)
AcceptAndOutputSolutions is a special method for building the hash index
of the
JVMPipelinedHashIndex , which accepts and immediately
forwards relevant solutions (non-blocking index). |
long |
JVMPipelinedHashJoinUtility.acceptAndOutputSolutions(UnsyncLocalOutputBuffer<IBindingSet> out,
ICloseableIterator<IBindingSet[]> itr,
NamedSolutionSetStats stats,
IConstraint[] joinConstraints,
PipelineOp subquery,
IBindingSet[] bsFromBindingsSetSource,
IVariable<?>[] projectInVars,
IVariable<?> askVar,
boolean isLastInvocation,
int distinctProjectionBufferThreshold,
int incomingBindingsBufferThreshold,
BOpContext<IBindingSet> context) |
protected void |
AbstractHashJoinUtilityTestCase.doHashJoinTest(JoinTypeEnum joinType,
IVariable<?>[] joinVars,
IVariable<?>[] selectVars,
IConstraint[] constraints,
List<IBindingSet> left,
List<IBindingSet> right,
IBindingSet[] expected)
Test helper for required or optional join tests.
|
protected void |
AbstractHashJoinUtilityTestCase.doMergeJoinTest(IConstraint[] constraints,
IBindingSet[] expected,
boolean optional,
IHashJoinUtility first,
IHashJoinUtility... others) |
void |
IHashJoinUtility.hashJoin2(ICloseableIterator<IBindingSet[]> leftItr,
BOpStats stats,
IBuffer<IBindingSet> outputBuffer,
IConstraint[] constraints)
Variant hash join method allows the caller to impose different
constraints or additional constraints.
|
void |
JVMHashJoinUtility.hashJoin2(ICloseableIterator<IBindingSet[]> leftItr,
BOpStats stats,
IBuffer<IBindingSet> outputBuffer,
IConstraint[] constraints)
Variant hash join method allows the caller to impose different
constraints or additional constraints.
|
void |
HTreeHashJoinUtility.hashJoin2(ICloseableIterator<IBindingSet[]> leftItr,
BOpStats stats,
IBuffer<IBindingSet> outputBuffer,
IConstraint[] constraints) |
void |
HTreePipelinedHashJoinUtility.hashJoinAndEmit(IBindingSet[] chunk,
BOpStats stats,
IBuffer<IBindingSet> outputBuffer,
IConstraint[] joinConstraints,
IVariable<?> askVar)
Executes the hash join for the chunk of solutions that is passed in
over rightSolutions and outputs the solutions.
|
void |
JVMPipelinedHashJoinUtility.hashJoinAndEmit(IBindingSet[] chunk,
BOpStats stats,
IBuffer<IBindingSet> outputBuffer,
IConstraint[] joinConstraints,
IVariable<?> askVar)
Executes the hash join for the chunk of solutions that is passed in
over rightSolutions and outputs the solutions.
|
void |
IHashJoinUtility.mergeJoin(IHashJoinUtility[] others,
IBuffer<IBindingSet> outputBuffer,
IConstraint[] constraints,
boolean optional)
Perform an N-way merge join.
|
void |
JVMHashJoinUtility.mergeJoin(IHashJoinUtility[] others,
IBuffer<IBindingSet> outputBuffer,
IConstraint[] constraints,
boolean optional) |
void |
HTreeHashJoinUtility.mergeJoin(IHashJoinUtility[] others,
IBuffer<IBindingSet> outputBuffer,
IConstraint[] constraints,
boolean optional)
Perform an N-way merge join.
|
Modifier and Type | Method and Description |
---|---|
IConstraint[] |
PartitionedJoinGroup.getJoinGraphConstraints()
Deprecated.
The
IConstraint s to be applied to the IPredicate s in the
join graph. |
IConstraint[] |
PartitionedJoinGroup.getJoinGraphConstraints(int[] pathIds,
boolean pathIsComplete)
Deprecated.
Return the set of constraints which should be attached to the last join
in the given the join path.
|
static IConstraint[][] |
PartitionedJoinGroup.getJoinGraphConstraints(IPredicate<?>[] path,
IConstraint[] joinGraphConstraints,
IVariable<?>[] knownBoundVars,
boolean pathIsComplete)
Deprecated.
Given a join path, return the set of constraints to be associated with
each join in that join path.
|
IConstraint[] |
PartitionedJoinGroup.getTailPlanConstraints(int bopId)
Deprecated.
Return the set of
IConstraint s which should be evaluated when an
identified predicate having SPARQL optional semantics is evaluated. |
Modifier and Type | Method and Description |
---|---|
static boolean |
PartitionedJoinGroup.canJoinUsingConstraints(IPredicate<?>[] path,
IPredicate<?> vertex,
IConstraint[] constraints)
Deprecated.
Return
true iff a predicate may be used to extend a join
path on the basis of at least one variable which is shared either
directly or via one or more constraints which may be attached to the
predicate when it is added to the join path. |
static IConstraint[][] |
PartitionedJoinGroup.getJoinGraphConstraints(IPredicate<?>[] path,
IConstraint[] joinGraphConstraints,
IVariable<?>[] knownBoundVars,
boolean pathIsComplete)
Deprecated.
Given a join path, return the set of constraints to be associated with
each join in that join path.
|
Constructor and Description |
---|
PartitionedJoinGroup(IPredicate<?>[] sourcePreds,
IConstraint[] constraints)
Deprecated.
Analyze a set of
IPredicate s representing "runFirst", optional
joins, and non-optional joins which may be freely reordered together with
a collection of IConstraint s and partition them into a join graph
and a tail plan. |
Modifier and Type | Method and Description |
---|---|
IConstraint[] |
JoinGraph.getConstraints() |
Modifier and Type | Method and Description |
---|---|
Path |
Path.addEdge(QueryEngine queryEngine,
JoinGraph joinGraph,
int limit,
Vertex vnew,
IConstraint[] constraints,
boolean pathIsComplete)
Add an edge to a path, computing the estimated cardinality of the new
path, and returning the new path.
|
static EdgeSample |
Path.cutoffJoin(QueryEngine queryEngine,
JoinGraph joinGraph,
int limit,
IPredicate<?>[] path,
IConstraint[] constraints,
boolean pathIsComplete,
SampleBase sourceSample)
Cutoff join of the last vertex in the join path.
|
Modifier and Type | Method and Description |
---|---|
IConstraint[] |
IGroupByRewriteState.getHaving2()
A modified version of the original HAVING expression which has the same
semantics (and
null iff the original was null
or empty). |
IConstraint[] |
GroupByRewriter.getHaving2()
A modified version of the original HAVING expression which has the same
semantics (and
null iff the original was null
or empty). |
IConstraint[] |
GroupByState.getHavingClause() |
IConstraint[] |
IGroupByState.getHavingClause()
Optional constraints applied to the aggregated solutions.
|
static IConstraint |
GroupByRewriter.rewrite(IConstraint e,
IVariableFactory f,
LinkedHashMap<IAggregate<?>,IVariable<?>> aggExpr)
Rewrite an
IConstraint . |
Modifier and Type | Method and Description |
---|---|
protected GroupByOp |
TestPipelinedAggregationOp.newFixture(IValueExpression<?>[] select,
IValueExpression<?>[] groupBy,
IConstraint[] having) |
protected GroupByOp |
TestMemoryGroupByOp.newFixture(IValueExpression<?>[] select,
IValueExpression<?>[] groupBy,
IConstraint[] having) |
protected abstract GroupByOp |
AbstractAggregationTestCase.newFixture(IValueExpression<?>[] select,
IValueExpression<?>[] groupBy,
IConstraint[] having)
Factory for
GroupByOp to be tested. |
static IConstraint |
GroupByRewriter.rewrite(IConstraint e,
IVariableFactory f,
LinkedHashMap<IAggregate<?>,IVariable<?>> aggExpr)
Rewrite an
IConstraint . |
Constructor and Description |
---|
GroupByState(IValueExpression<?>[] select,
IValueExpression<?>[] groupBy,
IConstraint[] having) |
Modifier and Type | Class and Description |
---|---|
class |
ProjectedConstraint
This class implements 'AS' in a projection as found in both
subselects and bind, e.g.
|
class |
SPARQLConstraint<X extends XSDBooleanIV>
BOpConstraint that wraps a
EBVBOp , which itself computes the
effective boolean value of an IValueExpression . |
class |
TryBeforeMaterializationConstraint
This is useful when a solution can be filtered out before it goes through the
materialization pipeline.
|
Constructor and Description |
---|
TryBeforeMaterializationConstraint(IConstraint x) |
Constructor and Description |
---|
AbstractRuleDistinctTermScan(String name,
SPOPredicate head,
SPOPredicate[] body,
IConstraint[] constraints) |
AbstractRuleFastClosure_11_13(String name,
SPOPredicate head,
SPOPredicate[] body,
IConstraint[] constraints) |
Modifier and Type | Method and Description |
---|---|
IConstraint[] |
HavingNode.getConstraints()
Return the
IConstraint s for this HavingNode . |
Modifier and Type | Method and Description |
---|---|
static boolean |
StaticAnalysis.requiresMaterialization(IConstraint c)
Use the
INeedsMaterialization interface to find and collect
variables that need to be materialized for this constraint. |
Modifier and Type | Method and Description |
---|---|
protected static IConstraint[] |
AST2BOpFilters.getJoinConstraints(Collection<IConstraint> constraints,
Map<IConstraint,Set<IVariable<IV>>> needsMaterialization)
Partition the constraints for a join into those which can (or might) be
able to run attached to that join and those which must (or might) need to
materialize some variables before they can be evaluated.
|
protected static IConstraint[] |
AST2BOpFilters.getJoinConstraints2(Collection<IConstraint> constraints,
Map<IConstraint,Set<IVariable<IV>>> needsMaterialization,
boolean conditionalRouting)
Partition the constraints for a join into those which can (or might) be
able to run attached to that join and those which must (or might) need to
materialize some variables before they can be evaluated.
|
Modifier and Type | Method and Description |
---|---|
protected static List<IConstraint> |
AST2BOpFilters.getJoinConstraints(IJoinNode joinNode)
Convert the attached join filters into a list of
IConstraint s. |
Modifier and Type | Method and Description |
---|---|
static EdgeSample |
AST2BOpRTO.cutoffJoin(QueryEngine queryEngine,
JoinGraph joinGraph,
int limit,
IPredicate<?>[] predicates,
IConstraint[] constraints,
boolean pathIsComplete,
SampleBase sourceSample)
Cutoff join of the last vertex in the join path.
|
Modifier and Type | Method and Description |
---|---|
protected static PipelineOp |
AST2BOpFilters.addMaterializationSteps3(PipelineOp left,
Set<IVariable<?>> doneSet,
Map<IConstraint,Set<IVariable<IV>>> needsMaterialization,
Properties queryHints,
AST2BOpContext ctx)
For each filter which requires materialization steps, add the
materializations steps to the pipeline and then add the filter to the
pipeline.
|
protected static PipelineOp |
AST2BOpFilters.addNonConditionalMaterializationSteps(PipelineOp left,
Set<IVariable<?>> doneSet,
Map<IConstraint,Set<IVariable<IV>>> needsMaterialization,
Long cutoffLimit,
Properties queryHints,
AST2BOpContext ctx)
The RTO requires that we do not reorder solutions.
|
protected static IConstraint[] |
AST2BOpFilters.getJoinConstraints(Collection<IConstraint> constraints,
Map<IConstraint,Set<IVariable<IV>>> needsMaterialization)
Partition the constraints for a join into those which can (or might) be
able to run attached to that join and those which must (or might) need to
materialize some variables before they can be evaluated.
|
protected static IConstraint[] |
AST2BOpFilters.getJoinConstraints(Collection<IConstraint> constraints,
Map<IConstraint,Set<IVariable<IV>>> needsMaterialization)
Partition the constraints for a join into those which can (or might) be
able to run attached to that join and those which must (or might) need to
materialize some variables before they can be evaluated.
|
protected static IConstraint[] |
AST2BOpFilters.getJoinConstraints2(Collection<IConstraint> constraints,
Map<IConstraint,Set<IVariable<IV>>> needsMaterialization,
boolean conditionalRouting)
Partition the constraints for a join into those which can (or might) be
able to run attached to that join and those which must (or might) need to
materialize some variables before they can be evaluated.
|
protected static IConstraint[] |
AST2BOpFilters.getJoinConstraints2(Collection<IConstraint> constraints,
Map<IConstraint,Set<IVariable<IV>>> needsMaterialization,
boolean conditionalRouting)
Partition the constraints for a join into those which can (or might) be
able to run attached to that join and those which must (or might) need to
materialize some variables before they can be evaluated.
|
static PipelineOp |
AST2BOpJoins.join(PipelineOp left,
Predicate pred,
Set<IVariable<?>> doneSet,
Collection<IConstraint> constraints,
Long cutoffLimit,
Properties queryHints,
AST2BOpContext ctx)
Add a join for a statement pattern.
|
Modifier and Type | Method and Description |
---|---|
IConstraint |
IRule.getConstraint(int index)
Return the constraint at the given index.
|
IConstraint |
Rule.getConstraint(int index) |
Modifier and Type | Method and Description |
---|---|
Iterator<IConstraint> |
IRule.getConstraints()
The optional constraints.
|
Iterator<IConstraint> |
Rule.getConstraints() |
Modifier and Type | Method and Description |
---|---|
IRule<E> |
IRule.specialize(IBindingSet bindingSet,
IConstraint[] constraints)
Specialize a rule - the name of the new rule will be derived from the
name of the old rule with an appended single quote to indicate that it is
a derived variant.
|
IRule<E> |
Rule.specialize(IBindingSet bindingSet,
IConstraint[] constraints) |
IRule<E> |
IRule.specialize(String name,
IBindingSet bindingSet,
IConstraint[] constraints)
Specialize a rule by binding zero or more variables and adding zero or
more constraints.
|
IRule<E> |
Rule.specialize(String name,
IBindingSet bindingSet,
IConstraint[] constraints) |
Constructor and Description |
---|
Rule(String name,
IPredicate head,
IPredicate[] tail,
IConstraint[] constraints)
Rule ctor.
|
Rule(String name,
IPredicate head,
IPredicate[] tail,
IQueryOptions queryOptions,
IConstraint[] constraints)
Rule ctor.
|
Rule(String name,
IPredicate head,
IPredicate[] tail,
IQueryOptions queryOptions,
IConstraint[] constraints,
IBindingSet constants,
IRuleTaskFactory taskFactory) |
Rule(String name,
IPredicate head,
IPredicate[] tail,
IQueryOptions queryOptions,
IConstraint[] constraints,
IBindingSet constants,
IRuleTaskFactory taskFactory,
IVariable[] requiredVars)
Fully specified ctor.
|
Modifier and Type | Method and Description |
---|---|
boolean |
AbstractJoinNexus.bind(IPredicate<?> pred,
IConstraint[] constraints,
Object e,
IBindingSet bindings) |
boolean |
IJoinNexus.bind(IPredicate<?> pred,
IConstraint[] constraints,
Object e,
IBindingSet bindings)
Binds variables from a visited element.
|
Copyright © 2006–2019 SYSTAP, LLC DBA Blazegraph. All rights reserved.