Package | Description |
---|---|
com.bigdata.bop |
This package provides an API for query operators.
|
com.bigdata.bop.aggregate | |
com.bigdata.bop.ap | |
com.bigdata.bop.bindingSet | |
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.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.fed.shards | |
com.bigdata.bop.join | |
com.bigdata.bop.joinGraph.rto | |
com.bigdata.bop.mutation | |
com.bigdata.bop.paths | |
com.bigdata.bop.rdf.aggregate | |
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.graph |
The GAS (Gather Apply Scatter) API was developed for PowerGraph
(aka GraphLab 2.1).
|
com.bigdata.rdf.internal.constraints | |
com.bigdata.rdf.internal.encoder | |
com.bigdata.rdf.lexicon | |
com.bigdata.rdf.relation.rule | |
com.bigdata.rdf.rules | |
com.bigdata.rdf.sail |
This package contains the SAIL that allow bigdata to be used as a backend for
the Sesame 2.x platform.
|
com.bigdata.rdf.sail.sparql |
This package was imported from the
org.openrdf.query.parser.sparql
package of the openrdf distribution. |
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.service | |
com.bigdata.rdf.sparql.ast.optimizers | |
com.bigdata.rdf.sparql.ast.service |
This package provides support for SPARQL 1.1 Federated Query, including the
special case of "service" end points which live within the same JVM and use
direct method calls rather than SPARQL Query and remote (HTTP) end points
for which we will generate an appropriate SPARQL query.
|
com.bigdata.rdf.sparql.ast.ssets | |
com.bigdata.rdf.spo |
This package defines a statement model using long term identifiers rather than
RDF Value objects.
|
com.bigdata.rdf.store |
This package provides several realizations of an RDF database using the bigdata
architecture, including one suitable for temporary data, one suitable for local
processing (single host), and one designed for scale-out on commodity hardware.
|
com.bigdata.relation |
This package includes an abstraction layer for relations.
|
com.bigdata.relation.accesspath |
This package includes an abstraction layer for efficient access paths, including
chunked iterators, blocking buffers, and an abstraction corresponding to the natural
order of an index.
|
com.bigdata.relation.rule |
This package includes an abstraction layer for rules.
|
com.bigdata.relation.rule.eval |
This package supports rule evaluation.
|
com.bigdata.relation.rule.eval.pipeline |
This package implements a pipeline join.
|
com.bigdata.search |
This package provides full text indexing and search.
|
com.bigdata.service.fts | |
com.bigdata.service.geospatial | |
com.bigdata.service.geospatial.impl |
Modifier and Type | Class and Description |
---|---|
class |
ContextBindingSet
Wraps an
IBindingSet to provide access to the BOpContext . |
Modifier and Type | Field and Description |
---|---|
static IBindingSet[] |
BOpUtility.EMPTY_CHUNK
An empty
IBindingSet []. |
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 . |
IBindingSet |
ContextBindingSet.clone() |
IBindingSet |
IBindingSet.clone()
Return a shallow copy of the binding set.
|
IBindingSet |
ContextBindingSet.copy(IVariable[] variablesToKeep) |
IBindingSet |
IBindingSet.copy(IVariable[] variablesToKeep)
Return a shallow copy of the binding set, eliminating unnecessary
variables.
|
IBindingSet |
ContextBindingSet.copyMinusErrors(IVariable[] variablesToKeep) |
IBindingSet |
IBindingSet.copyMinusErrors(IVariable[] variablesToKeep)
Return a shallow copy of the binding set, eliminating unnecessary
variables and error values (equal to Constant.errorValueConstant()).
|
static IBindingSet[] |
BOpUtility.toArray(Iterator<IBindingSet[]> itr,
BOpStats stats)
Combine chunks drawn from an iterator into a single chunk.
|
Modifier and Type | Method and Description |
---|---|
static BOpContext<IBindingSet> |
TestMockUtility.mockContext(AbstractTripleStore kb)
Creates a mocked context associated with the given abstract triple store,
with index manager properly initialized.
|
Modifier and Type | Method and Description |
---|---|
boolean |
IConstraint.accept(IBindingSet bindingSet)
Return
true if the binding set satisfies the constraint. |
IPredicate<E> |
IPredicate.asBound(IBindingSet bindingSet)
Return a new instance in which all occurrences of the variable appearing
in the binding set have been replaced by their bound values.
|
Object |
IPredicate.asBound(int index,
IBindingSet bindingSet)
Extract the as bound value from the predicate.
|
static ICloseableIterator<IBindingSet[]> |
BOpUtility.asIterator(IBindingSet[] bindingSets)
Wrap the solutions with an
ICloseableIterator . |
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 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 void |
BOpContext.copyValues(IElement e,
IPredicate<?> pred,
IBindingSet bindingSet)
Copy the values for variables in the predicate from the element, applying
them to the caller's
IBindingSet . |
E |
Var.get(IBindingSet bindingSet) |
E |
Constant.get(IBindingSet bindingSet) |
E |
Bind.get(IBindingSet bindingSet) |
E |
IValueExpression.get(IBindingSet bindingSet)
Return the as bound value of the variable, constant, or
expression.
|
static boolean |
BOpUtility.isConsistent(IConstraint[] constraints,
IBindingSet bindingSet)
Check constraints.
|
String |
IPredicate.toString(IBindingSet bindingSet)
Representation of the predicate with variable bindings.
|
Modifier and Type | Method and Description |
---|---|
abstract FutureTask<Void> |
PipelineOp.eval(BOpContext<IBindingSet> context)
Return a
FutureTask which computes the operator against the
evaluation context. |
Constructor and Description |
---|
ContextBindingSet(BOpContextBase context,
IBindingSet delegate) |
Modifier and Type | Method and Description |
---|---|
E |
AggregateBase.get(IBindingSet bset)
Return the current value of the aggregate (this has a side-effect on the
internal state of the
IAggregate operator). |
E |
IAggregate.get(IBindingSet bset)
Return the current value of the aggregate (this has a side-effect on the
internal state of the
IAggregate operator). |
Modifier and Type | Method and Description |
---|---|
protected Predicate<E> |
Predicate._asBound(IBindingSet bindingSet)
Override any unbound variables for which we were giving bindings.
|
Predicate<E> |
Predicate.asBound(IBindingSet bindingSet)
Fast path for as-bound.
|
Object |
Predicate.asBound(int index,
IBindingSet bindingSet) |
E |
R.newElement(List<BOp> a,
IBindingSet bindingSet) |
String |
Predicate.toString(IBindingSet bindingSet) |
Modifier and Type | Method and Description |
---|---|
FutureTask<Void> |
TestPredicateAccessPath.MockPipelineOp.eval(BOpContext<IBindingSet> context) |
Modifier and Type | Class and Description |
---|---|
class |
EmptyBindingSet
An immutable empty binding set.
|
class |
HashBindingSet
IBindingSet backed by a LinkedHashMap . |
class |
ListBindingSet
An
IBindingSet based on a LinkedList . |
Modifier and Type | Method and Description |
---|---|
IBindingSet |
ListBindingSet.copy(IVariable[] variablesToKeep) |
IBindingSet |
HashBindingSet.copyMinusErrors(IVariable[] variablesToKeep) |
IBindingSet |
ListBindingSet.copyMinusErrors(IVariable[] variablesToKeep) |
protected abstract IBindingSet |
TestIBindingSet.newBindingSet(int size) |
protected IBindingSet |
TestHashBindingSet.newBindingSet(int size) |
protected IBindingSet |
TestListBindingSet.newBindingSet(int sizeIsIgnored) |
protected abstract IBindingSet |
TestIBindingSet.newBindingSet(IVariable<?>[] vars,
IConstant<?>[] vals) |
protected IBindingSet |
TestHashBindingSet.newBindingSet(IVariable<?>[] vars,
IConstant<?>[] vals) |
protected IBindingSet |
TestListBindingSet.newBindingSet(IVariable<?>[] vars,
IConstant<?>[] vals) |
Modifier and Type | Method and Description |
---|---|
protected void |
TestIBindingSet.assertEqual(IBindingSet actual,
IVariable<?>[] vars,
IConstant<?>[] vals)
Compare actual and expected, where the latter is expressed using
(vars,vals).
|
protected void |
TestIBindingSet.assertEquals(IBindingSet expected,
IBindingSet actual) |
Modifier and Type | Method and Description |
---|---|
IBindingSet[] |
CopyOp.bindingSets() |
Modifier and Type | Method and Description |
---|---|
FutureTask<Void> |
CopyOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
ConditionalRoutingOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
EndOp.eval(BOpContext<IBindingSet> context) |
Modifier and Type | Method and Description |
---|---|
boolean |
Constraint.accept(IBindingSet bs) |
Boolean |
NE.get(IBindingSet s) |
Boolean |
EQConstant.get(IBindingSet bset) |
Boolean |
BooleanValueExpression.get(IBindingSet bs) |
Boolean |
AND.get(IBindingSet s) |
Boolean |
INBinarySearch.get(IBindingSet bindingSet) |
Boolean |
INHashMap.get(IBindingSet bindingSet) |
Boolean |
EQ.get(IBindingSet s) |
Boolean |
NEConstant.get(IBindingSet s) |
Boolean |
OR.get(IBindingSet s) |
Modifier and Type | Method and Description |
---|---|
protected ThickAsynchronousIterator<IBindingSet[]> |
AbstractSubqueryTestCase.newBindingSetIterator(IBindingSet bindingSet)
Return an
IAsynchronousIterator that will read a single,
empty IBindingSet . |
protected ThickAsynchronousIterator<IBindingSet[]> |
AbstractSubqueryTestCase.newBindingSetIterator(IBindingSet[] bindingSets)
Return an
IAsynchronousIterator that will read a single, chunk
containing all of the specified IBindingSet s. |
protected ThickAsynchronousIterator<IBindingSet[]> |
AbstractSubqueryTestCase.newBindingSetIterator(IBindingSet[][] bindingSetChunks)
Return an
IAsynchronousIterator that will read a single, chunk
containing all of the specified IBindingSet s. |
Modifier and Type | Method and Description |
---|---|
FutureTask<Void> |
HTreeNamedSubqueryOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
JVMNamedSubqueryOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
SubqueryOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
ServiceCallJoin.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
AbstractSubqueryOp.eval(BOpContext<IBindingSet> context) |
Modifier and Type | Method and Description |
---|---|
IChunkAccessor<IBindingSet> |
LocalNativeChunkMessage.getChunkAccessor() |
IChunkAccessor<IBindingSet> |
LocalChunkMessage.getChunkAccessor() |
Modifier and Type | Method and Description |
---|---|
static void |
AbstractQueryEngineTestCase.assertSameSolutions(IBindingSet[] expected,
IAsynchronousIterator<IBindingSet[]> itr)
Deprecated.
by
#assertSameSolutions(Future, IBindingSet[], IAsynchronousIterator) |
static void |
AbstractQueryEngineTestCase.assertSameSolutions(IBindingSet[] expected,
ICloseableIterator<IBindingSet[]> itr,
Future<Void> ft)
Verify the expected solutions.
|
static void |
AbstractQueryEngineTestCase.assertSameSolutions(IBindingSet[] expected,
IRunningQuery runningQuery)
Verify the expected solutions.
|
static void |
AbstractQueryEngineTestCase.assertSameSolutionsAnyOrder(IBindingSet[] expected,
ICloseableIterator<IBindingSet[]> itr,
Future<?> future) |
static void |
AbstractQueryEngineTestCase.assertSameSolutionsAnyOrder(IBindingSet[] expected,
IRunningQuery runningQuery)
Verifies that the iterator visits the specified objects in some arbitrary
ordering and that the iterator is exhausted once all expected objects
have been visited.
|
static void |
AbstractQueryEngineTestCase.assertSameSolutionsAnyOrder(String msg,
IBindingSet[] expected,
ICloseableIterator<IBindingSet[]> itr,
Future<?> runningQuery) |
static void |
AbstractQueryEngineTestCase.assertSameSolutionsAnyOrder(String msg,
IBindingSet[] expected,
IRunningQuery runningQuery)
Verifies that the iterator visits the specified objects in some arbitrary
ordering and that the iterator is exhausted once all expected objects
have been visited.
|
AbstractRunningQuery |
QueryEngine.eval(BOp op,
IBindingSet bset)
Evaluate a query.
|
AbstractRunningQuery |
QueryEngine.eval(BOp op,
IBindingSet[] bsets)
Evaluate a query.
|
AbstractRunningQuery |
QueryEngine.eval(BOp op,
IBindingSet[] bsets,
Map<Object,Object> attribs)
Evaluate a query.
|
AbstractRunningQuery |
QueryEngine.eval(UUID queryId,
BOp op,
IBindingSet bset)
Note: Used only by the test suite.
|
AbstractRunningQuery |
QueryEngine.eval(UUID queryId,
BOp op,
Map<Object,Object> queryAttributes,
IBindingSet[] bset)
Note: Used only by the test suite.
|
AbstractRunningQuery |
QueryEngine.eval(UUID queryId,
BOp op,
Map<Object,Object> queryAttributes,
IBindingSet[][] bset)
Note: Used only by the test suite.
|
int |
IChunkHandler.handleChunk(IRunningQuery query,
int bopId,
int sinkId,
IBindingSet[] chunk)
Take an
IBindingSet [] chunk generated by some pass over an
operator and make it available to the target operator. |
int |
StandaloneChunkHandler.handleChunk(IRunningQuery query,
int bopId,
int sinkId,
IBindingSet[] chunk) |
static void |
SolutionsLog.log(UUID queryId,
BOp bop,
int bopId,
int partitionId,
IBindingSet[] a) |
protected ThickAsynchronousIterator<IBindingSet[]> |
TestRunState.newBindingSetIterator(IBindingSet bindingSet)
Return an
IAsynchronousIterator that will read a single,
empty IBindingSet . |
protected ThickAsynchronousIterator<IBindingSet[]> |
TestQueryEngine_DistinctOp.newBindingSetIterator(IBindingSet[][] bindingSetChunks)
Return an
IAsynchronousIterator that will read a single, chunk
containing all of the specified IBindingSet s. |
protected ThickAsynchronousIterator<IBindingSet[]> |
TestQueryEngine_Slice.newBindingSetIterator(IBindingSet[][] bindingSetChunks)
Return an
IAsynchronousIterator that will read a single, chunk
containing all of the specified IBindingSet s. |
protected ThickAsynchronousIterator<IBindingSet[]> |
TestQueryEngine_GroupByOp.newBindingSetIterator(IBindingSet[][] bindingSetChunks)
Return an
IAsynchronousIterator that will read a single, chunk
containing all of the specified IBindingSet s. |
Modifier and Type | Method and Description |
---|---|
protected boolean |
ChunkedRunningQuery.acceptChunk(IChunkMessage<IBindingSet> msg)
Make a chunk of binding sets available for consumption by the query.
|
protected abstract boolean |
AbstractRunningQuery.acceptChunk(IChunkMessage<IBindingSet> msg)
Make a chunk of binding sets available for consumption by the query.
|
protected boolean |
QueryEngine.acceptChunk(IChunkMessage<IBindingSet> msg)
Add a chunk of intermediate results for consumption by some query.
|
void |
QueryEngine.bufferReady(IChunkMessage<IBindingSet> msg) |
void |
IQueryPeer.bufferReady(IChunkMessage<IBindingSet> msg)
Notify a service that a buffer having data for some
BOp in some
running query is available. |
FutureTask<Void> |
PipelineDelayOp.eval(BOpContext<IBindingSet> context) |
AbstractRunningQuery |
QueryEngine.eval(UUID queryId,
PipelineOp query,
Map<Object,Object> queryAttributes,
IChunkMessage<IBindingSet> msg)
Evaluate a query.
|
protected AbstractRunningQuery |
QueryEngine.newRunningQuery(UUID queryId,
boolean controller,
IQueryClient clientProxy,
UUID queryControllerId,
PipelineOp query,
IChunkMessage<IBindingSet> realSource)
Factory for
IRunningQuery s. |
protected void |
AbstractRunningQuery.startQuery(IChunkMessage<IBindingSet> msg)
Message provides notice that the query has started execution and will
consume some specific number of binding set chunks.
|
Constructor and Description |
---|
LocalChunkMessage(IQueryClient queryController,
UUID queryId,
int bopId,
int partitionId,
IBindingSet bset) |
LocalChunkMessage(IQueryClient queryController,
UUID queryId,
int bopId,
int partitionId,
IBindingSet[] bsets) |
LocalChunkMessage(IQueryClient queryController,
UUID queryId,
int bopId,
int partitionId,
IBindingSet[][] bindingSetChunks)
TODO There are a few unit tests which rely on the ability to push
multiple chunks through the query engine, otherwise this could be changed
to an IBindingSet[] by flattening the caller's IBindingSet[][] when
given.
|
LocalNativeChunkMessage(IQueryClient queryController,
UUID queryId,
int bopId,
int partitionId,
IQueryContext queryContext,
IBindingSet[] bsets) |
LocalNativeChunkMessage(IQueryClient queryController,
UUID queryId,
int bopId,
int partitionId,
IQueryContext queryContext,
IBindingSet[][] bindingSetChunks) |
Constructor and Description |
---|
AbstractRunningQuery(QueryEngine queryEngine,
UUID queryId,
boolean controller,
IQueryClient clientProxy,
PipelineOp query,
IChunkMessage<IBindingSet> realSource) |
ChunkedRunningQuery(QueryEngine queryEngine,
UUID queryId,
boolean controller,
IQueryClient clientProxy,
PipelineOp query,
IChunkMessage<IBindingSet> realSource) |
Modifier and Type | Method and Description |
---|---|
int |
FederationChunkHandler.handleChunk(IRunningQuery query,
int bopId,
int sinkId,
IBindingSet[] chunk)
Take an
IBindingSet [] chunk generated by some pass over an
operator and make it available to the target operator. |
protected ThickAsynchronousIterator<IBindingSet[]> |
TestRemoteAccessPath.newBindingSetIterator(IBindingSet bindingSet)
Return an
IAsynchronousIterator that will read a single,
empty IBindingSet . |
protected void |
FederationChunkHandler.sendChunkMessage(FederatedRunningQuery q,
UUID serviceUUID,
int sinkId,
int partitionId,
DirectBufferPoolAllocator.IAllocationContext allocationContext,
IBindingSet[] source)
Create and send an
IChunkMessage from some intermediate results. |
Modifier and Type | Method and Description |
---|---|
protected boolean |
FederatedRunningQuery.acceptChunk(IChunkMessage<IBindingSet> msg)
Overridden to make this visible to the
FederatedQueryEngine . |
void |
FederatedQueryEngine.bufferReady(IChunkMessage<IBindingSet> msg)
Notify a service that a buffer having data for some
BOp in some
running query is available. |
FutureTask<Void> |
TestRemoteAccessPath.MockPipelineOp.eval(BOpContext<IBindingSet> context) |
protected FederatedRunningQuery |
FederatedQueryEngine.newRunningQuery(UUID queryId,
boolean controller,
IQueryClient clientProxy,
UUID queryControllerId,
PipelineOp query,
IChunkMessage<IBindingSet> realSource)
Factory for
IRunningQuery s. |
Constructor and Description |
---|
ThickChunkMessage(IQueryClient queryController,
UUID queryId,
int bopId,
int partitionId,
IBindingSet[] source) |
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 |
---|---|
class |
MapBindingSetsOverShardsBuffer<E extends IBindingSet,F>
A stream of
IBindingSet are mapped across the shards which will have
the data for the IPredicate.asBound(IBindingSet) IPredicate . |
Modifier and Type | Method and Description |
---|---|
protected void |
MapBindingSetsOverShardsBuffer.handleChunk(E[] chunk)
Maps the chunk of
IBindingSet s across the index partition(s) for
the sink join dimension. |
Modifier and Type | Field and Description |
---|---|
IBindingSet |
JVMHashIndex.SolutionHit.solution
The input solution.
|
Modifier and Type | Field and Description |
---|---|
protected BOpContext<IBindingSet> |
HashIndexOpBase.ChunkTaskBase.context |
protected BOpContext<IBindingSet> |
FastRangeCountOp.ChunkTask.context |
Modifier and Type | Method and Description |
---|---|
IBindingSet |
IDistinctFilter.accept(IBindingSet bset)
If the bindings are distinct for the configured variables then return a
new
IBindingSet consisting of only the selected variables. |
IBindingSet |
JVMDistinctFilter.accept(IBindingSet bset) |
protected IBindingSet |
HTreeHashJoinUtility.decodeSolution(ITuple<?> t)
Decode a solution from an encoded
IV []. |
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<IBindingSet> |
IHashJoinUtility.indexScan()
Return an
BytesTrie.Iterator that visits all solutions in the index (index
scan). |
ICloseableIterator<IBindingSet> |
JVMHashJoinUtility.indexScan() |
ICloseableIterator<IBindingSet> |
HTreeHashJoinUtility.indexScan() |
Modifier and Type | Method and Description |
---|---|
IBindingSet |
IDistinctFilter.accept(IBindingSet bset)
If the bindings are distinct for the configured variables then return a
new
IBindingSet consisting of only the selected variables. |
IBindingSet |
JVMDistinctFilter.accept(IBindingSet bset) |
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) |
JVMHashIndex.Key |
JVMHashIndex.add(IBindingSet bset)
Add the solution to the index.
|
void |
JVMHashIndex.Bucket.add(IBindingSet solution) |
boolean |
JVMHashIndex.addDistinct(IBindingSet bset)
Add the solution to the index iff the solution is not already present in
the index.
|
boolean |
JVMHashIndex.Bucket.addDistinct(IBindingSet solution)
Add the solution to the bucket iff the solutions is not already
present in the bucket.
|
protected static void |
AbstractHashJoinUtilityTestCase.assertSameSolutionsAnyOrder(IBindingSet[] expected,
Iterator<IBindingSet> actual) |
boolean |
JVMHashIndex.Bucket.contains(IBindingSet bs) |
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) |
JVMHashIndex.Bucket |
JVMHashIndex.getBucket(IBindingSet left)
Return the hash
JVMHashIndex.Bucket into which the given solution is mapped. |
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.
|
protected ThickAsynchronousIterator<IBindingSet[]> |
TestDistinctTermScanOp.newBindingSetIterator(IBindingSet bindingSet)
Return an
IAsynchronousIterator that will read a single
IBindingSet . |
protected ThickAsynchronousIterator<IBindingSet[]> |
AbstractHashJoinOpTestCase.newBindingSetIterator(IBindingSet bindingSet)
Return an
IAsynchronousIterator that will read a single
IBindingSet . |
protected ThickAsynchronousIterator<IBindingSet[]> |
TestFastRangeCountOp.newBindingSetIterator(IBindingSet bindingSet)
Return an
IAsynchronousIterator that will read a single
IBindingSet . |
protected ThickAsynchronousIterator<IBindingSet[]> |
TestPipelineJoin.newBindingSetIterator(IBindingSet bindingSet)
Return an
IAsynchronousIterator that will read a single
IBindingSet . |
protected void |
JVMHashJoinUtility.outputSolution(IBuffer<IBindingSet> outputBuffer,
IBindingSet outSolution)
Output a solution.
|
protected HTreeHashJoinUtility.BS[] |
HTreeHashJoinUtility.vector(IBindingSet[] leftSolutions,
IVariable<?>[] joinVars,
IVariable<?>[] selectVars,
boolean ignoreUnboundVariables,
AtomicInteger vectorSize)
Vector a chunk of solutions.
|
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 |
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 |
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) |
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 static void |
AbstractHashJoinUtilityTestCase.assertSameSolutionsAnyOrder(IBindingSet[] expected,
Iterator<IBindingSet> actual) |
IHashJoinUtility |
IHashJoinUtilityFactory.create(BOpContext<IBindingSet> context,
INamedSolutionSetRef namedSetRef,
PipelineOp op,
JoinTypeEnum joinType)
Return an instance of the
IHashJoinUtility . |
protected HashIndexOpBase.ChunkTaskBase |
PipelinedHashIndexAndSolutionSetJoinOp.createChunkTask(BOpContext<IBindingSet> context) |
protected abstract HashIndexOpBase.ChunkTaskBase |
HashIndexOpBase.createChunkTask(BOpContext<IBindingSet> context) |
protected HashIndexOpBase.ChunkTaskBase |
HashIndexOp.createChunkTask(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.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.
|
FutureTask<Void> |
AbstractHashJoinUtilityTestCase.MockPipelineOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
DistinctTermScanOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
SolutionSetHashJoinOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
HashJoinOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
PipelineJoin.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
HashIndexOpBase.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
JVMMergeJoin.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
FastRangeCountOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
HTreeMergeJoin.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
NestedLoopJoinOp.eval(BOpContext<IBindingSet> context) |
long |
IHashJoinUtility.filterSolutions(ICloseableIterator<IBindingSet[]> itr,
BOpStats stats,
IBuffer<IBindingSet> sink)
Filter solutions, writing only the DISTINCT solutions onto the sink.
|
long |
IDistinctFilter.filterSolutions(ICloseableIterator<IBindingSet[]> itr,
BOpStats stats,
IBuffer<IBindingSet> sink)
Vectored DISTINCT.
|
long |
JVMHashJoinUtility.filterSolutions(ICloseableIterator<IBindingSet[]> itr,
BOpStats stats,
IBuffer<IBindingSet> sink) |
long |
JVMDistinctFilter.filterSolutions(ICloseableIterator<IBindingSet[]> itr,
BOpStats stats,
IBuffer<IBindingSet> sink) |
long |
HTreeHashJoinUtility.filterSolutions(ICloseableIterator<IBindingSet[]> itr,
BOpStats stats,
IBuffer<IBindingSet> sink) |
void |
IHashJoinUtility.hashJoin(ICloseableIterator<IBindingSet[]> leftItr,
BOpStats stats,
IBuffer<IBindingSet> outputBuffer)
Do a hash join between a stream of source solutions (left) and a hash
index (right).
|
void |
JVMHashJoinUtility.hashJoin(ICloseableIterator<IBindingSet[]> leftItr,
BOpStats stats,
IBuffer<IBindingSet> outputBuffer) |
void |
HTreeHashJoinUtility.hashJoin(ICloseableIterator<IBindingSet[]> leftItr,
BOpStats stats,
IBuffer<IBindingSet> outputBuffer) |
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.
|
protected IHashJoinUtility |
JVMHashJoinOp.newState(BOpContext<IBindingSet> context,
INamedSolutionSetRef namedSetRef,
JoinTypeEnum joinType) |
protected abstract IHashJoinUtility |
HashJoinOp.newState(BOpContext<IBindingSet> context,
INamedSolutionSetRef namedSetRef,
JoinTypeEnum joinType)
Return the instance of the
IHashJoinUtility to be used by this
operator. |
protected IHashJoinUtility |
HTreeHashJoinOp.newState(BOpContext<IBindingSet> context,
INamedSolutionSetRef namedSetRef,
JoinTypeEnum joinType) |
void |
IHashJoinUtility.outputJoinSet(IBuffer<IBindingSet> out)
Output the solutions which joined.
|
void |
JVMHashJoinUtility.outputJoinSet(IBuffer<IBindingSet> outputBuffer) |
void |
HTreeHashJoinUtility.outputJoinSet(IBuffer<IBindingSet> out) |
void |
IHashJoinUtility.outputOptionals(IBuffer<IBindingSet> outputBuffer)
Identify and output the optional solutions.
|
void |
JVMHashJoinUtility.outputOptionals(IBuffer<IBindingSet> outputBuffer) |
void |
HTreeHashJoinUtility.outputOptionals(IBuffer<IBindingSet> outputBuffer) |
protected void |
JVMHashJoinUtility.outputSolution(IBuffer<IBindingSet> outputBuffer,
IBindingSet outSolution)
Output a solution.
|
void |
IHashJoinUtility.outputSolutions(IBuffer<IBindingSet> out)
Output the solutions buffered in the hash index.
|
void |
JVMHashJoinUtility.outputSolutions(IBuffer<IBindingSet> out) |
void |
HTreeHashJoinUtility.outputSolutions(IBuffer<IBindingSet> out) |
Constructor and Description |
---|
JVMHashIndex.Bucket(int hashCode,
IBindingSet solution) |
Constructor and Description |
---|
FastRangeCountOp.ChunkTask(FastRangeCountOp<E> op,
BOpContext<IBindingSet> context) |
HashIndexOp.ChunkTask(HashIndexOp op,
BOpContext<IBindingSet> context) |
HashIndexOpBase.ChunkTaskBase(HashIndexOpBase op,
BOpContext<IBindingSet> context) |
HTreePipelinedHashJoinUtility(PipelineOp op,
JoinTypeEnum joinType,
BOpContext<IBindingSet> context,
int chunkCapacity) |
JVMPipelinedHashJoinUtility(PipelineOp op,
JoinTypeEnum joinType,
BOpContext<IBindingSet> context,
int chunkCapacity) |
Modifier and Type | Method and Description |
---|---|
IBindingSet[] |
SampleBase.getSample()
The sampled solution set.
|
Modifier and Type | Method and Description |
---|---|
FutureTask<Void> |
JoinGraph.eval(BOpContext<IBindingSet> context) |
Constructor and Description |
---|
EdgeSample(SampleBase sourceSample,
int inputCount,
long tuplesRead,
long sumRangeCount,
long outputCount,
long adjustedCard,
double f,
long estCard,
long estRead,
int limit,
EstimateEnum estimateEnum,
IBindingSet[] sample)
Create an object which encapsulates a sample of an edge.
|
SampleBase(long estimatedCardinality,
int limit,
EstimateEnum estimateEnum,
IBindingSet[] sample) |
VertexSample(long estCard,
int limit,
EstimateEnum estimateEnum,
IBindingSet[] sample)
Note: For a
Vertex , the estimatedCardinality is the fast range
count. |
Modifier and Type | Method and Description |
---|---|
FutureTask<Void> |
InsertOp.eval(BOpContext<IBindingSet> context) |
Modifier and Type | Method and Description |
---|---|
FutureTask<Void> |
ArbitraryLengthPathOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
ZeroLengthPathOp.eval(BOpContext<IBindingSet> context)
Deprecated.
|
Constructor and Description |
---|
ArbitraryLengthPathTask(ArbitraryLengthPathOp controllerOp,
BOpContext<IBindingSet> context) |
Modifier and Type | Method and Description |
---|---|
IV |
SAMPLE.get(IBindingSet bindingSet) |
IV |
MAX.get(IBindingSet bindingSet) |
IV |
AVERAGE.get(IBindingSet bindingSet) |
IV |
COUNT.get(IBindingSet bindingSet)
Return the current value of the aggregate (this has a side-effect on the
internal state of the
IAggregate operator). |
IV |
SUM.get(IBindingSet bindingSet) |
IV |
GROUP_CONCAT.get(IBindingSet bindingSet) |
IV |
MIN.get(IBindingSet bindingSet) |
Modifier and Type | Method and Description |
---|---|
IBindingSet[] |
ChunkedMaterializationIterator.next() |
Modifier and Type | Method and Description |
---|---|
FutureTask<Void> |
InlineMaterializeOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
MockTermResolverOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
DataSetJoin.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
VariableUnificationOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
ChunkedMaterializationOp.eval(BOpContext<IBindingSet> context) |
Modifier and Type | Method and Description |
---|---|
protected static IV |
AbstractAddRemoveStatementsOp.getIV(IVariable<?> var,
IBindingSet bset,
boolean required)
Return the bound value for the variable.
|
protected static ISPO |
AbstractAddRemoveStatementsOp.getSPO(IBindingSet bset,
boolean bindsC,
StatementEnum type)
Return an
ISPO constructed from the source solution. |
Modifier and Type | Method and Description |
---|---|
protected static Set<ISPO> |
AbstractAddRemoveStatementsOp.acceptSolutions(BOpContext<IBindingSet> context,
boolean bindsC)
|
FutureTask<Void> |
CommitOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
ParseOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
ChunkedResolutionOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
RemoveStatementsOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
InsertStatementsOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
InsertDataOp.eval(BOpContext<IBindingSet> context) |
Modifier and Type | Field and Description |
---|---|
protected List<IBindingSet> |
AbstractDistinctSolutionsTestCase.Setup.data |
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<IBindingSet> |
ISolutionSet.scan()
Visit all entries in the index in the natural order of the index.
|
ICloseableIterator<IBindingSet> |
SolutionSetStream.scan() |
Modifier and Type | Method and Description |
---|---|
int |
BindingSetComparator.compare(IBindingSet bs1,
IBindingSet bs2) |
Modifier and Type | Method and Description |
---|---|
FutureTask<Void> |
MockQuery.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
MemoryGroupByOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
ProjectionOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
SliceOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
MemorySortOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
HTreeDistinctBindingSetsOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
JVMDistinctBindingSetsOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
PipelinedAggregationOp.eval(BOpContext<IBindingSet> context) |
FutureTask<Void> |
DropOp.eval(BOpContext<IBindingSet> context) |
Modifier and Type | Method and Description |
---|---|
List<org.openrdf.model.Value> |
BinderBase.bind(org.openrdf.model.ValueFactory vf,
IGASState<VS,ES,ST> state,
org.openrdf.model.Value u,
IVariable<?>[] outVars,
IBindingSet bs)
|
List<org.openrdf.model.Value> |
IBinder.bind(org.openrdf.model.ValueFactory vf,
IGASState<VS,ES,ST> state,
org.openrdf.model.Value u,
IVariable<?>[] outVars,
IBindingSet bs)
New multi-binding strategy allows binders to bind multiple values to
a given output variable (multiplying the number of solutions by the
number of bindings).
|
Modifier and Type | Method and Description |
---|---|
boolean |
TrueBOp.accept(IBindingSet bs) |
boolean |
IsBoundBOp.accept(IBindingSet bs)
Returns true if var is bound to a value.
|
boolean |
IsLiteralBOp.accept(IBindingSet bs) |
boolean |
NeedsMaterializationBOp.accept(IBindingSet bs) |
boolean |
OrBOp.accept(IBindingSet bs)
Follows semantics from SPARQL spec - "Testing Values".
|
boolean |
SparqlTypeErrorBOp.accept(IBindingSet bs) |
protected abstract boolean |
XSDBooleanIVValueExpression.accept(IBindingSet bs)
Implement this method.
|
protected boolean |
LangMatchesBOp.accept(IBindingSet bs) |
boolean |
IsURIBOp.accept(IBindingSet bs) |
boolean |
InBinaryBOp.accept(IBindingSet bindingSet) |
boolean |
AndBOp.accept(IBindingSet bs)
Follows semantics from SPARQL spec - "Testing Values".
|
boolean |
ProjectedConstraint.accept(IBindingSet bindingSet) |
boolean |
IsBNodeBOp.accept(IBindingSet bs) |
boolean |
EBVBOp.accept(IBindingSet bs)
11.2.2 Effective Boolean Value (EBV)
Effective boolean value is used to calculate the arguments to the logical
functions logical-and, logical-or, and fn:not, as well as evaluate the
result of a FILTER expression.
|
boolean |
ComputedIN.accept(IBindingSet bindingSet) |
boolean |
TryBeforeMaterializationConstraint.accept(IBindingSet bs)
This is useful when a solution can be filtered out before it goes
through the materialization pipeline.
|
boolean |
StrendsBOp.accept(IBindingSet bs) |
boolean |
InHashBOp.accept(IBindingSet bindingSet) |
boolean |
RegexBOp.accept(IBindingSet bs) |
boolean |
IsMaterializedBOp.accept(IBindingSet bs) |
boolean |
StrcontainsBOp.accept(IBindingSet bs) |
boolean |
SameTermBOp.accept(IBindingSet bs) |
boolean |
NotBOp.accept(IBindingSet bs) |
boolean |
SPARQLConstraint.accept(IBindingSet bs) |
boolean |
CompareBOp.accept(IBindingSet s) |
boolean |
IsInlineBOp.accept(IBindingSet bs) |
boolean |
FalseBOp.accept(IBindingSet bs) |
boolean |
IsNumericBOp.accept(IBindingSet bs) |
boolean |
StrstartsBOp.accept(IBindingSet bs) |
RangeBOp |
RangeBOp.asBound(IBindingSet bs) |
protected IV |
IVValueExpression.asIV(BigdataValue value,
IBindingSet bs)
Return an
IV for the Value . |
protected IV |
IVValueExpression.asIV(org.openrdf.model.Value value,
IBindingSet bs)
Return an
IV for the Value . |
IV |
NumericBOp.get(IBindingSet bs) |
IV |
XsdUnsignedLongBOp.get(IBindingSet bs) |
IV |
IriBOp.get(IBindingSet bs) |
IV |
MathBOp.get(IBindingSet bs) |
IV |
LcaseBOp.get(IBindingSet bs) |
IV |
StrlenBOp.get(IBindingSet bs) |
IV |
CoalesceBOp.get(IBindingSet bs) |
XSDBooleanIV |
XSDBooleanIVValueExpression.get(IBindingSet bs)
Delegates to
XSDBooleanIVValueExpression.accept(IBindingSet) . |
IV |
NowBOp.get(IBindingSet bs) |
IV |
LangBOp.get(IBindingSet bs) |
IV |
RandBOp.get(IBindingSet bindingSet) |
IV |
UUIDBOp.get(IBindingSet bs) |
IV |
StrBeforeBOp.get(IBindingSet bs) |
IV |
XsdStrBOp.get(IBindingSet bs) |
IV |
ConcatBOp.get(IBindingSet bs) |
IV |
DigestBOp.get(IBindingSet bs) |
IV |
BNodeBOp.get(IBindingSet bs) |
E |
ConditionalBind.get(IBindingSet bindingSet) |
IV |
StrAfterBOp.get(IBindingSet bs) |
IV |
StrBOp.get(IBindingSet bs) |
IV |
FuncBOp.get(IBindingSet bs) |
IV |
SubstrBOp.get(IBindingSet bs) |
IV |
ReplaceBOp.get(IBindingSet bs) |
IV |
StrdtBOp.get(IBindingSet bs) |
IV |
IfBOp.get(IBindingSet bs) |
IV |
DateBOp.get(IBindingSet bs) |
IV |
DatatypeBOp.get(IBindingSet bs) |
IV |
EncodeForURIBOp.get(IBindingSet bs) |
Boolean |
InferenceBVE.get(IBindingSet bs)
For inference rules, we want to trap unbound variable exceptions and
allow the solution through.
|
IV |
XsdLongBOp.get(IBindingSet bs) |
IV |
StrlangBOp.get(IBindingSet bs) |
IV |
UcaseBOp.get(IBindingSet bs) |
protected IV |
IVValueExpression.getAndCheckBound(int i,
IBindingSet bs)
Get the function argument (a value expression) and evaluate it against
the source solution.
|
protected IV |
IVValueExpression.getAndCheckLiteral(int i,
IBindingSet bs)
Get the function argument (a value expression) and evaluate it against
the source solution.
|
protected org.openrdf.model.Literal |
IVValueExpression.getAndCheckLiteralValue(int i,
IBindingSet bs)
|
protected ILexiconConfiguration<BigdataValue> |
IVValueExpression.getLexiconConfiguration(IBindingSet bset)
Return the
ILexiconConfiguration . |
Modifier and Type | Method and Description |
---|---|
IBindingSet |
IVBindingSetEncoder.decodeSolution(byte[] val,
int off,
int len,
boolean resolveCachedValues) |
IBindingSet |
IVSolutionSetDecoder.decodeSolution(byte[] data,
int off,
int len,
boolean resolveCachedValues)
Decode an
IBindingSet . |
IBindingSet |
IBindingSetDecoder.decodeSolution(byte[] val,
int off,
int len,
boolean resolveCachedValues)
Decode an
IBindingSet . |
IBindingSet |
IVSolutionSetDecoder.decodeSolution(DataInputBuffer in,
boolean resolveCachedValues)
Stream oriented decode.
|
protected IBindingSet |
AbstractBindingSetEncoderTestCase.doEncodeDecodeTest(IBindingSet expected) |
protected IBindingSet |
AbstractBindingSetEncoderTestCase.doEncodeDecodeTest(IBindingSet expected,
boolean testCache) |
IBindingSet[] |
SolutionSetStreamDecoder.next() |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractBindingSetEncoderTestCase.assertEquals(IBindingSet expected,
IBindingSet actual,
boolean testCache) |
protected IBindingSet |
AbstractBindingSetEncoderTestCase.doEncodeDecodeTest(IBindingSet expected) |
protected IBindingSet |
AbstractBindingSetEncoderTestCase.doEncodeDecodeTest(IBindingSet expected,
boolean testCache) |
void |
IVSolutionSetEncoder.encodeSolution(DataOutputBuffer out,
IBindingSet bset)
Encode the solution on the stream.
|
byte[] |
IVBindingSetEncoder.encodeSolution(IBindingSet bset) |
byte[] |
IBindingSetEncoder.encodeSolution(IBindingSet bset)
|
byte[] |
IVSolutionSetEncoder.encodeSolution(IBindingSet bset) |
byte[] |
IVBindingSetEncoder.encodeSolution(IBindingSet bset,
boolean updateCache) |
byte[] |
IBindingSetEncoder.encodeSolution(IBindingSet bset,
boolean updateCache)
Encode the solution as an
IV []. |
byte[] |
IVSolutionSetEncoder.encodeSolution(IBindingSet bset,
boolean updateCacheIsIgnored)
Encode the solution as an
IV []. |
void |
IVBindingSetEncoderWithIVCache.resolveCachedValues(IBindingSet bset)
Deprecated.
Resolve any
IV s in the solution for which there are cached
BigdataValue s to those values. |
void |
IVBindingSetEncoder.resolveCachedValues(IBindingSet bset)
Resolve any
IV s in the solution for which there are cached
BigdataValue s to those values. |
void |
IVSolutionSetDecoder.resolveCachedValues(IBindingSet bset) |
void |
IBindingSetDecoder.resolveCachedValues(IBindingSet bset)
Resolve any
IV s in the solution for which there are cached
BigdataValue s to those values. |
Modifier and Type | Method and Description |
---|---|
protected void |
TestIVSolutionSetEncoder.doEncodeDecodeTest(List<IBindingSet> expectedSolutions) |
Modifier and Type | Method and Description |
---|---|
LexPredicate |
LexPredicate.asBound(IBindingSet bindingSet)
Strengthened return type.
|
BigdataValue |
LexiconRelation.newElement(List<BOp> a,
IBindingSet bindingSet)
Note : this method is part of the mutation api.
|
Modifier and Type | Method and Description |
---|---|
byte[] |
BindingSetSortKeyBuilder.getSortKey(IBindingSet bindingSet) |
Modifier and Type | Method and Description |
---|---|
IBindingSet[] |
SPOBindingSetSerializer.deserialize(ObjectInput in) |
Modifier and Type | Method and Description |
---|---|
ISortKeyBuilder<IBindingSet> |
RDFJoinNexus.newBindingSetSortKeyBuilder(IRule rule)
FIXME unit tests for DISTINCT with a head and ELEMENT, with bindings and
a head, with bindings but no head, and with a head but no bindings
(error).
|
Modifier and Type | Method and Description |
---|---|
protected void |
TestSlice.assertSameSolutions(IChunkedOrderedIterator<ISolution> itr,
IBindingSet[] expected)
Verifies the the iterator visits
ISolution s have the expected
IBindingSet s in the expected order. |
protected void |
AbstractRuleTestCase.assertSameSolutionsAnyOrder(IChunkedOrderedIterator<ISolution> itr,
IBindingSet[] expected)
Verifies the the iterator visits
ISolution s have the expected
IBindingSet s when those bindings may occur in any order. |
Boolean |
RejectAnythingSameAsItself.get(IBindingSet bindingSet) |
void |
SPOBindingSetSerializer.serialize(ObjectOutput out,
IBindingSet[] obj) |
Constructor and Description |
---|
Bigdata2Sesame2BindingSetIterator(ICloseableIterator<IBindingSet> src) |
Bigdata2Sesame2BindingSetIterator(ICloseableIterator<IBindingSet> src,
org.openrdf.query.BindingSet constants) |
Modifier and Type | Method and Description |
---|---|
IBindingSet |
BigdataExprBuilder.visit(ASTBindingSet node,
Object data)
Note:
BigdataValue s have already been resolved to IV s. |
Modifier and Type | Method and Description |
---|---|
IBindingSet[] |
QueryNodeWithBindingSet.getBindingSets() |
IBindingSet[] |
ASTContainer.getOptimizedASTBindingSets()
Return the incoming binding sets associated with the optimized AST.
|
IBindingSet[] |
SolutionSetStatserator.next() |
Modifier and Type | Method and Description |
---|---|
List<IBindingSet> |
BindingsClause.getBindingSets()
The binding sets -or-
null . |
Modifier and Type | Method and Description |
---|---|
protected void |
SolutionSetStatserator.filter(IBindingSet[] a)
Compute incremental statistics from an observed chunk of solutions.
|
IV |
FunctionRegistry.UnknownFunctionBOp.get(IBindingSet bindingSet) |
static ISolutionSetStats |
SolutionSetStatserator.get(IBindingSet[] bindingSets)
Convenience method.
|
protected ISolutionSetStats |
TestSolutionSetStats.newFixture(IBindingSet[] bindingSets) |
protected abstract ISolutionSetStats |
AbstractSolutionSetStatsTestCase.newFixture(IBindingSet[] bindingSets)
Implement this method to test a specific
ISolutionSetStats class. |
protected ISolutionSetStats |
TestSolutionSetStatserator.newFixture(IBindingSet[] bindingSets) |
void |
ASTContainer.setOptimizedASTBindingSets(IBindingSet[] bindingSets)
Set the incoming binding sets associated with the optimized AST.
|
String |
QueryRoot.toString(int indent,
IBindingSet[] bs) |
Modifier and Type | Method and Description |
---|---|
Set<IVariable<?>> |
StaticAnalysis.getVarsInBindingSet(List<IBindingSet> bss)
Extract the set of variables contained in a binding set.
|
void |
BindingsClause.setBindingSets(List<IBindingSet> bindingSets) |
Constructor and Description |
---|
QueryNodeWithBindingSet(IQueryNode queryNode,
IBindingSet[] bindingSets) |
SolutionSetStats(IBindingSet[] bindingSets)
Deprecated.
|
Constructor and Description |
---|
BindingsClause(LinkedHashSet<IVariable<?>> declaredVars,
List<IBindingSet> bindingSets) |
Modifier and Type | Method and Description |
---|---|
IBindingSet[] |
AST2BOpUpdateContext.getBindings() |
IBindingSet |
GeoSpatialServiceFactory.GeoSpatialInputBindingsIterator.next() |
Modifier and Type | Method and Description |
---|---|
protected void |
ASTSearchInSearchOptimizer.optimizeJoinGroup(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode group)
Optimize the join group.
|
void |
AST2BOpUpdateContext.setBindings(IBindingSet[] bindingSets) |
GeoSpatialQuery |
GeoSpatialServiceFactory.GeoSpatialServiceCallConfiguration.toGeoSpatialQuery(IBindingSet bs)
Converts the configuration into a query over the given binding set
|
Constructor and Description |
---|
GeoSpatialServiceFactory.GeoSpatialInputBindingsIterator(IBindingSet[] bindingSet,
GeoSpatialServiceFactory.GeoSpatialServiceCallConfiguration gssConfig,
AbstractTripleStore kb,
com.bigdata.rdf.sparql.ast.eval.GeoSpatialServiceFactory.GeoSpatialServiceCall serviceCall) |
Constructor and Description |
---|
BigdataNativeMockServiceFactory(List<IBindingSet> serviceSolutions) |
Modifier and Type | Method and Description |
---|---|
IBindingSet[] |
ASTStaticBindingsOptimizer.StaticBindingInfo.joinProduced() |
Modifier and Type | Method and Description |
---|---|
List<List<IBindingSet>> |
ASTStaticBindingsOptimizer.StaticBindingInfo.getProduced() |
Modifier and Type | Method and Description |
---|---|
void |
ASTStaticBindingsOptimizer.StaticBindingInfo.addProduced(IBindingSet bs) |
protected void |
ASTRangeCountOptimizer.attachRangeCounts(AST2BOpContext ctx,
List<StatementPatternNode> spNodes,
IBindingSet exogenousBindings,
int nrExogeneousBindings)
Use the
SPORelation from the database to grab the appropriate
range counts for the StatementPatternNode s. |
protected void |
ASTRangeCountOptimizer.estimateCardinality(StatementPatternNode sp,
AST2BOpContext ctx,
IBindingSet exogenousBindings,
int nrExogeneousBindings)
For testing purposes we can override this method.
|
protected static IV |
ASTRangeCountOptimizer.getIV(TermNode term,
IBindingSet exogenousBindings,
AtomicBoolean usesExogeneousBinding)
Helper method grabs the IV out of the TermNode, doing the appropriate
NULL and constant/var checks.
|
protected void |
ASTFilterNormalizationOptimizer.normalizeAndDecomposeFilters(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode group)
Bring all FILTERs into CNF and split them at top-level to contain
simpler FILTER expressions.
|
protected void |
ASTCardinalityOptimizer.optimizeJoinGroup(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode group)
Calculate the estimated cardinality of a join group.
|
protected void |
ASTRangeCountOptimizer.optimizeJoinGroup(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode group)
Optimize the join group.
|
protected void |
ASTALPServiceOptimizer.optimizeJoinGroup(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode group)
Optimize the join group.
|
protected void |
ASTJoinGroupOrderOptimizer.optimizeJoinGroup(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode joinGroup) |
protected void |
ASTPropertyPathOptimizer.optimizeJoinGroup(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode group)
Optimize the join group.
|
protected void |
ASTRangeOptimizer.optimizeJoinGroup(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode group)
Optimize the join group, attach range nodes.
|
protected abstract void |
AbstractJoinGroupOptimizer.optimizeJoinGroup(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode op)
Subclasses can do the work of optimizing a join group here.
|
protected void |
ASTJoinOrderByTypeOptimizer.optimizeJoinGroup(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode joinGroup)
Deprecated.
Get the group member nodes into the right order:
|
protected void |
ASTFilterNormalizationOptimizer.optimizeJoinGroup(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode group) |
protected void |
ASTFilterNormalizationOptimizer.removeDuplicatesAndTautologies(AST2BOpContext ctx,
StaticAnalysis sa,
IBindingSet[] bSets,
JoinGroupNode group)
Remove duplicate FILTERs and tautologies
|
Modifier and Type | Method and Description |
---|---|
void |
ASTStaticBindingsOptimizer.StaticBindingInfo.addProduced(List<IBindingSet> bsList) |
Constructor and Description |
---|
ASTStaticBindingsOptimizer.StaticBindingInfo(IBindingSet[] queryInput)
Constructor with given input binding set.
|
Modifier and Type | Method and Description |
---|---|
static IBindingSet[] |
ServiceCallUtility.resolve(AbstractTripleStore db,
org.openrdf.query.BindingSet[] serviceResults)
Batch resolve BigdataValues to IVs.
|
Modifier and Type | Method and Description |
---|---|
static org.openrdf.query.BindingSet |
ServiceCallUtility.bigdata2Openrdf(LexiconRelation lex,
Set<IVariable<?>> vars,
IBindingSet in)
Convert the
IBindingSet into an openrdf BindingSet . |
static org.openrdf.query.BindingSet[] |
ServiceCallUtility.convert(LexiconRelation lex,
Set<IVariable<?>> projectedVars,
IBindingSet[] in)
Convert
IBindingSet [] to openrdf BindingSet []. |
static BigdataURI |
ServiceCallUtility.getServiceURI(IVariableOrConstant<?> serviceRef,
IBindingSet bset)
Return the effective service URI.
|
Modifier and Type | Method and Description |
---|---|
protected static IBindingSet[] |
TestSolutionSetManager.flatten(Iterator<IBindingSet[]> itr)
Flatten out the iterator into a single chunk.
|
Modifier and Type | Method and Description |
---|---|
protected static void |
TestSolutionSetManager.assertSameSolutionsAnyOrder(IBindingSet[] expected,
ICloseableIterator<IBindingSet[]> itr) |
protected static void |
TestSolutionSetManager.assertSameSolutionsAnyOrder(String msg,
IBindingSet[] expected,
ICloseableIterator<IBindingSet[]> itr) |
Modifier and Type | Method and Description |
---|---|
protected IBindingSet |
TestSPOStarJoin.createBindingSet(IBinding... bindings) |
Modifier and Type | Method and Description |
---|---|
SPOPredicate |
SPOPredicate.asBound(IBindingSet bindingSet)
Strengthened return type.
|
SPOPredicate |
SPOStarJoin.asBound(IBindingSet bindingSet)
Return an as-bound version of this star join and its star contraints
using the supplied binding set.
|
IStarJoin.IStarConstraint<ISPO> |
SPOStarJoin.SPOStarConstraint.asBound(IBindingSet bindingSet)
Return an as-bound version of this SPO star constraint for the
supplied binding set.
|
void |
SPOStarJoin.SPOStarConstraint.bind(IBindingSet bs,
ISPO spo)
Use the supplied SPO to create variable bindings for supplied
binding set.
|
SPO |
SPORelation.newElement(List<BOp> a,
IBindingSet bindingSet) |
String |
SPOStarJoin.toString(IBindingSet bindingSet) |
String |
SPOStarJoin.SPOStarConstraint.toString(IBindingSet bindingSet) |
Modifier and Type | Method and Description |
---|---|
protected void |
TestSPOStarJoin.compare(IChunkedOrderedIterator<ISolution> result,
Collection<IBindingSet> answer) |
Modifier and Type | Method and Description |
---|---|
protected IBindingSet[] |
BigdataOpenRDFBindingSetsResolverator.resolveChunk(org.openrdf.query.BindingSet[] chunk)
Resolve a chunk of
BindingSet s into a chunk of
IBindingSet s in which RDF Value s have been resolved to
IV s. |
protected IBindingSet[] |
BigdataBindingSetResolverator.resolveChunk(IBindingSet[] chunk)
Resolve a chunk of
IBindingSet s into a chunk of
IBindingSet s in which term identifiers have been resolved to
BigdataValue s. |
protected IBindingSet[] |
BigdataSolutionResolverator.resolveChunk(ISolution[] chunk)
Resolve a chunk of
ISolution s into a chunk of
IBindingSet s in which term identifiers have been resolved to
BigdataValue s. |
static IBindingSet[] |
BigdataOpenRDFBindingSetsResolverator.resolveChunk(LexiconRelation r,
org.openrdf.query.BindingSet[] chunk)
Resolve a chunk of
BindingSet s into a chunk of
IBindingSet s in which RDF Value s have been resolved to
IV s. |
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<IBindingSet> |
AbstractTripleStore.match(org.openrdf.model.Literal[] lits,
org.openrdf.model.URI[] preds,
org.openrdf.model.URI cls)
Specialized
IRule execution using the full text index to identify
possible completions of the given literals for which there exists a
subject s such that: |
Modifier and Type | Method and Description |
---|---|
protected IBindingSet[] |
BigdataBindingSetResolverator.resolveChunk(IBindingSet[] chunk)
Resolve a chunk of
IBindingSet s into a chunk of
IBindingSet s in which term identifiers have been resolved to
BigdataValue s. |
Constructor and Description |
---|
BigdataBindingSetResolverator(AbstractTripleStore db,
IChunkedOrderedIterator<IBindingSet> src,
UUID queryId,
IVariable[] required,
int chunkOfChunksCapacity,
int chunkCapacity,
long chunkTimeout,
int termsChunkSize,
int blobsChunkSize) |
Modifier and Type | Method and Description |
---|---|
E |
RelationFusedView.newElement(List<BOp> a,
IBindingSet bindingSet)
Deprecated.
|
E |
IRelation.newElement(List<BOp> args,
IBindingSet bindingSet)
Create and return a new element.
|
Modifier and Type | Class and Description |
---|---|
class |
UnsyncLocalOutputBuffer<E extends IBindingSet>
Wraps the base class to update the caller's
BOpStats . |
Modifier and Type | Method and Description |
---|---|
protected void |
UnsyncLocalOutputBuffer.handleChunk(E[] chunk)
Adds the chunk to the
UnsyncLocalOutputBuffer.syncBuffer and updates the
BOpStats . |
Modifier and Type | Method and Description |
---|---|
IBindingSet |
IRule.getConstants()
Returns any variables that were bound to constants when an
IRule
was specialized . |
IBindingSet |
Rule.getConstants() |
Modifier and Type | Method and Description |
---|---|
IStarJoin.IStarConstraint<E> |
IStarJoin.IStarConstraint.asBound(IBindingSet bindingSet)
Return an as-bound version of this star constraint.
|
void |
IStarJoin.IStarConstraint.bind(IBindingSet bs,
E e)
Adds variable bindings to the supplied binding set based on the
as-bound values of the supplied element.
|
int |
IRule.getVariableCount(int index,
IBindingSet bindingSet)
The #of arguments in the selected predicate that are variables (vs
constants) with the given the bindings.
|
int |
Rule.getVariableCount(int index,
IBindingSet bindingSet) |
boolean |
IRule.isConsistent(IBindingSet bindingSet)
|
boolean |
Rule.isConsistent(IBindingSet bindingSet) |
boolean |
IRule.isFullyBound(IBindingSet bindingSet)
If the rule is fully bound for the given bindings.
|
boolean |
Rule.isFullyBound(IBindingSet bindingSet) |
boolean |
IRule.isFullyBound(int index,
IBindingSet bindingSet)
Return true iff the selected predicate is fully bound.
|
boolean |
Rule.isFullyBound(int index,
IBindingSet bindingSet) |
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) |
String |
IRule.toString(IBindingSet bindingSet)
Externalizes the rule displaying variable names, their bindings, and
constants.
|
String |
Rule.toString(IBindingSet bindingSet) |
Constructor and Description |
---|
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 |
---|---|
IBindingSet |
ISolution.getBindingSet()
Return the
IBindingSet for this solution (optional operation). |
IBindingSet |
Solution.getBindingSet() |
IBindingSet |
AbstractJoinNexus.newBindingSet(IRule rule) |
IBindingSet |
IJoinNexus.newBindingSet(IRule rule)
Factory for
IBindingSet implementations. |
Modifier and Type | Method and Description |
---|---|
ISortKeyBuilder<IBindingSet> |
IJoinNexus.newBindingSetSortKeyBuilder(IRule rule)
Return an
ISortKeyBuilder for an IBindingSet . |
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.
|
boolean |
AbstractJoinNexus.bind(IRule rule,
int index,
Object e,
IBindingSet bindings) |
boolean |
IJoinNexus.bind(IRule rule,
int index,
Object e,
IBindingSet bindings)
Deprecated.
by
#bind(IPredicate, Object, IBindingSet) |
ISolution |
AbstractJoinNexus.newSolution(IRule rule,
IBindingSet bindingSet) |
ISolution |
IJoinNexus.newSolution(IRule rule,
IBindingSet bindingSet)
Create a new
ISolution . |
String |
RuleState.toString(IBindingSet bindingSet)
Shows the bindings (if given), the computed evaluation order, the
computed
IKeyOrder , and the required variables for each
IPredicate in the rule. |
String |
IRuleState.toString(IBindingSet bindingSet)
Shows the bindings (if given), the computed evaluation order, and the
computed
IKeyOrder for each IPredicate in the rule. |
Constructor and Description |
---|
Solution(IJoinNexus joinNexus,
IRule<E> rule,
IBindingSet bindingSet)
Constructs the element iff requested, saves the rule reference iff
requested, and clones and saves the bindingSet iff requested.
|
Modifier and Type | Class and Description |
---|---|
class |
UnsyncLocalOutputBuffer<E extends IBindingSet>
Keeps track of the chunks of binding sets that are generated on the caller's
JoinStats . |
Modifier and Type | Method and Description |
---|---|
protected IBindingSet[] |
DistributedJoinTask.combineChunks(List<IBindingSet[]> chunks,
int bindingSetCount)
Combine the chunk(s) into a single chunk.
|
protected IBindingSet[] |
LocalJoinTask.nextChunk()
Return the next chunk of
IBindingSet s the source
JoinTask . |
protected abstract IBindingSet[] |
JoinTask.nextChunk()
Return a chunk of
IBindingSet s from the
IAsynchronousIterator s. |
protected IBindingSet[] |
DistributedJoinTask.nextChunk()
Returns a chunk of
IBindingSet s by combining chunks from the
various source JoinTask s. |
Modifier and Type | Method and Description |
---|---|
protected Map<IPredicate<?>,Collection<IBindingSet>> |
JoinTask.BindingSetConsumerTask.combineBindingSets(IBindingSet[] chunk)
Populates a map of asBound predicates paired to a set of
bindingSets.
|
protected AbstractUnsynchronizedArrayBuffer<IBindingSet> |
LocalJoinTask.newUnsyncOutputBuffer()
Note: The target buffer on which the unsynchronized buffer writes
depends on whether or not there is a downstream sink for this
LocalJoinTask . |
protected abstract AbstractUnsynchronizedArrayBuffer<IBindingSet> |
JoinTask.newUnsyncOutputBuffer()
A method used by the
JoinTask.threadLocalBufferFactory to create new
output buffer as required. |
protected AbstractUnsynchronizedArrayBuffer<IBindingSet> |
DistributedJoinTask.newUnsyncOutputBuffer() |
Modifier and Type | Method and Description |
---|---|
protected Map<IPredicate<?>,Collection<IBindingSet>> |
JoinTask.BindingSetConsumerTask.combineBindingSets(IBindingSet[] chunk)
Populates a map of asBound predicates paired to a set of
bindingSets.
|
protected void |
UnsyncLocalOutputBuffer.handleChunk(E[] chunk)
Adds the chunk to the
UnsyncLocalOutputBuffer.syncBuffer and updated the
JoinStats to reflect the #of IBindingSet chunks that
will be output and the #of IBindingSet s in those chunks. |
protected List<Future> |
DistributedJoinMasterTask.mapBindingSet(IBindingSet bindingSet)
Map the given
IBindingSet over the JoinTask (s) for
the index partition(s) the span the IAccessPath for that
IBindingSet in parallel. |
protected ThickAsynchronousIterator<IBindingSet[]> |
JoinMasterTask.newBindingSetIterator(IBindingSet bindingSet)
Return an
IAsynchronousIterator that will read a single
IBindingSet . |
Modifier and Type | Method and Description |
---|---|
protected JoinTask.AccessPathTask[] |
JoinTask.BindingSetConsumerTask.getAccessPathTasks(Map<IPredicate<?>,Collection<IBindingSet>> map)
Creates an
JoinTask.AccessPathTask for each IBindingSet in
the given chunk. |
Constructor and Description |
---|
JoinTask.ChunkTask(IBindingSet[] bindingSet,
AbstractUnsynchronizedArrayBuffer<IBindingSet> unsyncBuffer,
Object[] chunk) |
Constructor and Description |
---|
JoinTask.AccessPathTask(IPredicate<?> predicate,
Collection<IBindingSet> bindingSets)
Evaluate an
IBindingSet for the join dimension. |
JoinTask.ChunkTask(IBindingSet[] bindingSet,
AbstractUnsynchronizedArrayBuffer<IBindingSet> unsyncBuffer,
Object[] chunk) |
Modifier and Type | Method and Description |
---|---|
Object |
FullTextIndex.newElement(List a,
IBindingSet bindingSet) |
Modifier and Type | Field and Description |
---|---|
protected IBindingSet |
FulltextSearchHit.incomingBindings |
Modifier and Type | Method and Description |
---|---|
IBindingSet |
IFulltextSearchHit.getIncomingBindings()
Get the set of incoming bindings for the search hit
|
IBindingSet |
IFulltextSearch.FulltextSearchQuery.getIncomingBindings() |
IBindingSet |
FulltextSearchHit.getIncomingBindings() |
Constructor and Description |
---|
FulltextSearchHit(String res,
Double score,
String snippet,
IBindingSet incomingBindings,
FTS.SearchResultType searchResultType) |
FulltextSearchServiceFactory.FulltextSearchMultiHiterator(IBindingSet[] bindingSet,
TermNode query,
TermNode endpoint,
TermNode endpointType,
TermNode params,
TermNode searchField,
TermNode scoreField,
TermNode snippetField,
TermNode searchResultType,
TermNode searchTimeout,
FulltextSearchServiceFactory.FulltextSearchDefaults defaults,
ServiceCallCreateParams serviceCallParams) |
IFulltextSearch.FulltextSearchQuery(String query,
String params,
String endpoint,
Integer searchTimeout,
String searchField,
String scoreField,
String snippetField,
IBindingSet incomingBindings,
FTS.SearchResultType searchResultType)
Constructor
|
Modifier and Type | Method and Description |
---|---|
IBindingSet |
IGeoSpatialQuery.getIncomingBindings() |
Modifier and Type | Method and Description |
---|---|
IBindingSet |
GeoSpatialQuery.getIncomingBindings() |
Constructor and Description |
---|
GeoSpatialQuery(GeoSpatialConfig geoSpatialConfig,
GeoSpatial.GeoFunction searchFunction,
org.openrdf.model.URI searchDatatype,
IConstant<?> subject,
TermNode predicate,
TermNode context,
GeoSpatialUtility.PointLatLon spatialCircleCenter,
Double spatialCircleRadius,
GeoSpatialUtility.PointLatLon spatialRectangleSouthWest,
GeoSpatialUtility.PointLatLon spatialRectangleNorthEast,
ICoordinate.UNITS spatialUnit,
Long timeStart,
Long timeEnd,
Long coordSystem,
Map<String,IGeoSpatialQuery.LowerAndUpperValue> customFieldsConstraints,
IVariable<?> locationVar,
IVariable<?> timeVar,
IVariable<?> locationAndTimeVar,
IVariable<?> latVar,
IVariable<?> lonVar,
IVariable<?> coordSystemVar,
IVariable<?> customFieldsVar,
IVariable<?> literalVar,
IVariable<?> distanceVar,
IBindingSet incomingBindings)
Constructor
|
Copyright © 2006–2019 SYSTAP, LLC DBA Blazegraph. All rights reserved.