Package | Description |
---|---|
com.bigdata.blueprints | |
com.bigdata.bop |
This package provides an API for query operators.
|
com.bigdata.bop.engine | |
com.bigdata.bop.join | |
com.bigdata.bop.rdf.join | |
com.bigdata.bop.solutions |
This package provides distinct, sort, and aggregation operators.
|
com.bigdata.btree |
The
BTree is a scalable B+-Tree with copy-on-write
semantics mapping variable length unsigned byte[] keys to variable
length byte[] values (null values are allowed). |
com.bigdata.gom.om | |
com.bigdata.htree | |
com.bigdata.rdf.inf |
This package provides an eager closure inference engine for most of the RDF and
RDFS entailments and can be used to realize entailments for owl:sameAs, owl:equivilentClass,
and owl:equivilentProperty.
|
com.bigdata.rdf.internal.encoder | |
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.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.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.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.service.proxy |
This package provides implementations of proxy objects for commonly used
classes.
|
com.bigdata.stream | |
com.bigdata.striterator |
Streaming iterator patterns based on Martyn Cutcher's striterator design
but supporting generics and with extensions for closable, chunked, and
ordered streaming iterators.
|
cutthecrap.utils.striterators |
Modifier and Type | Class and Description |
---|---|
class |
BigdataGraph.WrappedResult<E> |
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<BigdataGraphEdit> |
BigdataGraph.history(List<org.openrdf.model.URI> ids)
If history is enabled, return an iterator of historical graph edits
related to any of the supplied ids.
|
ICloseableIterator<BigdataGraphEdit> |
BigdataGraph.history(List<org.openrdf.model.URI> ids,
String extQueryId) |
ICloseableIterator<BigdataGraphAtom> |
BigdataGraph.project(String queryStr)
Project a subgraph using a SPARQL query.
|
ICloseableIterator<BigdataGraphAtom> |
BigdataGraph.project(String queryStr,
String externalQueryId)
Project a subgraph using a SPARQL query.
|
ICloseableIterator<BigdataBindingSet> |
BigdataGraph.select(String queryStr)
Select results using a SPARQL query.
|
ICloseableIterator<BigdataBindingSet> |
BigdataGraph.select(String queryStr,
String externalQueryId)
Select results using a SPARQL query.
|
Modifier and Type | Method and Description |
---|---|
static ICloseableIterator<IBindingSet[]> |
BOpUtility.asIterator(IBindingSet[] bindingSets)
Wrap the solutions with an
ICloseableIterator . |
ICloseableIterator<IBindingSet[]> |
BOpContext.getAlternateSource(INamedSolutionSetRef namedSetRef)
Return an
ICloseableIterator that can be used to read the
solutions to be indexed from a source other than the pipeline. |
static ICloseableIterator<IBindingSet[]> |
NamedSolutionSetRefUtility.getSolutionSet(ISolutionSetManager sparqlCache,
IBTreeManager localIndexManager,
String namespace,
long timestamp,
String localName,
IVariable[] joinVars,
int chunkCapacity)
Resolve the pre-existing named solution set returning an iterator that
will visit the solutions (access path scan).
|
ICloseableIterator<E[]> |
BOpContext.getSource()
Where to read the data to be consumed by the operator.
|
ICloseableIterator<IBindingSet[]> |
BOpContext.solutions(IChunkedIterator<?> src,
IPredicate<?> pred,
BaseJoinStats stats)
Convert an
IAccessPath.iterator() into a stream of chunks of
IBindingSet . |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<IBindingSet[]> |
AbstractRunningQuery.iterator() |
ICloseableIterator<IBindingSet[]> |
IRunningQuery.iterator()
Return an iterator which will drain the solutions from the query.
|
ICloseableIterator<E[]> |
IChunkAccessor.iterator()
Visit the binding sets in the chunk.
|
Modifier and Type | Method and Description |
---|---|
static void |
AbstractQueryEngineTestCase.assertSameSolutions(IBindingSet[] expected,
ICloseableIterator<IBindingSet[]> itr,
Future<Void> ft)
Verify the expected solutions.
|
static void |
AbstractQueryEngineTestCase.assertSameSolutionsAnyOrder(IBindingSet[] expected,
ICloseableIterator<IBindingSet[]> itr,
Future<?> future) |
static void |
AbstractQueryEngineTestCase.assertSameSolutionsAnyOrder(String msg,
IBindingSet[] expected,
ICloseableIterator<IBindingSet[]> itr,
Future<?> runningQuery) |
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 |
---|---|
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) |
long |
IHashJoinUtility.acceptSolutions(ICloseableIterator<IBindingSet[]> itr,
BOpStats stats)
Buffer solutions on a hash index.
|
long |
JVMHashJoinUtility.acceptSolutions(ICloseableIterator<IBindingSet[]> itr,
BOpStats stats) |
long |
HTreeHashJoinUtility.acceptSolutions(ICloseableIterator<IBindingSet[]> itr,
BOpStats stats) |
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) |
Modifier and Type | Class and Description |
---|---|
class |
ChunkedMaterializationIterator
Iterator pattern for chunked materialization.
|
Constructor and Description |
---|
ChunkedMaterializationIterator(IVariable<?>[] vars,
LexiconRelation lex,
boolean materializeInlineIVs,
ICloseableIterator<IBindingSet[]> src) |
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<IBindingSet[]> |
ISolutionSet.get()
Return an
ICloseableIterator reading the solutions from the
stream. |
ICloseableIterator<IBindingSet[]> |
SolutionSetStream.get() |
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 |
---|---|
void |
ISolutionSet.put(ICloseableIterator<IBindingSet[]> src)
Replace the contents of the stream with the solutions read from the
source.
|
void |
SolutionSetStream.put(ICloseableIterator<IBindingSet[]> src2) |
void |
SolutionSetStream.write(ICloseableIterator<?> src) |
Modifier and Type | Class and Description |
---|---|
class |
EntryScanIterator
Iterator visits index entries (dereferencing visited tuples to the
application objects stored within those tuples).
|
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<?> |
ISimpleIndexAccess.scan()
Visit all entries in the index in the natural order of the index
(dereferencing visited tuples to the application objects stored within
those tuples).
|
ICloseableIterator<?> |
AbstractBTree.scan() |
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<org.openrdf.query.BindingSet> |
NanoSparqlObjectManager.evaluate(String query) |
ICloseableIterator<org.openrdf.query.BindingSet> |
ObjectManager.evaluate(String query) |
ICloseableIterator<org.openrdf.query.BindingSet> |
IObjectManager.evaluate(String queryStr) |
ICloseableIterator<org.openrdf.model.Statement> |
NanoSparqlObjectManager.evaluateGraph(String query) |
ICloseableIterator<org.openrdf.model.Statement> |
ObjectManager.evaluateGraph(String query) |
ICloseableIterator<org.openrdf.model.Statement> |
IObjectManager.evaluateGraph(String query) |
Modifier and Type | Method and Description |
---|---|
protected Map<org.openrdf.model.Resource,IGPO> |
ObjectMgrModel.initGPO(GPO gpo,
ICloseableIterator<org.openrdf.model.Statement> stmts)
Initialize one or more
IGPO s from a collection of statements. |
Map<org.openrdf.model.Resource,IGPO> |
ObjectMgrModel.initGPOs(ICloseableIterator<org.openrdf.model.Statement> itr) |
Map<org.openrdf.model.Resource,IGPO> |
IObjectManager.initGPOs(ICloseableIterator<org.openrdf.model.Statement> itr)
Partially materialize
IGPO s from a stream of Statement s. |
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<?> |
AbstractHTree.scan() |
Modifier and Type | Interface and Description |
---|---|
interface |
IJustificationIterator
Interface for chunked
Justification iterators. |
Modifier and Type | Class and Description |
---|---|
class |
BackchainOwlSameAsIterator |
class |
BackchainOwlSameAsPropertiesIterator
Provides backward chaining for property collection and reverse property
collection on owl:sameAs for all access paths.
|
class |
BackchainOwlSameAsPropertiesPIterator
Provides backward chaining for property collection and reverse property
collection on owl:sameAs for the ?P? and ??? access paths.
|
class |
BackchainOwlSameAsPropertiesPOIterator
Provides backward chaining for reverse property collection on owl:sameAs for
the ?PO and ??O access paths.
|
class |
BackchainOwlSameAsPropertiesSPIterator
Provides backward chaining for property collection on owl:sameAs for the SP?
and S?? access paths.
|
class |
BackchainOwlSameAsPropertiesSPOIterator
Provides backward chaining for property collection and reverse property
collection on owl:sameAs for the SPO and S?O access paths.
|
class |
BackchainTypeResourceIterator
Provides backward chaining for (x rdf:type rdfs:Resource).
|
static class |
BackchainTypeResourceIterator.PushbackIterator<E>
Implementation class for
BackchainTypeResourceIterator.PushbackFilter . |
class |
FullyBufferedJustificationIterator
Fully buffers and then visits all
Justification s for a given
statement. |
class |
JustificationIterator
Deprecated.
replace with appropriate access path reading on the
justifications index for SPORelation (or treat as a secondary
relation).
|
class |
OwlSameAsPropertiesExpandingIterator |
Modifier and Type | Class and Description |
---|---|
class |
SolutionSetStreamDecoder
Stream decoder for solution sets (chunk oriented).
|
Modifier and Type | Method and Description |
---|---|
void |
SolutionSetStreamEncoder.encode(DataOutputStream os,
ICloseableIterator<IBindingSet[]> src2)
Encode solutions onto the output stream.
|
Modifier and Type | Class and Description |
---|---|
class |
RunningQueryCloseableIterator<E>
Iteration construct wraps an
IRunningQuery with logic to (a) verify
that the IRunningQuery has not encountered an error; and (b) to
cancel the IRunningQuery when the iterator draining the
IRunningQuery is closed . |
class |
Sesame2BigdataIterator<T,E extends Exception>
Class aligns a Sesame 2
CloseableIteration with a bigdata
ICloseableIterator . |
Constructor and Description |
---|
Bigdata2Sesame2BindingSetIterator(ICloseableIterator<IBindingSet> src) |
Bigdata2Sesame2BindingSetIterator(ICloseableIterator<IBindingSet> src,
org.openrdf.query.BindingSet constants) |
Bigdata2SesameIteration(ICloseableIterator<? extends T> src) |
RunningQueryCloseableIterator(IRunningQuery runningQuery,
ICloseableIterator<E> src) |
Modifier and Type | Class and Description |
---|---|
class |
SolutionSetStatserator
Class populates an
ISolutionSetStats object from a stream of
solutions. |
Modifier and Type | Class and Description |
---|---|
static class |
GeoSpatialServiceFactory.GeoSpatialInputBindingsIterator
Iterates a geospatial search over a set of input bindings.
|
Modifier and Type | Method and Description |
---|---|
static ICloseableIterator<IBindingSet[]> |
ASTEvalHelper.evaluateTupleQuery2(AbstractTripleStore store,
ASTContainer astContainer,
org.openrdf.query.algebra.evaluation.QueryBindingSet globallyScopedBS,
boolean materialize)
Evaluate a SELECT query without converting the results into openrdf
solutions.
|
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<org.openrdf.query.BindingSet> |
RemoteServiceCallImpl.call(org.openrdf.query.BindingSet[] bindingSets) |
ICloseableIterator<E> |
ServiceCall.call(E[] bindingSets)
Invoke an service.
|
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<IBindingSet[]> |
SolutionSetManager.getSolutions(String solutionSet) |
ICloseableIterator<IBindingSet[]> |
ISolutionSetManager.getSolutions(String solutionSet)
Read the solutions from a named solution set.
|
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) |
void |
SolutionSetManager.putSolutions(String solutionSet,
ICloseableIterator<IBindingSet[]> src) |
void |
ISolutionSetManager.putSolutions(String solutionSet,
ICloseableIterator<IBindingSet[]> src)
Save the solutions into a named solution set.
|
Modifier and Type | Class and Description |
---|---|
class |
DistinctSPOIterator
Deprecated.
By a simple distinct filter and a filter which strips off the
context position from an SPOC. Stack them together and it does
the same thing. (The fall back to the B+Tree might still be
interesting if we do not have a persistent hash map to fall back
on instead and we want streaming results. Otherwise use an
external merge sort.)
|
class |
SPOArrayIterator
Deprecated.
by
ChunkedArrayIterator but this still has some very
purpose specific uses mainly dealing with
TruthMaintenance and with fully buffering precisely
because the DB impl is not using concurrency controls. |
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<ISPO> |
SPORelation.distinctSPOIterator(ICloseableIterator<ISPO> src)
Return an iterator that will visit the distinct (s,p,o) tuples in the
source iterator.
|
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<ISPO> |
SPORelation.distinctSPOIterator(ICloseableIterator<ISPO> src)
Return an iterator that will visit the distinct (s,p,o) tuples in the
source iterator.
|
Constructor and Description |
---|
DistinctSPOIterator(SPORelation spoRelation,
ICloseableIterator<ISPO> src)
Deprecated.
|
Modifier and Type | Interface and Description |
---|---|
interface |
BigdataStatementIterator
Iterator visiting
BigdataStatement s. |
interface |
BigdataValueIterator
Iterator visiting
BigdataValue s. |
Modifier and Type | Class and Description |
---|---|
class |
BigdataBindingSetResolverator
Efficiently resolve term identifiers in Bigdata
IBindingSet s to RDF
BigdataValue s. |
class |
BigdataOpenRDFBindingSetsResolverator
Efficiently resolve openrdf
BindingSet s to bigdata
IBindingSet s (this is a streaming API). |
class |
BigdataSolutionResolverator
Efficiently resolve term identifiers in Bigdata
ISolution s to RDF
BigdataValue s. |
class |
BigdataStatementIteratorImpl
Efficiently resolve term identifiers in Bigdata
ISPO s to RDF
BigdataValue s. |
class |
BigdataTriplePatternMaterializer
Efficient batched, streaming resolution of triple patterns to statements
spanned by those triple patterns that are present in the data.
|
class |
BigdataValueIteratorImpl
Wraps an iterator that visits term identifiers and exposes each visited term
identifier as a
BigdataValue (batch API). |
class |
EmptyStatementIterator
Empty iterator.
|
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: |
static ICloseableIterator<BigdataStatement> |
TripleStoreUtility.notFoundInTarget(AbstractTripleStore expected,
AbstractTripleStore actual)
Visits expected
BigdataStatement s not found in actual. |
Modifier and Type | Interface and Description |
---|---|
interface |
IAsynchronousIterator<E>
Interface for iterators that are running asynchronously.
|
interface |
IMultiSourceCloseableIterator<E>
An interface which permits new sources to be attached dynamically.
|
Modifier and Type | Class and Description |
---|---|
protected class |
BlockingBuffer.BlockingIterator
An inner class that reads from the buffer.
|
class |
ChunkConsumerIterator<E>
A class that aligns a buffer of
E[] s (a buffer of chunks) with
an IChunkedOrderedIterator . |
class |
EmptyAsynchronousIterator<E>
An empty
IAsynchronousIterator . |
class |
EmptyCloseableIterator<E>
An empty
ICloseableIterator . |
class |
MultiSourceSequentialCloseableIterator<E>
Class allows new sources to be attached dynamically.
|
class |
ThickAsynchronousIterator<E>
An
IAsynchronousIterator that may be serialized and sent to a remote
JVM for consumption. |
class |
ThickCloseableIterator<E>
An
ICloseableIterator that may be serialized and sent to a remote
JVM for consumption. |
class |
WrappedAsynchronousIterator<E,F>
|
Modifier and Type | Method and Description |
---|---|
ICloseableIterator<IBindingSet[]> |
IBindingSetAccessPath.solutions(BOpContext context,
long limit,
BaseJoinStats stats)
Return an iterator which will visit the solutions drawn from the access
path with a limit on the number of solutions drawn.
|
ICloseableIterator<IBindingSet[]> |
AccessPath.solutions(BOpContext context,
long limit,
BaseJoinStats stats)
Return an iterator which will visit the solutions drawn from the access
path with a limit on the number of solutions drawn.
|
Modifier and Type | Method and Description |
---|---|
boolean |
MultiSourceSequentialCloseableIterator.add(ICloseableIterator<E> src) |
boolean |
IMultiSourceCloseableIterator.add(ICloseableIterator<E> src)
Add a source.
|
protected void |
TestThickCloseableIterator.assertSameIterator(String[] expected,
ICloseableIterator<String> actual) |
protected void |
TestThickCloseableIterator.doRoundTripTest(String[] expected,
ICloseableIterator<String> itr) |
Constructor and Description |
---|
ChunkConsumerIterator(ICloseableIterator<E[]> src) |
ChunkConsumerIterator(ICloseableIterator<E[]> src,
IKeyOrder<E> keyOrder) |
MultiSourceSequentialCloseableIterator(ICloseableIterator<E> src) |
Modifier and Type | Class and Description |
---|---|
class |
ClientAsynchronousIterator<E>
Wraps an
RemoteAsynchronousIterator so that it looks like an
IAsynchronousIterator again. |
class |
WrappedRemoteChunkedIterator<E>
Wraps an
IRemoteChunkedIterator so that it looks like an
IChunkedOrderedIterator again. |
Modifier and Type | Method and Description |
---|---|
abstract ICloseableIterator<?> |
Stream.scan() |
Modifier and Type | Method and Description |
---|---|
abstract void |
Stream.write(ICloseableIterator<?> src)
Write entries onto the stream.
|
Modifier and Type | Interface and Description |
---|---|
interface |
IChunkedIterator<E>
An iterator that is able visit items in chunks.
|
interface |
IChunkedOrderedIterator<R>
An extension of
IChunkedIterator interface that knows about natural
traversal orders and how to re-order the elements that are being visited to
support JOINs where the natural order for the access paths is different for
the left- and right-hand side of the JOIN. |
interface |
IChunkedOrderedStriterator<I extends IChunkedOrderedIterator<E>,E>
Generic-enabled streaming iterator pattern for chunked ordered iterators.
|
interface |
IChunkedStriterator<I extends IChunkedIterator<E>,E>
Generic-enabled streaming iterator pattern for chunked iterators.
|
interface |
IStriterator<I extends Iterator<E>,E>
Streaming iterator pattern ala Martyn Cutcher with generics.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractChunkedResolverator<E,F,S>
Wraps an
IChunkedIterator and asynchronously resolves chunks. |
class |
ChunkedArrayIterator<E>
Fully buffered iterator.
|
class |
ChunkedArraysIterator<E>
An iterator that visits the elements in the given iterator of arrays.
|
class |
ChunkedConvertingIterator<E,F>
Supports the chunk-at-a-time filter and conversion operations.
|
class |
ChunkedOrderedStriterator<I extends IChunkedOrderedIterator<E>,E>
Chunked ordered streaming iterator.
|
class |
ChunkedResolvingIterator<E,S>
Converts the type of the source iterator using
ChunkedResolvingIterator.resolve(Object) . |
class |
ChunkedStriterator<I extends IChunkedIterator<E>,E>
Chunked streaming iterator.
|
class |
ChunkedWrappedIterator<E>
Converts an
Iterator into chunked iterator. |
class |
Chunkerator<E>
Iterator "chunks" up another iterator, visiting arrays of elements at a time.
|
class |
ClosableEmptyIterator<E>
A closable iterator that visits nothing.
|
class |
ClosableSingleItemIterator<E>
A closable iterator that visits a single item.
|
class |
CloseableChunkedIteratorWrapperConverter<E>
A fly weight conversion that wraps a normal
IChunkedIterator as an
ICloseableIterator visiting the source iterator's chunks, i.e., this
converts between an IChunkedIterator and an Iterator visiting
chunks. |
class |
CloseableIteratorWrapper<E>
Wraps a normal
Iterator as an ICloseableIterator . |
class |
Dechunkerator<E>
Wrap an iterator visiting chunks as an iterator visiting the individual
elements in each chunk.
|
class |
DelegateChunkedIterator<E>
Abstract class for delegation patterns for chunked iterators.
|
class |
EmptyChunkedIterator<E>
An empty iterator.
|
class |
GenericChunkedOrderedStriterator<E>
Chunked ordered streaming iterator class that supresses generic types.
|
class |
GenericChunkedStriterator<E>
Chunked streaming iterator class that supresses generic types.
|
class |
GenericStriterator<E>
Streaming iterator class that suppresses generic types.
|
class |
PushbackIterator<E>
Allows pushback of the most recently visited element onto the iterator.
|
class |
SingleValueChunkedIterator<E>
An iterator that will visit a single value.
|
Constructor and Description |
---|
ChunkedArraysIterator(ICloseableIterator<E[]> a)
An iterator that visits the elements in the given iterator of arrays.
|
ChunkedArraysIterator(ICloseableIterator<E[]> a,
IKeyOrder<E> keyOrder)
An iterator that visits the elements in the given iterator of arrays.
|
Modifier and Type | Class and Description |
---|---|
class |
SingleValueIterator<E>
SingleValueIterator
Only one value but need to return an iterator? This makes it easy.
|
class |
Striterator
Striterator - transformation and mapping patterns over java
Iterator
s. |
class |
XPropertyIterator
XPropertyIterator
|
Copyright © 2006–2019 SYSTAP, LLC DBA Blazegraph. All rights reserved.