Package | Description |
---|---|
com.bigdata.bop.engine | |
com.bigdata.bop.fed.shards | |
com.bigdata.bop.join | |
com.bigdata.rdf.load |
Support for concurrent loading of RDF data across one or more clients from
a variety of input sources.
|
com.bigdata.rdf.rio |
This package provides an integration with the openrdf RIO parser that supports
fast data loads.
|
com.bigdata.rdf.rules | |
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.eval |
This package supports rule evaluation.
|
com.bigdata.relation.rule.eval.pipeline |
This package implements a pipeline join.
|
com.bigdata.service |
This package provides implementations of bigdata services (metadata
service, data service, transaction manager service.
|
com.bigdata.service.proxy |
This package provides implementations of proxy objects for commonly used
classes.
|
Modifier and Type | Class and Description |
---|---|
class |
BlockingBufferWithStats<E>
Extended to use the
BufferAnnotations to provision the
BlockingBuffer and to track the BOpStats as chunks are added
to the buffer. |
class |
OutputStatsBuffer<E>
Delegation pattern handles the
SinkTransitionMetadata . |
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 IBuffer<IBindingSet[]> |
MapBindingSetsOverShardsBuffer.getBuffer(PartitionLocator locator)
Return the buffer used to absorb binding sets which target the specified
index partition.
|
protected abstract IBuffer<IBindingSet[]> |
MapBindingSetsOverShardsBuffer.newBuffer(PartitionLocator locator)
Return a buffer onto which binding sets will be written which are
destined for the specified shard.
|
Modifier and Type | Method and Description |
---|---|
Map<PartitionLocator,IBuffer<IBindingSet[]>> |
MapBindingSetsOverShardsBuffer.getSinks()
An immutable view of the sinks.
|
Modifier and Type | Class and Description |
---|---|
protected static class |
AbstractHashJoinUtilityTestCase.TestBuffer<E>
A buffer which absorbs solutions and let's us replay them via an
iterator.
|
Modifier and Type | Method and Description |
---|---|
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.
|
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) |
Modifier and Type | Class and Description |
---|---|
class |
VerifyStatementBuffer
Statements inserted into the buffer are verified against the database.
|
Modifier and Type | Interface and Description |
---|---|
interface |
IStatementBuffer<F extends org.openrdf.model.Statement>
Abstraction for a buffer that loads
Statement s into an
AbstractTripleStore . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractStatementBuffer<F extends org.openrdf.model.Statement,G extends BigdataStatement>
Class for efficiently converting
Statement s into
BigdataStatement s, including resolving term identifiers (or adding
entries to the lexicon for unknown terms) as required. |
static class |
AbstractStatementBuffer.StatementBuffer2<F extends org.openrdf.model.Statement,G extends BigdataStatement>
Loads
Statement s into an RDF database. |
protected class |
AsynchronousStatementBufferFactory.AsynchronousStatementBufferImpl
Inner class provides the statement buffer.
|
class |
StatementBuffer<S extends org.openrdf.model.Statement>
A write buffer for absorbing the output of the RIO parser or other
Statement source and writing that output onto an
AbstractTripleStore using the batch API. |
Modifier and Type | Class and Description |
---|---|
static class |
RDFJoinNexus.InsertSPOAndJustificationBuffer<E>
Buffer writes on
IMutableRelation#insert(IChunkedIterator) when it is
flushed . |
Modifier and Type | Method and Description |
---|---|
IBuffer<ISolution[]> |
RDFJoinNexus.newInsertBuffer(IMutableRelation relation)
Overridden to handle justifications when using truth maintenance.
|
Constructor and Description |
---|
AbstractRuleDistinctTermScan.DistinctTermScan(IRule rule,
IJoinNexus joinNexus,
IBuffer<ISolution[]> buffer,
IVariable<IV> h,
SPOKeyOrder keyOrder) |
AbstractRuleFastClosure_3_5_6_7_9.FastClosureRuleTask(String database,
String focusStore,
IRule rule,
IJoinNexus joinNexus,
IBuffer<ISolution[]> buffer,
IConstant<IV> rdfsSubPropertyOf,
IConstant<IV> propertyId)
(?x, {P}, ?y) -> (?x, propertyId, ?y)
Note: Both the database and the (optional) focusStore relation names
MUST be declared for these rules. |
Modifier and Type | Class and Description |
---|---|
class |
ThreadLocalBufferFactory<T extends IBuffer<E>,E>
A factory pattern for per-thread objects whose life cycle is tied to some
container.
|
Modifier and Type | Interface and Description |
---|---|
interface |
IBlockingBuffer<E>
Interface provides an iterator to drain chunks from an
IBuffer . |
interface |
IRunnableBuffer<E>
An
IBuffer that may be closed. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractArrayBuffer<E>
A thread-safe buffer backed by a fixed capacity array.
|
class |
AbstractElementBuffer<R>
Base class for
IBuffer of IRelation elements whose target is
a mutation (insert, delete, or update) of some IMutableRelation . |
static class |
AbstractElementBuffer.DeleteBuffer<R>
Buffer writes on
IMutableRelation.delete(IChunkedOrderedIterator)
when it is flushed . |
static class |
AbstractElementBuffer.InsertBuffer<R>
Buffer writes on
IMutableRelation.insert(IChunkedOrderedIterator)
when it is flushed . |
class |
AbstractUnsynchronizedArrayBuffer<E>
An abstract implementation of an unsynchronized buffer backed by a fixed
capacity array.
|
class |
BlockingBuffer<E>
A buffer that will block when it is full.
|
class |
DelegateBuffer<E>
A delegation pattern which does not pass on the
DelegateBuffer.close() method. |
class |
UnsynchronizedArrayBuffer<E>
An unsynchronized buffer backed by a fixed capacity array that migrates
references onto the caller's buffer (which is normally thread-safe) using
IBuffer#add(int) . |
class |
UnsynchronizedUnboundedChunkBuffer<E>
An unsynchronized buffer backed by a fixed capacity array that migrates
references onto an internal
Queue , which may be drained by an
UnsynchronizedUnboundedChunkBuffer.iterator() . |
class |
UnsyncLocalOutputBuffer<E extends IBindingSet>
Wraps the base class to update the caller's
BOpStats . |
Constructor and Description |
---|
FlushBufferTask(IBuffer<ISolution[]> buffer) |
UnsynchronizedArrayBuffer(IBuffer<E[]> target,
Class<? extends E> cls,
int capacity) |
UnsynchronizedArrayBuffer(IBuffer<E[]> target,
int capacity,
Class<? extends E> cls,
IElementFilter<E> filter) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractSolutionBuffer<R>
Base class for
IBuffer whose target is a mutation (insert, delete, or
update) of some IMutableRelation . |
static class |
AbstractSolutionBuffer.DeleteSolutionBuffer<E>
Buffer writes on
IMutableRelation.delete(IChunkedOrderedIterator) when it is
flushed . |
static class |
AbstractSolutionBuffer.InsertSolutionBuffer<E>
Buffer writes on
IMutableRelation#insert(IChunkedIterator) when it is
flushed . |
Modifier and Type | Method and Description |
---|---|
IBuffer<ISolution[]> |
AbstractJoinNexus.newDeleteBuffer(IMutableRelation relation)
Return a thread-safe buffer onto which chunks of computed
ISolution s will be written. |
IBuffer<ISolution[]> |
IJoinNexus.newDeleteBuffer(IMutableRelation relation)
Return a thread-safe buffer onto which chunks of computed
ISolution s will be written. |
IBuffer<ISolution[]> |
AbstractJoinNexus.newInsertBuffer(IMutableRelation relation)
Return a thread-safe buffer onto which chunks of computed
ISolution s will be written. |
IBuffer<ISolution[]> |
IJoinNexus.newInsertBuffer(IMutableRelation relation)
Return a thread-safe buffer onto which chunks of computed
ISolution s will be written. |
IBuffer<ISolution> |
AbstractJoinNexus.newUnsynchronizedBuffer(IBuffer<ISolution[]> targetBuffer,
int chunkCapacity) |
IBuffer<ISolution> |
IJoinNexus.newUnsynchronizedBuffer(IBuffer<ISolution[]> targetBuffer,
int chunkCapacity)
Return a buffer suitable for a single-threaded writer that flushes onto
the specified targetBuffer.
|
Modifier and Type | Method and Description |
---|---|
protected Map<String,IBuffer<ISolution[]>> |
AbstractStepTask.getMutationBuffers(IJoinNexus joinNexus,
Map<String,IRelation> relations)
Create the appropriate buffers to absorb writes by the rules in the
program that target an
IMutableRelation . |
Modifier and Type | Method and Description |
---|---|
IStepTask |
RunRuleAndFlushBufferTaskFactory.newTask(IRule rule,
IJoinNexus joinNexus,
IBuffer<ISolution[]> buffer)
Deprecated.
|
IStepTask |
DefaultRuleTaskFactory.newTask(IRule rule,
IJoinNexus joinNexus,
IBuffer<ISolution[]> buffer) |
IStepTask |
IRuleTaskFactory.newTask(IRule rule,
IJoinNexus joinNexus,
IBuffer<ISolution[]> buffer)
The object will be used to evaluate the rule for the
IRule . |
IBuffer<ISolution> |
AbstractJoinNexus.newUnsynchronizedBuffer(IBuffer<ISolution[]> targetBuffer,
int chunkCapacity) |
IBuffer<ISolution> |
IJoinNexus.newUnsynchronizedBuffer(IBuffer<ISolution[]> targetBuffer,
int chunkCapacity)
Return a buffer suitable for a single-threaded writer that flushes onto
the specified targetBuffer.
|
Modifier and Type | Method and Description |
---|---|
protected void |
MutationTask.flushBuffers(IJoinNexus joinNexus,
Map<String,IBuffer<ISolution[]>> buffers)
Flush the buffer(s) and aggregate the mutation count from each buffer.
|
protected long |
MutationTask.getMutationCountFromBuffers(RuleStats totals,
Map<String,IBuffer<ISolution[]>> buffers)
This just reads off and aggregates the mutationCount from each buffer as
reported by
flush() . |
protected List<Callable<RuleStats>> |
MutationTask.newMutationTasks(IStep step,
IJoinNexus joinNexus,
Map<String,IBuffer<ISolution[]>> buffers)
Builds a set of tasks for the program.
|
Constructor and Description |
---|
RunRuleAndFlushBufferTask(IStepTask stepTask,
IBuffer<ISolution[]> buffer) |
Modifier and Type | Class and Description |
---|---|
class |
JoinTask.ThreadLocalFactory<T extends IBuffer<E>,E>
A factory pattern for per-thread objects whose life cycle is tied to some
container.
|
Modifier and Type | Field and Description |
---|---|
protected IBuffer<ISolution[]> |
JoinMasterTask.solutionBuffer
From the ctor.
|
Modifier and Type | Method and Description |
---|---|
IBuffer<ISolution[]> |
IJoinMaster.getSolutionBuffer()
A proxy for the buffer on which the last
DistributedJoinTask must
write its query solutions. |
IBuffer<ISolution[]> |
DistributedJoinMasterTask.getSolutionBuffer() |
protected IBuffer<ISolution[]> |
LocalJoinTask.getSolutionBuffer() |
protected abstract IBuffer<ISolution[]> |
JoinTask.getSolutionBuffer()
The buffer on which the last predicate in the evaluation order will
write its
ISolution s. |
protected IBuffer<ISolution[]> |
DistributedJoinTask.getSolutionBuffer() |
IBuffer<ISolution[]> |
JoinMasterTask.getSolutionBuffer()
Returns the buffer specified to the ctor (overridden for distributed
joins).
|
Constructor and Description |
---|
DistributedJoinMasterTask(IRule rule,
IJoinNexus joinNexus,
IBuffer<ISolution[]> buffer) |
JoinMasterTask(IRule rule,
IJoinNexus joinNexus,
IBuffer<ISolution[]> solutionBuffer) |
LocalJoinMasterTask(IRule rule,
IJoinNexus joinNexus,
IBuffer<ISolution[]> buffer) |
LocalJoinTask(IRule rule,
IJoinNexus joinNexus,
int[] order,
int orderIndex,
IJoinMaster masterProxy,
UUID masterUUID,
IAsynchronousIterator<IBindingSet[]> source,
IBuffer<ISolution[]> solutionBuffer,
IVariable[][] requiredVars) |
Modifier and Type | Method and Description |
---|---|
abstract <E> IBuffer<E> |
AbstractDistributedFederation.getProxy(IBuffer<E> buffer)
Return a proxy object for an
IBuffer suitable for use in an RMI
environment. |
Modifier and Type | Method and Description |
---|---|
abstract <E> IBuffer<E> |
AbstractDistributedFederation.getProxy(IBuffer<E> buffer)
Return a proxy object for an
IBuffer suitable for use in an RMI
environment. |
Modifier and Type | Class and Description |
---|---|
class |
ClientBuffer<E>
Serializable class wraps a RemoteBuffer delegating methods
through to the IBuffer on the remote service while masquerading
IOException s so that we can implement the IBuffer API. |
class |
ClientRunnableBuffer<E,V>
Serializable class wraps a RemoteRunnableBuffer delegating
methods through to the IRunnableBuffer on the remote service while
masquerading IOException s so that we can implement the
IRunnableBuffer API. |
Constructor and Description |
---|
RemoteBufferImpl(IBuffer<E> buffer) |
Copyright © 2006–2019 SYSTAP, LLC DBA Blazegraph. All rights reserved.