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.aggregate | |
com.bigdata.bop.ap | |
com.bigdata.bop.ap.filter |
These filters are based on the striterator patterns.
|
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.join | |
com.bigdata.bop.joinGraph.rto | |
com.bigdata.bop.mutation | |
com.bigdata.bop.paths | |
com.bigdata.bop.rdf.aggregate | |
com.bigdata.bop.rdf.filter | |
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.btree.filter | |
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.internal.constraints | |
com.bigdata.rdf.lexicon | |
com.bigdata.rdf.rules | |
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.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.relation.rule |
This package includes an abstraction layer for rules.
|
com.bigdata.service.geospatial | |
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 | Interface and Description |
---|---|
interface |
BOp
An operator, such as a constant, variable, join, sort, filter, etc.
|
interface |
IBind<E>
A marker interface for an
IValueExpression which has the side-effect
of binding a value on an IVariable . |
interface |
IConstant<E>
A constant.
|
interface |
IConstraint
An interface for specifying constraints on the allowable states of an
IBindingSet . |
interface |
IPredicate<E>
An immutable constraint on the elements visited using an
IAccessPath . |
interface |
IValueExpression<E>
An expression which may be evaluated to a value.
|
interface |
IValueExpressionConstraint<X> |
interface |
IVariable<E>
A variable.
|
interface |
IVariableOrConstant<E>
Abstraction models either a constant or an unbound variable.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractAccessPathOp<E>
Interface for evaluating operations producing chunks of elements (tuples
materialized from some index of a relation).
|
class |
Bind<E>
Operator causes a variable to be bound to the result of its evaluation as a
side-effect.
|
class |
BOpBase
Abstract base class for copy-on-write
BOp s. |
class |
Constant<E>
A constant.
|
class |
CoreBaseBOp
Base class with some common methods for mutable and copy-on-write
BOp
s. |
class |
ImmutableBOp
|
class |
ModifiableBOpBase
Abstract base class for mutable
BOp s. |
class |
PipelineOp
Abstract base class for pipeline operators where the data moving along the
pipeline is chunks of
IBindingSet s. |
class |
Var<E>
A variable.
|
Modifier and Type | Interface and Description |
---|---|
interface |
IAggregate<E>
An aggregate operator, such as SUM, COUNT, MIN, MAX, etc.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregateBase<E>
Abstract base class for aggregate functions.
|
Modifier and Type | Class and Description |
---|---|
class |
Predicate<E>
A generic implementation of an immutable
IPredicate . |
class |
SampleIndex<E>
Sampling operator for the
IAccessPath implied by an
IPredicate . |
protected class |
TestPredicateAccessPath.MockPipelineOp |
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.
|
Constructor and Description |
---|
DistinctFilter.DistinctFilterImpl(IPropertySet propertySet)
DISTINCT filter based on Java heap data structures.
|
Modifier and Type | Class and Description |
---|---|
class |
ConditionalRoutingOp
An operator for conditional routing of binding sets in a pipeline.
|
class |
CopyOp
This operator copies its source to its sink(s).
|
class |
EndOp
A operator which may be used at the end of query pipelines when there is a
requirement to marshal solutions back to the query controller but no
requirement to
slice solutions. |
class |
StartOp
A version of
CopyOp which is always evaluated on the query
controller. |
class |
Tee
TEE(op):[sinkRef=X; altSinkRef=Y]
|
Modifier and Type | Interface and Description |
---|---|
interface |
BooleanValueExpression
Interface for boolean value expression BOps.
|
Modifier and Type | Class and Description |
---|---|
class |
AND
Imposes the constraint
x AND y . |
class |
Constraint<X>
Constraint wraps a BooleanValueExpression . |
class |
EQ
Imposes the constraint
x == y . |
class |
EQConstant
Imposes the constraint
var == constant . |
class |
INBinarySearch<T>
A constraint that a variable may only take on the bindings enumerated by some
set.
|
class |
INConstraint<T>
Abstract base class for "IN"
IConstraint implementations. |
class |
INHashMap<T>
A constraint that a variable may only take on the bindings enumerated by some
set.
|
class |
NE
Imposes the constraint
x != y . |
class |
NEConstant
Imposes the constraint
var != constant . |
class |
OR
Imposes the constraint
x OR y . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractSubqueryOp
Executes each of the operands as a subquery.
|
class |
HTreeNamedSubqueryOp
Evaluation of a subquery, producing a named result set.
|
class |
JVMNamedSubqueryOp
Evaluation of a subquery, producing a named result set.
|
class |
ServiceCallJoin
Vectored pipeline join of the source solution(s) with solutions from a a
SERVICE invocation.
|
class |
Steps
STEPS(ops)
|
class |
SubqueryOp
Pipelined join with subquery.
|
class |
Union
UNION()[maxParallel(default all); subqueries=ops]
|
Modifier and Type | Class and Description |
---|---|
class |
PipelineDelayOp
Operator blocks evaluation (sleeps) for the specified
PipelineDelayOp.Annotations.DELAY and then throws an PipelineDelayError . |
Modifier and Type | Class and Description |
---|---|
protected class |
TestRemoteAccessPath.MockPipelineOp |
Modifier and Type | Class and Description |
---|---|
protected class |
AbstractHashJoinUtilityTestCase.MockPipelineOp |
class |
AbstractMergeJoin
Abstract base class for MERGE JOIN implementations.
|
class |
DistinctTermScanOp<E>
This operator performs a distinct terms scan for an
IPredicate ,
binding the distinct values for the specified variable(s) from the
IAccessPath for the IPredicate . |
class |
FastRangeCountOp<E>
This operator reports the fast-range count for an as-bound
IPredicate
. |
class |
HashIndexOp
Operator builds a hash index from the source solutions.
|
class |
HashIndexOpBase
Base class for operators that use a hash index.
|
class |
HashJoinOp<E>
Abstract base class for both JVM and native memory hash join against an
IAccessPath . |
class |
HTreeHashJoinOp<E>
A hash join against an
IAccessPath based on the HTree and
suitable for very large intermediate result sets. |
class |
HTreeMergeJoin
An N-way merge join based on the
HTree . |
class |
HTreeSolutionSetHashJoinOp |
class |
JVMHashJoinOp<E>
A hash join against an
IAccessPath based on the Java collections
classes. |
class |
JVMMergeJoin
An N-way merge join on the Java heap.
|
class |
JVMSolutionSetHashJoinOp |
class |
NestedLoopJoinOp
This operator performs a nested loop join for solutions.
|
class |
PipelinedHashIndexAndSolutionSetJoinOp
Operator for pipelined hash index construction and subsequent join.
|
class |
PipelineJoin<E>
Pipelined join operator for online (selective) queries.
|
class |
SolutionSetHashJoinOp
Operator joins a solution set modeled as a hash index into the pipeline.
|
Modifier and Type | Class and Description |
---|---|
class |
JoinGraph
A join graph with annotations for estimated cardinality and other details in
support of runtime query optimization.
|
Modifier and Type | Class and Description |
---|---|
class |
InsertOp<E>
This operator writes elements constructed from binding sets and an orders
list of variables and constants on an index.
|
Modifier and Type | Class and Description |
---|---|
class |
ArbitraryLengthPathOp |
class |
ZeroLengthPathOp
Deprecated.
Does not work. Leads to cardinality problems and can be removed.
Zero Length Paths are integrated into the ALP node /
ArbitraryLengthPathOp now.
|
Modifier and Type | Class and Description |
---|---|
class |
AVERAGE
Operator computes the running sum over the presented binding sets for the
given variable.
|
class |
COUNT
Operator computes the number of non-null values over the presented binding
sets for the given variable.
|
class |
GROUP_CONCAT
Operator combines the string values over the presented binding sets for the
given variable.
|
class |
MAX
Operator reports the minimum observed value over the presented binding sets
for the given variable using SPARQL ORDER_BY semantics.
|
class |
MIN
Operator reports the minimum observed value over the presented binding sets
for the given variable using SPARQL ORDER_BY semantics.
|
class |
SAMPLE
Operator reports an arbitrary value from presented binding sets for the given
variable.
|
class |
SUM
Operator computes the running sum over the presented binding sets for the
given variable.
|
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 . |
Constructor and Description |
---|
NativeDistinctFilter.DistinctFilterImpl(IPropertySet properties)
DISTINCT
ISPO filter based on persistence capable data
structures. |
Modifier and Type | Class and Description |
---|---|
class |
ChunkedMaterializationOp
A vectored materialization operator based on pretty much the same logic as
BigdataBindingSetResolverator . |
class |
DataSetJoin
DataSetJoin(left)[var=g; graphs={graphIds}]
|
class |
InlineMaterializeOp<E>
This operator is used as part of the BigdataValue materialization step inside
the pipeline.
|
class |
MockTermResolverOp
A vectored operator that resolves variables bound to mocked terms in binding
sets through a dictionary join.
|
class |
VariableUnificationOp
Operator computing a join over two variables already bound variables in the
mapping set (for which the IV has been computed already).
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractAddRemoveStatementsOp
Abstract base class for operations which add or remove statements from the
statement indices.
|
class |
ChunkedResolutionOp
Vectored operator adds and/or resolves the RDF
Value s associated with
mock IV s. |
class |
CommitOp
Commit the operation.
|
class |
InsertDataOp
Operator to insert
ISPO s into bigdata. |
class |
InsertStatementsOp
Vectored insert operator for RDF Statements.
|
class |
ParseOp
Operator parses a RDF data source, writing bindings which represent
statements onto the output sink.
|
class |
RemoveStatementsOp
Vectored remove operator for RDF Statements.
|
Modifier and Type | Class and Description |
---|---|
class |
DropOp
Operator drops the identified variables from the solutions
|
class |
GroupByOp
Base class for operators which perform aggregation operations on binding
sets.
|
class |
HTreeDistinctBindingSetsOp
A pipelined DISTINCT operator based on the persistence capable
HTree
suitable for very large solution sets. |
class |
JVMDistinctBindingSetsOp
A pipelined DISTINCT operator based on a hash table.
|
class |
MemoryGroupByOp
An in-memory at-once generalized aggregation operator.
|
class |
MemorySortOp
An in-memory merge sort for binding sets.
|
class |
MockQuery |
class |
PipelinedAggregationOp
A pipelined aggregation operator based on an in memory hash table associating
with per-group state for each aggregate expression (it can also handle the
degenerate case where all solutions form a single implicit group).
|
class |
ProjectionOp
Operator projects only the identified variables.
|
class |
SliceOp
An operator which imposes an offset/limit on a binding set pipeline.
|
class |
SortOp
Base class for operators which sort binding sets.
|
Modifier and Type | 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 | Class and Description |
---|---|
class |
EdgeOnlyFilter<VS,ES,ST>
Filter visits only edges (filters out attribute values).
|
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 |
AndBOp
Imposes the constraint
x AND y . |
class |
BNodeBOp
The BNODE()/BNODE(Literal) function as defined in SPARQL 1.1 Query
Language for RDF.
|
class |
CoalesceBOp
Coalesce BOp The COALESCE function form returns the RDF term value of the first expression that evaluates without error.
|
class |
CompareBOp
Perform open-world value comparison operations per the SPARQL spec (the LT
operator).
|
class |
ComputedIN
"IN" and "NOT IN" operator based on testing of the enumerated value
expressions.
|
class |
ConcatBOp |
class |
ConditionalBind<E extends IV>
Operator causes a variable to be bound to the result of its evaluation as a
side-effect unless the variable is already bound and the as-bound value does
not compare as equals.
|
class |
DatatypeBOp
Return the datatype of the literal argument.
|
class |
DateBOp
A date expression involving a left IValueExpression operand.
|
class |
DigestBOp
A Digest expression involving a
IValueExpression operand. |
class |
EBVBOp
Calculates the "effective boolean value" of an IValueExpression.
|
class |
EncodeForURIBOp |
class |
FalseBOp
Always evaluates to false.
|
class |
FuncBOp
Call one of the Sesame casting functions.
|
class |
IfBOp
Conditional if BOp
|
class |
InBinaryBOp
A constraint that a variable may only take on the bindings enumerated by some
set.
|
class |
InBOp
Abstract base class for "IN"
IConstraint implementations. |
class |
InferenceBVE |
class |
InHashBOp
A constraint that a value expression which may only take on the bindings
enumerated by some set of constants.
|
class |
IriBOp
The IRI function, as defined in SPARQL 1.1 Query
Language for RDF.
|
class |
IsBNodeBOp
Imposes the constraint
isBNode(x) . |
class |
IsBoundBOp
Imposes the constraint
bound(x) for the variable x. |
class |
IsInlineBOp
Imposes the constraint
isInline(x) . |
class |
IsLiteralBOp
Imposes the constraint
isLiteral(x) . |
class |
IsMaterializedBOp
Imposes the constraint
isMaterialized(x) . |
class |
IsNumericBOp
Imposes the constraint
isLiteral(x) . |
class |
IsURIBOp
Imposes the constraint
isURI(x) . |
class |
IVValueExpression<T extends IV>
A specialized IValueExpression that evaluates to an IV.
|
class |
LangBOp
Return the language tag of the literal argument.
|
class |
LangMatchesBOp
Implements the langMatches
SPARQL operator.
|
class |
LcaseBOp
http://www.w3.org/2005/xpath-functions#lower-case
|
class |
MathBOp
A math expression involving a left and right IValueExpression operand.
|
class |
NeedsMaterializationBOp
Attempts to run a constraint prior to materialization.
|
class |
NotBOp
Imposes the constraint
!x . |
class |
NowBOp
Implements the now() operator.
|
class |
NumericBOp
A math expression involving a left and right IValueExpression operand.
|
class |
OrBOp
Imposes the constraint
x OR y . |
class |
ProjectedConstraint
This class implements 'AS' in a projection as found in both
subselects and bind, e.g.
|
class |
RandBOp |
class |
RangeBOp
Operator used to impose a key-range constraint on a variable on access path.
|
class |
RegexBOp
SPARQL REGEX operator.
|
class |
ReplaceBOp |
class |
SameTermBOp
Compare two terms for exact equality.
|
class |
SPARQLConstraint<X extends XSDBooleanIV>
BOpConstraint that wraps a
EBVBOp , which itself computes the
effective boolean value of an IValueExpression . |
class |
SparqlTypeErrorBOp
Always throws a SparqlTypeError.
|
class |
StrAfterBOp |
class |
StrBeforeBOp |
class |
StrBOp
Convert the
IV to a xsd:string . |
class |
StrcontainsBOp |
class |
StrdtBOp |
class |
StrendsBOp |
class |
StrlangBOp |
class |
StrlenBOp |
class |
StrstartsBOp |
class |
SubstrBOp
This function has an origin of ONE (1) not ZERO (0).
|
class |
TrueBOp
Always evaluates to true.
|
class |
TryBeforeMaterializationConstraint
This is useful when a solution can be filtered out before it goes through the
materialization pipeline.
|
class |
UcaseBOp |
class |
UUIDBOp
Implements the now() operator.
|
class |
XSDBooleanIVValueExpression
Base class for RDF value expression BOps that happen to evaluate to an
XSDBooleanIV . |
class |
XsdLongBOp
Convert the
IV to a xsd:long . |
class |
XsdStrBOp
Convert the
IV to a xsd:string . |
class |
XsdUnsignedLongBOp
Convert the
IV to a xsd:unsignedLong . |
Modifier and Type | Class and Description |
---|---|
class |
CacheValueFilter
Cache the
BigdataValue on the IV (create a cross linkage). |
class |
LexPredicate
A
lex(BigdataValue,IV)
predicate used for querying the LexiconRelation 's TERMS
index. |
Modifier and Type | Class and Description |
---|---|
class |
RejectAnythingSameAsItself
Rejects (x y z) iff x==z and y==owl:sameAs, where x, y, and z are variables.
|
Modifier and Type | Interface and Description |
---|---|
interface |
IBindingProducerNode
A marker interface for
IQueryNode s which are capable of producing
bindings. |
interface |
IGroupMemberNode
An interface for an
IQueryNode which may appear in an
IGroupNode . |
interface |
IGroupNode<E extends IGroupMemberNode>
A type of query node that groups a set of query nodes together.
|
interface |
IJoinNode
A marker interface for any kind of AST Node which joins stuff.
|
interface |
IQueryNode
This is the basic interface for any AST operator that appears in the query
plan.
|
interface |
IReorderableNode
Interface for things which can be re-ordered by the static join
optimizer.
|
interface |
IStatementContainer
Marker interface for things which either are statements (or statement
patterns) or contain statements (or statement pattern).
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractFromToGraphManagement
Any of the operations which has a FROM and/or TO graph.
|
class |
AbstractGraphDataUpdate
Abstract base class for the
INSERT DATA and
DELETE DATA operations. |
class |
AbstractOneGraphManagement
Any of the operations which acts on a single target graph.
|
class |
AbstractStatementContainer<E extends IStatementContainer>
Recursive container for ground
StatementPatternNode s. |
class |
AddGraph
Graph management operation inserts all data from one graph into another.
|
class |
ArbitraryLengthPathNode
A special kind of AST node that represents the SPARQL 1.1 arbitrary length
path operator.
|
class |
AssignmentNode
AST node models the assignment of a value expression to a variable
|
class |
ASTBase
Base class for the AST.
|
class |
ASTContainer
A super container for the AST.
|
class |
BindingsClause
The solutions declared by a BINDINGS clause.
|
class |
ClearGraph
The CLEAR operation removes all the triples in the specified graph(s) in the
Graph Store.
|
class |
ConstantNode
Used to represent a constant in the AST.
|
class |
ConstructNode
A template for the construction of one or more graphs based on the solutions
projected by a query.
|
class |
CopyGraph
The COPY operation is a shortcut for inserting all data from an input graph
into a destination graph.
|
class |
CreateEntailments
The CREATE ENTAILMENTS operation compute entailments in the Graph Store.
|
class |
CreateGraph
This operation creates a graph in the Graph Store (this operation is a NOP
for bigdata).
|
class |
DatasetNode
AST node models a SPARQL default graph and/or named graph data set.
|
class |
DeleteData
The DELETE DATA operation removes some triples, given inline in the request,
if the respective graphs in the Graph Store contain those:
|
class |
DeleteInsertGraph
The DELETE/INSERT operation can be used to remove or add triples from/to the
Graph Store based on bindings for a query pattern specified in a WHERE
clause:
|
class |
DisableEntailments
The DISABLE ENTAILMENTS operation disable incremental truth maintenance.
|
class |
DropEntailments
The DROP ENTAILMENTS operation removes all entailments from the Graph Store.
|
class |
DropGraph
The DROP operation removes the specified graph(s) from the Graph Store.
|
class |
DummyConstantNode
The dummy constant node is used to represent constants in the AST that do not
actually exist in the database.
|
class |
EnableEntailments
The ENABLE ENTAILMENTS operation enable incremental truth maintenance.
|
class |
ExistsNode
A special function node for modeling EXISTS.
|
class |
FilterNode
AST node models a value expression which imposes a constraint.
|
class |
FunctionNode
AST node for anything which is neither a constant nor a variable, including
math operators, string functions, etc.
|
static class |
FunctionRegistry.UnknownFunctionBOp |
class |
GraphManagement
A Graph Management operation.
|
class |
GraphPatternGroup<E extends IGroupMemberNode>
Join group or union.
|
class |
GraphUpdate
A Graph Update operation.
|
class |
GroupByNode
AST node for a GROUP BY clause.
|
class |
GroupMemberNodeBase<E extends IGroupMemberNode>
Anything which can appear in an
IGroupNode . |
class |
GroupMemberValueExpressionNodeBase |
class |
GroupNodeBase<E extends IGroupMemberNode>
Base class for AST group nodes.
|
class |
HavingNode
AST node for a HAVING clause.
|
class |
InsertData
The INSERT DATA operation adds some triples, given inline in the request,
into the Graph Store:
|
class |
JoinGroupNode
An optional or non-optional collection of query nodes that run together in
a group.
|
class |
LoadGraph
The LOAD operation reads an RDF document from a IRI and inserts its triples
into the specified graph in the Graph Store.
|
class |
MoveGraph
The MOVE operation is a shortcut for moving all data from an input graph into
a destination graph.
|
class |
NamedSubqueriesNode
A node whose children are a list of
NamedSubqueryRoot s. |
class |
NamedSubqueryInclude
An AST node which provides a reference in an
IGroupNode and indicates
that a named solution set should be joined with the solutions in the group. |
class |
NamedSubqueryRoot
A subquery with a named solution set which can be referenced from other parts
of the query.
|
class |
NotExistsNode
A special function node for modeling NOT EXISTS.
|
class |
OrderByExpr
An
IValueExpressionNode paired with a flag to indicating an ascending
or descending sort order. |
class |
OrderByNode
AST node models an ORDER BY clause.
|
class |
PathNode
AST Node used to represent a property path.
|
static class |
PathNode.PathAlternative
Used to signify an OR (UNION) of multiple possible subpaths.
|
static class |
PathNode.PathElt
A specific path element.
|
static class |
PathNode.PathNegatedPropertySet |
static class |
PathNode.PathOneInPropertySet |
static class |
PathNode.PathSequence
A sequence of paths (JOINS).
|
class |
ProjectionNode
AST node modeling projected value expressions.
|
class |
PropertyPathNode
A node in the AST representing a triple pattern with a property path.
|
class |
PropertyPathUnionNode
This node is purely to trick the ASTJoinOrderByTypeOptimizer - we need to
keep the property path stuff in the right order, even the UNIONs.
|
class |
QuadData
Recursive container for ground
StatementPatternNode s. |
class |
QuadsDataOrNamedSolutionSet
An AST node which models either
QuadData or a named solution set in
support of the INSERT clause and DELETE clause of a DeleteInsertGraph
operations. |
class |
QueryBase
Contains the projection clause, where clause, and solution modified clauses.
|
class |
QueryNodeBase
AST node base class.
|
class |
QueryNodeListBaseNode<E extends IQueryNode>
Base class for AST nodes which model an ordered list of children.
|
class |
QueryRoot
The top-level Query.
|
class |
RangeNode
It's a value expression because it does eventually evaluate to a value -
a
Range value. |
class |
SliceNode
AST node for a SLICE (offset/limit).
|
class |
SolutionModifierBase
AST node for solution modifiers (SLICE, ORDER BY, GROUP BY)
|
class |
SolutionSetStatsFilter
Class may be used to collect statistics from a stream of solutions.
|
class |
StatementPatternNode
A node in the AST representing a statement pattern.
|
class |
SubqueryBase
AST node for subqueries.
|
class |
SubqueryFunctionNodeBase
A special function node for modeling value expression nodes which are
evaluated against an inner graph expression, such as EXISTS and NOT EXISTS.
|
class |
SubqueryRoot
A SPARQL 1.1 style subquery.
|
class |
TermNode
Used to represent a variable or constant in the AST (a term in a statement
pattern for example).
|
class |
UnionNode
A special kind of group
IGroupNode that represents the sparql union
operator. |
class |
Update
A SPARQL Update operation.
|
class |
UpdateRoot
The top level container for a sequence of UPDATE operations.
|
class |
ValueExpressionListBaseNode<E extends IValueExpressionNode>
Base class for AST nodes which model an ordered list of value expressions.
|
class |
ValueExpressionNode
AST node for value expressions.
|
class |
VarNode
Used to represent a variable in the AST.
|
class |
ZeroLengthPathNode
Deprecated.
Does not work - leads to cardinality problems and can be removed.
Zero Length Paths are integrated into the ALP node /
ArbitraryLengthPathOp now.
|
Modifier and Type | Class and Description |
---|---|
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 |
ServiceNode
An extension point for external service calls which produce solution
multisets (a SPARQL
SERVICE ). |
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 . |
class |
SPOPredicate
A predicate that is a triple with one or more variables.
|
class |
SPOStarJoin
Implementation of a star join for SPOs.
|
protected static class |
TestSPORelation.P |
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 | Interface and Description |
---|---|
interface |
IStarJoin<E>
Deprecated.
This is not currently supported. It was implemented, but we did
not find improved performance for it.
|
Modifier and Type | Class and Description |
---|---|
protected static class |
AbstractRuleTestCase.P |
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 | 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 | Interface and Description |
---|---|
interface |
IFilter
Provides the hook interface that allows use by Striterators
TODO The
Striterator protocol does not support a close() method for
Filter s. |
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 |
Copyright © 2006–2019 SYSTAP, LLC DBA Blazegraph. All rights reserved.