Package | Description |
---|---|
com.bigdata.bfs |
This package provides a scale-out content repository (aka distributed file
system) suitable as the backend for a REST-ful service using the bigdata
architecture.
|
com.bigdata.bop |
This package provides an API for query operators.
|
com.bigdata.bop.ap | |
com.bigdata.bop.ap.filter |
These filters are based on the striterator patterns.
|
com.bigdata.bop.rdf.filter | |
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.btree.filter | |
com.bigdata.btree.view | |
com.bigdata.rdf.graph.impl |
This is an implementation of the GAS API for the bigdata platform.
|
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.lexicon | |
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.spo |
This package defines a statement model using long term identifiers rather than
RDF Value objects.
|
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.resources |
This package provides the logic to managed the live journal and the
historical journals and index segments for a
DataService . |
com.bigdata.service |
This package provides implementations of bigdata services (metadata
service, data service, transaction manager service.
|
com.bigdata.service.geospatial | |
com.bigdata.service.ndx | |
com.bigdata.sparse |
This package provides support for treating normal B+Trees using a
"sparse row store" pattern and can be applied to both local B+Trees
and scale-out indices.
|
cutthecrap.utils.striterators |
Modifier and Type | Class and Description |
---|---|
class |
FileVersionDeleter
A procedure that performs a key range scan, marking all non-deleted
versions within the key range as deleted (by storing a null property
value for the
FileMetadataSchema.VERSION ). |
Modifier and Type | Method and Description |
---|---|
IFilter |
IPredicate.getAccessPathFilter()
Return the optional filter to be evaluated once tuples have been
converted into relation elements by the access path (local to the
caller).
|
IFilter |
IPredicate.getIndexLocalFilter()
Return the optional filter to be evaluated local to the index.
|
Modifier and Type | Method and Description |
---|---|
IFilter |
Predicate.getAccessPathFilter() |
IFilter |
Predicate.getIndexLocalFilter() |
Modifier and Type | Method and Description |
---|---|
Predicate<E> |
Predicate.addAccessPathFilter(IFilter filter)
|
Predicate<E> |
Predicate.addIndexLocalFilter(IFilter filter)
|
Modifier and Type | Class and Description |
---|---|
class |
BOpFilter
Used to filter for objects which satisfy some criteria.
|
class |
BOpFilterBase
Base class for operators which apply striterator patterns for access paths.
|
class |
BOpFilterNOP
A filter which does nothing.
|
class |
BOpResolver
Striterator resolver pattern.
|
class |
BOpTupleFilter<E>
Filter supporting
ITupleIterator s. |
class |
DistinctFilter
A DISTINCT operator based for elements in a relation.
|
static class |
DistinctFilter.DistinctFilterImpl
DISTINCT filter based on Java heap data structures.
|
Modifier and Type | Class and Description |
---|---|
class |
NativeDistinctFilter
A scalable DISTINCT operator based for
SPO s. |
static class |
NativeDistinctFilter.DistinctFilterImpl
|
class |
StripContextFilter
Strips the context information from an
SPO . |
Modifier and Type | Field and Description |
---|---|
protected IFilter |
AbstractChunkedTupleIterator.filter
Optional filter.
|
Modifier and Type | Method and Description |
---|---|
protected int |
TestChunkedIterators.doDeserializationTest(BTree ndx,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filterCtor)
Test helper requests an
ITupleIterator using the specified
parameters directly on the BTree (ground truth for the purposes
of this test) and indirectly via an AbstractChunkedTupleIterator . |
protected ResultSet |
ChunkedLocalRangeIterator.getResultSet(long timestamp,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
Note: timestamp is ignored since we are reading against a local
index object.
|
protected abstract ResultSet |
AbstractChunkedTupleIterator.getResultSet(long timestamp,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
Abstract method must return the next
ResultSet based on the
supplied parameter values. |
ITupleIterator |
IRangeQuery.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filterCtor)
Designated variant (the one that gets overridden) for an iterator that
visits the entries in a half-open key range.
|
ITupleIterator |
DelegateIndex.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter) |
ITupleIterator |
ReadCommittedView.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filterCtor) |
ITupleIterator |
UnisolatedReadWriteIndex.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
The iterator will read on the underlying index in chunks, buffering
tuples as it goes.
|
ITupleIterator |
ReadOnlyIndex.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
IRangeQuery.REMOVEALL and Iterator.remove() are disabled. |
ITupleIterator |
AbstractBTree.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacityIsIgnored,
int flags,
IFilter filter)
Designated variant (the one that gets overridden) for an iterator that
visits the entries in a half-open key range.
|
ITupleIterator |
AbstractBTree.rangeIterator(Object fromKey,
Object toKey,
int capacity,
int flags,
IFilter filter)
Variant implicitly converts the optional application keys into unsigned
byte[]s.
|
Constructor and Description |
---|
AbstractChunkedTupleIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter) |
ChunkedLocalRangeIterator(IIndex ndx,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter) |
Modifier and Type | Interface and Description |
---|---|
interface |
ITupleFilter<E>
Interface for stacked filtering iterators for
ITuple s. |
Modifier and Type | Class and Description |
---|---|
class |
Advancer<E>
Used to write logic that advances an
ITupleCursor to another key
after it visits some element. |
class |
LookaheadTupleFilter<E>
Lookahead filter for an
ITuple . |
class |
PrefixFilter<E>
Filter visits all
ITuple s whose keys begin with any of the specified
prefix(s). |
class |
TupleFilter<E>
Filter supporting
ITupleIterator s. |
class |
TupleRemover<E>
Visits all elements visited by the source iterator and removes those
matching the filter.
|
class |
TupleTransformer<E,F>
Abstract base class for an
ITupleFilter that transforms the data type
of the keys and/or values. |
class |
TupleUpdater<E>
Filter allows mutation of the visited
ITuple s. |
Modifier and Type | Method and Description |
---|---|
ITupleIterator |
FusedView.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
Core implementation.
|
Modifier and Type | Class and Description |
---|---|
class |
EdgeOnlyFilter<VS,ES,ST>
Filter visits only edges (filters out attribute values).
|
Modifier and Type | Method and Description |
---|---|
protected IFilter |
GASContext.getLinkAttribFilter(IGASContext<VS,ES,ST> ctx,
org.openrdf.model.URI linkAttribType)
Return a filter that only visits the edges of graph that are instances of
the specified link attribute type.
|
Modifier and Type | Class and Description |
---|---|
static class |
BackchainTypeResourceIterator.PushbackFilter<E>
Filterator style construct that allows push back of a single visited
element.
|
Modifier and Type | Class and Description |
---|---|
class |
CacheValueFilter
Cache the
BigdataValue on the IV (create a cross linkage). |
Modifier and Type | Class and Description |
---|---|
class |
SolutionSetStatsFilter
Class may be used to collect statistics from a stream of solutions.
|
Modifier and Type | Class and Description |
---|---|
static class |
GeoSpatialServiceFactory.AcceptAllSolutionsFilter
Dummy filter asserting that a point delivered by the advancer lies into
a given rectangle.
|
static class |
GeoSpatialServiceFactory.GeoSpatialFilterBase |
static class |
GeoSpatialServiceFactory.GeoSpatialInCircleFilter
Filter asserting that a given point lies into a specified square, defined
by its lower and upper border, plus time frame.
|
Modifier and Type | Class and Description |
---|---|
class |
ContextAdvancer
Advancer for a quads index whose last key component is the "context position
(such as SPOC or SOPC).
|
class |
DistinctMultiTermAdvancer
This was cloned from the
DistinctTermAdvancer . |
class |
DistinctTermAdvancer
Advances the source
ITupleCursor through the distinct term
identifiers for some AccessPath . |
Modifier and Type | Class and Description |
---|---|
class |
ElementFilter<R>
Align the predicate's
IElementFilter constraint with
ITupleFilter so that the IElementFilter can be evaluated
close to the data by an ITupleIterator . |
class |
SameVariableConstraintTupleFilter<E>
TupleFilter class wrapping the SameVariableConstraint . |
class |
TupleObjectResolver<R>
Resolve an
ITuple to its AbstractTuple.getObject() . |
Modifier and Type | Field and Description |
---|---|
protected IFilter |
AccessPath.accessPathFilter
The filter derived from optional
IPredicate.Annotations#ACCESS_PATH_FILTER . |
protected IFilter |
AccessPath.indexLocalFilter
The filter derived from optional
IPredicate.Annotations#INDEX_LOCAL_FILTER . |
Modifier and Type | Method and Description |
---|---|
static <R> IFilter |
ElementFilter.newInstance(IElementFilter<R> test)
Helper method conditionally wraps the test.
|
static <R> IFilter |
ElementFilter.newInstance(IFilterTest test)
Helper method conditionally wraps the test.
|
Modifier and Type | Method and Description |
---|---|
protected ITupleIterator<R> |
AccessPath.rangeIterator(int capacity,
int flags,
IFilter filter) |
Modifier and Type | Method and Description |
---|---|
ResultSet |
AbstractResourceManagerTestCase.MockMetadataService.rangeIterator(long tx,
String name,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter) |
Modifier and Type | Method and Description |
---|---|
ITupleIterator |
CachingMetadataIndex.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
FIXME this is wrong.
|
ITupleIterator |
CacheOnceMetadataIndex.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter) |
ITupleIterator |
NoCacheMetadataIndexView.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
Note: Since this view is read-only this method forces the use of
ITx.READ_COMMITTED IFF the timestamp for the view is
ITx.UNISOLATED . |
ResultSet |
IDataService.rangeIterator(long tx,
String name,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
Streaming traversal of keys and/or values in a key range.
|
ResultSet |
DataService.rangeIterator(long tx,
String name,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter) |
Constructor and Description |
---|
DataService.RangeIteratorTask(ConcurrencyManager concurrencyManager,
long startTime,
String name,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter) |
Modifier and Type | Class and Description |
---|---|
class |
ZOrderIndexBigMinAdvancer
Advances the cursor to the next zOrderKey that is greater or equal than the
first point in the next region.
|
Modifier and Type | Method and Description |
---|---|
protected ResultSet |
RawDataServiceTupleIterator.getResultSet(long timestamp,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
Atomic operation caches a chunk of results from an
IDataService . |
ITupleIterator |
AbstractScaleOutClientIndexView.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
Identifies the index partition(s) that are spanned by the key range query
and maps an iterator across each index partition.
|
ITupleIterator |
ClientIndexView.rangeIterator(byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
Identifies the index partition(s) that are spanned by the key range query
and maps an iterator across each index partition.
|
Constructor and Description |
---|
DataServiceTupleIterator(IScaleOutClientIndex ndx,
IDataService dataService,
String name,
long timestamp,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter) |
PartitionedTupleIterator(IScaleOutClientIndex ndx,
long ts,
boolean isReadConsistentTx,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter)
Note: The
PartitionedTupleIterator uses a sequential scan (rather
than mapping across the index partitions in parallel) and always picks up
from the successor of the last key visited. |
RawDataServiceTupleIterator(IDataService dataService,
String name,
long timestamp,
boolean readConsistent,
byte[] fromKey,
byte[] toKey,
int capacity,
int flags,
IFilter filter) |
Modifier and Type | Class and Description |
---|---|
class |
AtomicRowFilter
Transforms an
ITupleIterator reading directly on an IIndex
backing a SparseRowStore into an ITupleIterator visiting
logical ITPS rows. |
Modifier and Type | Class and Description |
---|---|
class |
Appender
Appender
Used with Appenderator by Striterator to filter returned objects.
|
class |
Contractor
Used with a Contractorator to contract an Expanded iterator
The Contractorator will call contract on this object
|
class |
ExclusionFilter
Derived from Filter, and excludes a single object from the iteration.
|
class |
Expander
Expander
Used with Expanderator by Striterator to expand returned objects.
|
class |
Filter
Used with Filterator by Striterator to filter returned objects.
|
class |
FilterBase
Used with Filterator by Striterator to filter returned objects.
|
class |
Mapper
Mapper
Used with Mapperator by Striterator to map instance methods against member objects.
|
class |
Merger
Used with Mergerator by Striterator to merge returned objects.
|
class |
NOPFilter
A filter which is initially a NOP.
|
class |
Resolver
Resolver
Used with Resolverator by Striterator to resolve returned objects.
|
class |
Sorter
Used with Sorterator by Striterator to sort iterations.
|
class |
UniquenessFilter
UniquenessFilter
Derived from Filter, and ensures no duplication, not to be used with large
sets!
|
class |
Visitor |
Modifier and Type | Method and Description |
---|---|
IStriterator |
IStriterator.addFilter(IFilter filter)
Adds a Discriminating IFilter object
|
IStriterator |
Striterator.addFilter(IFilter filter)
creates a Filterator to apply the filter
|
FilterBase |
FilterBase.addFilter(IFilter filter)
Add a filter to the end of this filter chain.
|
Constructor and Description |
---|
Striterator(Iterator src,
List<IFilter> filters) |
Copyright © 2006–2019 SYSTAP, LLC DBA Blazegraph. All rights reserved.