Package | Description |
---|---|
com.bigdata.bop |
This package provides an API for query operators.
|
com.bigdata.bop.ap | |
com.bigdata.bop.bset | |
com.bigdata.bop.controller |
This package provides operators for subquery, including UNION, STEPS,
and STAR (transitive closure).
|
com.bigdata.bop.engine | |
com.bigdata.bop.fed | |
com.bigdata.bop.join | |
com.bigdata.bop.joinGraph.rto | |
com.bigdata.bop.mutation | |
com.bigdata.bop.paths | |
com.bigdata.bop.rdf.join | |
com.bigdata.bop.rdf.update |
This package provides bigdata operators for SPARQL update.
|
com.bigdata.bop.solutions |
This package provides distinct, sort, and aggregation operators.
|
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.rdf.sparql.ast.eval.update |
Modifier and Type | Method and Description |
---|---|
PipelineOp |
BOpContext.getOperator()
Return the operator that is being executed.
|
static PipelineOp |
BOpUtility.makeAggregateDistinct(PipelineOp subQuery)
Return a copy of the subquery in which each
IAggregate function
is a distinct instance. |
Modifier and Type | Method and Description |
---|---|
static PipelineOp |
BOpUtility.makeAggregateDistinct(PipelineOp subQuery)
Return a copy of the subquery in which each
IAggregate function
is a distinct instance. |
static <E> BOpContext<E> |
BOpContext.newMock(IRunningQuery runningQuery,
IBigdataFederation<?> fed,
IIndexManager localIndexManager,
int partitionId,
BOpStats stats,
PipelineOp op,
boolean lastInvocation,
ICloseableIterator<E[]> source,
IBlockingBuffer<E[]> sink,
IBlockingBuffer<E[]> sink2)
Test suite helper.
|
Constructor and Description |
---|
BOpContext(IRunningQuery runningQuery,
int partitionId,
BOpStats stats,
PipelineOp op,
boolean lastInvocation,
ICloseableIterator<E[]> source,
IBlockingBuffer<E[]> sink,
IBlockingBuffer<E[]> sink2) |
PipelineOp(PipelineOp op)
Constructor required for
com.bigdata.bop.BOpUtility#deepCopy(FilterNode) . |
Modifier and Type | Class and Description |
---|---|
protected class |
TestPredicateAccessPath.MockPipelineOp |
Modifier and Type | Class and Description |
---|---|
class |
ConditionalRoutingOp
An operator for conditional routing of binding sets in a pipeline.
|
class |
CopyOp
This operator copies its source to its sink(s).
|
class |
EndOp
A operator which may be used at the end of query pipelines when there is a
requirement to marshal solutions back to the query controller but no
requirement to
slice solutions. |
class |
StartOp
A version of
CopyOp which is always evaluated on the query
controller. |
class |
Tee
TEE(op):[sinkRef=X; altSinkRef=Y]
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractSubqueryOp
Executes each of the operands as a subquery.
|
class |
HTreeNamedSubqueryOp
Evaluation of a subquery, producing a named result set.
|
class |
JVMNamedSubqueryOp
Evaluation of a subquery, producing a named result set.
|
class |
ServiceCallJoin
Vectored pipeline join of the source solution(s) with solutions from a a
SERVICE invocation.
|
class |
Steps
STEPS(ops)
|
class |
SubqueryOp
Pipelined join with subquery.
|
class |
Union
UNION()[maxParallel(default all); subqueries=ops]
|
Modifier and Type | Class and Description |
---|---|
class |
PipelineDelayOp
Operator blocks evaluation (sleeps) for the specified
PipelineDelayOp.Annotations.DELAY and then throws an PipelineDelayError . |
Modifier and Type | Method and Description |
---|---|
PipelineOp |
IQueryDecl.getQuery()
The query.
|
PipelineOp |
AbstractRunningQuery.getQuery() |
PipelineOp |
QueryDecl.getQuery() |
PipelineOp |
QueryEngine.getQuery(UUID queryId) |
PipelineOp |
IQueryClient.getQuery(UUID queryId)
Return the query.
|
Modifier and Type | Method and Description |
---|---|
AbstractRunningQuery |
QueryEngine.eval(UUID queryId,
PipelineOp query,
Map<Object,Object> queryAttributes,
IChunkMessage<IBindingSet> msg)
Evaluate a query.
|
protected IChunkHandler |
ChunkedRunningQuery.getChunkHandler(QueryEngine queryEngine,
PipelineOp query)
Factory returns the effective
IChunkHandler for this query. |
protected IBlockingBuffer<IBindingSet[]> |
AbstractRunningQuery.newQueryBuffer(PipelineOp query,
BOpStats queryStats)
Return the buffer that will be used to absorb solutions.
|
protected AbstractRunningQuery |
QueryEngine.newRunningQuery(UUID queryId,
boolean controller,
IQueryClient clientProxy,
UUID queryControllerId,
PipelineOp query,
IChunkMessage<IBindingSet> realSource)
Factory for
IRunningQuery s. |
Constructor and Description |
---|
AbstractRunningQuery(QueryEngine queryEngine,
UUID queryId,
boolean controller,
IQueryClient clientProxy,
PipelineOp query,
IChunkMessage<IBindingSet> realSource) |
BlockingBufferWithStats(PipelineOp op,
BOpStats stats) |
ChunkedRunningQuery(QueryEngine queryEngine,
UUID queryId,
boolean controller,
IQueryClient clientProxy,
PipelineOp query,
IChunkMessage<IBindingSet> realSource) |
QueryDecl(IQueryClient clientProxy,
UUID queryId,
PipelineOp query) |
Modifier and Type | Class and Description |
---|---|
protected class |
TestRemoteAccessPath.MockPipelineOp |
Modifier and Type | Method and Description |
---|---|
protected IChunkHandler |
FederatedRunningQuery.getChunkHandler(QueryEngine queryEngine,
PipelineOp query) |
protected FederatedRunningQuery |
FederatedQueryEngine.newRunningQuery(UUID queryId,
boolean controller,
IQueryClient clientProxy,
UUID queryControllerId,
PipelineOp query,
IChunkMessage<IBindingSet> realSource)
Factory for
IRunningQuery s. |
Constructor and Description |
---|
FederatedRunningQuery(FederatedQueryEngine queryEngine,
UUID queryId,
boolean controller,
IQueryClient clientProxy,
UUID queryControllerId,
PipelineOp query,
IChunkMessage<IBindingSet> realSource) |
Modifier and Type | Class and Description |
---|---|
protected class |
AbstractHashJoinUtilityTestCase.MockPipelineOp |
class |
AbstractMergeJoin
Abstract base class for MERGE JOIN implementations.
|
class |
DistinctTermScanOp<E>
This operator performs a distinct terms scan for an
IPredicate ,
binding the distinct values for the specified variable(s) from the
IAccessPath for the IPredicate . |
class |
FastRangeCountOp<E>
This operator reports the fast-range count for an as-bound
IPredicate
. |
class |
HashIndexOp
Operator builds a hash index from the source solutions.
|
class |
HashIndexOpBase
Base class for operators that use a hash index.
|
class |
HashJoinOp<E>
Abstract base class for both JVM and native memory hash join against an
IAccessPath . |
class |
HTreeHashJoinOp<E>
A hash join against an
IAccessPath based on the HTree and
suitable for very large intermediate result sets. |
class |
HTreeMergeJoin
An N-way merge join based on the
HTree . |
class |
HTreeSolutionSetHashJoinOp |
class |
JVMHashJoinOp<E>
A hash join against an
IAccessPath based on the Java collections
classes. |
class |
JVMMergeJoin
An N-way merge join on the Java heap.
|
class |
JVMSolutionSetHashJoinOp |
class |
NestedLoopJoinOp
This operator performs a nested loop join for solutions.
|
class |
PipelinedHashIndexAndSolutionSetJoinOp
Operator for pipelined hash index construction and subsequent join.
|
class |
PipelineJoin<E>
Pipelined join operator for online (selective) queries.
|
class |
SolutionSetHashJoinOp
Operator joins a solution set modeled as a hash index into the pipeline.
|
Modifier and Type | Method and Description |
---|---|
protected abstract PipelineOp |
AbstractHashJoinOpTestCase.newJoin(BOp[] args,
int joinId,
IVariable<IV>[] joinVars,
Predicate<IV> predOp,
UUID queryId,
NV... annotations)
Return a new join operator instance for the test.
|
protected PipelineOp |
TestJVMHashJoinOp.newJoin(BOp[] args,
int joinId,
IVariable<IV>[] joinVars,
Predicate<IV> predOp,
UUID queryId,
NV... annotations) |
protected PipelineOp |
TestHTreeHashJoinOp.newJoin(BOp[] args,
int joinId,
IVariable<IV>[] joinVars,
Predicate<IV> predOp,
UUID queryId,
NV... annotations) |
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) |
IHashJoinUtility |
IHashJoinUtilityFactory.create(BOpContext<IBindingSet> context,
INamedSolutionSetRef namedSetRef,
PipelineOp op,
JoinTypeEnum joinType)
Return an instance of the
IHashJoinUtility . |
protected static HTreeIndexMetadata |
HTreeHashJoinUtility.getIndexMetadata(PipelineOp op)
|
protected HTreeHashJoinUtility |
TestHTreeHashJoinUtility.newHashJoinUtility(PipelineOp op,
JoinTypeEnum joinType) |
protected JVMHashJoinUtility |
TestJVMHashJoinUtility.newHashJoinUtility(PipelineOp op,
JoinTypeEnum joinType) |
protected abstract IHashJoinUtility |
AbstractHashJoinUtilityTestCase.newHashJoinUtility(PipelineOp op,
JoinTypeEnum joinType)
Factory for
IHashJoinUtility instances under test. |
Constructor and Description |
---|
HTreeHashJoinUtility(IMemoryManager mmgr,
PipelineOp op,
JoinTypeEnum joinType) |
HTreePipelinedHashJoinUtility(IMemoryManager mmgr,
PipelineOp op,
JoinTypeEnum joinType) |
HTreePipelinedHashJoinUtility(PipelineOp op,
JoinTypeEnum joinType,
BOpContext<IBindingSet> context,
int chunkCapacity) |
JVMHashJoinUtility(PipelineOp op,
JoinTypeEnum joinType) |
JVMPipelinedHashJoinUtility(PipelineOp op,
JoinTypeEnum joinType,
BOpContext<IBindingSet> context,
int chunkCapacity) |
Modifier and Type | Class and Description |
---|---|
class |
JoinGraph
A join graph with annotations for estimated cardinality and other details in
support of runtime query optimization.
|
Modifier and Type | Method and Description |
---|---|
PipelineOp |
JoinGraph.getQueryPlan(IRunningQuery q)
Return the query plan to be executed based on the RTO determined join
ordering.
|
Modifier and Type | Class and Description |
---|---|
class |
InsertOp<E>
This operator writes elements constructed from binding sets and an orders
list of variables and constants on an index.
|
Modifier and Type | Class and Description |
---|---|
class |
ArbitraryLengthPathOp |
class |
ZeroLengthPathOp
Deprecated.
Does not work. Leads to cardinality problems and can be removed.
Zero Length Paths are integrated into the ALP node /
ArbitraryLengthPathOp now.
|
Modifier and Type | Class and Description |
---|---|
class |
ChunkedMaterializationOp
A vectored materialization operator based on pretty much the same logic as
BigdataBindingSetResolverator . |
class |
DataSetJoin
DataSetJoin(left)[var=g; graphs={graphIds}]
|
class |
InlineMaterializeOp<E>
This operator is used as part of the BigdataValue materialization step inside
the pipeline.
|
class |
MockTermResolverOp
A vectored operator that resolves variables bound to mocked terms in binding
sets through a dictionary join.
|
class |
VariableUnificationOp
Operator computing a join over two variables already bound variables in the
mapping set (for which the IV has been computed already).
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractAddRemoveStatementsOp
Abstract base class for operations which add or remove statements from the
statement indices.
|
class |
ChunkedResolutionOp
Vectored operator adds and/or resolves the RDF
Value s associated with
mock IV s. |
class |
CommitOp
Commit the operation.
|
class |
InsertDataOp
Operator to insert
ISPO s into bigdata. |
class |
InsertStatementsOp
Vectored insert operator for RDF Statements.
|
class |
ParseOp
Operator parses a RDF data source, writing bindings which represent
statements onto the output sink.
|
class |
RemoveStatementsOp
Vectored remove operator for RDF Statements.
|
Constructor and Description |
---|
InsertDataOp(PipelineOp op) |
Modifier and Type | Class and Description |
---|---|
class |
DropOp
Operator drops the identified variables from the solutions
|
class |
GroupByOp
Base class for operators which perform aggregation operations on binding
sets.
|
class |
HTreeDistinctBindingSetsOp
A pipelined DISTINCT operator based on the persistence capable
HTree
suitable for very large solution sets. |
class |
JVMDistinctBindingSetsOp
A pipelined DISTINCT operator based on a hash table.
|
class |
MemoryGroupByOp
An in-memory at-once generalized aggregation operator.
|
class |
MemorySortOp
An in-memory merge sort for binding sets.
|
class |
MockQuery |
class |
PipelinedAggregationOp
A pipelined aggregation operator based on an in memory hash table associating
with per-group state for each aggregate expression (it can also handle the
degenerate case where all solutions form a single implicit group).
|
class |
ProjectionOp
Operator projects only the identified variables.
|
class |
SliceOp
An operator which imposes an offset/limit on a binding set pipeline.
|
class |
SortOp
Base class for operators which sort binding sets.
|
Modifier and Type | Method and Description |
---|---|
protected abstract PipelineOp |
AbstractDistinctSolutionsTestCase.newDistinctBindingSetsOp(BOp[] args,
NV... anns)
Factory for a DISTINCT SOLUTIONS operator.
|
protected PipelineOp |
TestHTreeDistinctBindingSets.newDistinctBindingSetsOp(BOp[] args,
NV... anns) |
protected PipelineOp |
TestJVMDistinctBindingSets.newDistinctBindingSetsOp(BOp[] args,
NV... anns) |
Modifier and Type | Method and Description |
---|---|
PipelineOp |
ASTContainer.getQueryPlan()
Return the physical query plan (pipeline bops).
|
Modifier and Type | Method and Description |
---|---|
void |
ASTContainer.setQueryPlan(PipelineOp queryPlan)
Set the physical plan for query or update (pipeline bops).
|
Modifier and Type | Method and Description |
---|---|
protected static PipelineOp |
AST2BOpFilters.addChunkedMaterializationStep(PipelineOp left,
Set<IVariable<IV>> vars,
boolean materializeInlineIvs,
Long cutoffLimit,
Properties queryHints,
AST2BOpContext ctx)
Use a pipeline operator which uses the chunked materialization pattern
for solution sets.
|
protected static PipelineOp |
AST2BOpFilters.addMaterializationSteps1(PipelineOp left,
int rightId,
IValueExpression<IV> ve,
Set<IVariable<IV>> vars,
Properties queryHints,
AST2BOpContext ctx)
If the value expression that needs the materialized variables can run
without a
NotMaterializedException then just route to the
rightId (around the rest of the materialization pipeline steps). |
protected static PipelineOp |
AST2BOpFilters.addMaterializationSteps2(PipelineOp left,
int rightId,
Set<IVariable<IV>> vars,
Properties queryHints,
AST2BOpContext ctx)
Adds a series of materialization steps to materialize terms needed
downstream.
|
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 PipelineOp |
AST2BOpBase.applyQueryHints(PipelineOp op,
ASTBase node,
AST2BOpContext ctx)
Apply any query hints to the operator as annotations of that operator.
|
protected static PipelineOp |
AST2BOpBase.applyQueryHints(PipelineOp op,
Properties nodeQueryHints,
AST2BOpContext ctx)
Apply any query hints to the operator as annotations of that operator.
|
static PipelineOp |
AST2BOpRTO.compileJoinGraph(QueryEngine queryEngine,
JoinGraph joinGraph,
Path path)
Compile a join graph into a query plan.
|
PipelineOp |
IExternalAST2BOp.convertJoinGroup(PipelineOp left,
JoinGroupNode joinGroup,
Set<IVariable<?>> doneSet,
AtomicInteger start,
AST2BOpContext ctx)
Translate the given join group.
|
protected static PipelineOp |
AST2BOpRTO.convertRTOJoinGraph(PipelineOp left,
JoinGroupNode joinGroup,
Set<IVariable<?>> doneSet,
AST2BOpContext ctx,
AtomicInteger start)
Inspect the remainder of the join group.
|
protected static PipelineOp |
AST2BOpUpdate.convertUpdate(AST2BOpUpdateContext context)
Convert and/or execute the update request.
|
PipelineOp |
IExternalAST2BOp.fastRangeCountJoin(PipelineOp left,
List<NV> anns,
Predicate<?> pred,
DatasetNode dataset,
Long cutoffLimitIsIgnored,
VarNode fastRangeCountVar,
Properties queryHints,
AST2BOpContext ctx)
Use a
FastRangeCountOp . |
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 |
---|---|
protected static PipelineOp |
AST2BOpFilters.addChunkedMaterializationStep(PipelineOp left,
Set<IVariable<IV>> vars,
boolean materializeInlineIvs,
Long cutoffLimit,
Properties queryHints,
AST2BOpContext ctx)
Use a pipeline operator which uses the chunked materialization pattern
for solution sets.
|
protected static PipelineOp |
AST2BOpFilters.addMaterializationSteps1(PipelineOp left,
int rightId,
IValueExpression<IV> ve,
Set<IVariable<IV>> vars,
Properties queryHints,
AST2BOpContext ctx)
If the value expression that needs the materialized variables can run
without a
NotMaterializedException then just route to the
rightId (around the rest of the materialization pipeline steps). |
protected static PipelineOp |
AST2BOpFilters.addMaterializationSteps2(PipelineOp left,
int rightId,
Set<IVariable<IV>> vars,
Properties queryHints,
AST2BOpContext ctx)
Adds a series of materialization steps to materialize terms needed
downstream.
|
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 PipelineOp |
AST2BOpBase.applyQueryHints(PipelineOp op,
ASTBase node,
AST2BOpContext ctx)
Apply any query hints to the operator as annotations of that operator.
|
protected static PipelineOp |
AST2BOpBase.applyQueryHints(PipelineOp op,
Properties nodeQueryHints,
AST2BOpContext ctx)
Apply any query hints to the operator as annotations of that operator.
|
protected void |
TestPipelinedHashJoin.assertPipelinedPlanOrNot(PipelineOp queryPlan,
ASTContainer container,
boolean assertPipelined,
boolean analyticMode)
Asserts that a PipelinedHashIndexAndSolutionSetOp is contained in the
query plan if contains equals
true , otherwise that it is
NOT contained. |
PipelineOp |
IExternalAST2BOp.convertJoinGroup(PipelineOp left,
JoinGroupNode joinGroup,
Set<IVariable<?>> doneSet,
AtomicInteger start,
AST2BOpContext ctx)
Translate the given join group.
|
protected static PipelineOp |
AST2BOpRTO.convertRTOJoinGraph(PipelineOp left,
JoinGroupNode joinGroup,
Set<IVariable<?>> doneSet,
AST2BOpContext ctx,
AtomicInteger start)
Inspect the remainder of the join group.
|
PipelineOp |
IExternalAST2BOp.fastRangeCountJoin(PipelineOp left,
List<NV> anns,
Predicate<?> pred,
DatasetNode dataset,
Long cutoffLimitIsIgnored,
VarNode fastRangeCountVar,
Properties queryHints,
AST2BOpContext ctx)
Use a
FastRangeCountOp . |
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.
|
protected static BOp[] |
AST2BOpBase.leftOrEmpty(PipelineOp left)
Return either left wrapped as the sole member of an array or
BOp.NOARGS iff left is null . |
Modifier and Type | Method and Description |
---|---|
protected static BOp[] |
TestUpdateBootstrap.leftOrEmpty(PipelineOp left)
Return either left wrapped as the sole member of an array or
BOp.NOARGS iff left is null . |
Copyright © 2006–2019 SYSTAP, LLC DBA Blazegraph. All rights reserved.