| Package | Description | 
|---|---|
| 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.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.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.rule | 
    This package includes an abstraction layer for rules. | 
| 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  | BOpBaseAbstract base class for copy-on-write  BOps. | 
| class  | Constant<E>A constant. | 
| class  | ImmutableBOp | 
| class  | ModifiableBOpBaseAbstract base class for mutable  BOps. | 
| class  | PipelineOpAbstract base class for pipeline operators where the data moving along the
 pipeline is chunks of  IBindingSets. | 
| class  | Var<E>A variable. | 
| Modifier and Type | Method and Description | 
|---|---|
| CoreBaseBOp | CoreBaseBOp. clone()Deep copy clone semantics. | 
| 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  IAccessPathimplied by anIPredicate. | 
| protected class  | TestPredicateAccessPath.MockPipelineOp | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BOpFilterUsed to filter for objects which satisfy some criteria. | 
| class  | BOpFilterBaseBase class for operators which apply striterator patterns for access paths. | 
| class  | BOpFilterNOPA filter which does nothing. | 
| class  | BOpResolverStriterator resolver pattern. | 
| class  | BOpTupleFilter<E>
 Filter supporting  ITupleIterators. | 
| class  | DistinctFilterA DISTINCT operator based for elements in a relation. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ConditionalRoutingOpAn operator for conditional routing of binding sets in a pipeline. | 
| class  | CopyOpThis operator copies its source to its sink(s). | 
| class  | EndOpA 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  slicesolutions. | 
| class  | StartOpA version of  CopyOpwhich is always evaluated on the query
 controller. | 
| class  | TeeTEE(op):[sinkRef=X; altSinkRef=Y] | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ANDImposes the constraint  x AND y. | 
| class  | Constraint<X>Constraintwraps aBooleanValueExpression. | 
| class  | EQImposes the constraint  x == y. | 
| class  | EQConstantImposes 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"  IConstraintimplementations. | 
| class  | INHashMap<T>A constraint that a variable may only take on the bindings enumerated by some
 set. | 
| class  | NEImposes the constraint  x != y. | 
| class  | NEConstantImposes the constraint  var != constant. | 
| class  | ORImposes the constraint  x OR y. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractSubqueryOpExecutes each of the operands as a subquery. | 
| class  | HTreeNamedSubqueryOpEvaluation of a subquery, producing a named result set. | 
| class  | JVMNamedSubqueryOpEvaluation of a subquery, producing a named result set. | 
| class  | ServiceCallJoinVectored pipeline join of the source solution(s) with solutions from a a
 SERVICE invocation. | 
| class  | StepsSTEPS(ops) | 
| class  | SubqueryOpPipelined join with subquery. | 
| class  | UnionUNION()[maxParallel(default all); subqueries=ops] | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PipelineDelayOpOperator blocks evaluation (sleeps) for the specified
  PipelineDelayOp.Annotations.DELAYand then throws anPipelineDelayError. | 
| Modifier and Type | Class and Description | 
|---|---|
| protected class  | TestRemoteAccessPath.MockPipelineOp | 
| Modifier and Type | Class and Description | 
|---|---|
| protected class  | AbstractHashJoinUtilityTestCase.MockPipelineOp | 
| class  | AbstractMergeJoinAbstract 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 theIAccessPathfor theIPredicate. | 
| class  | FastRangeCountOp<E>This operator reports the fast-range count for an as-bound  IPredicate. | 
| class  | HashIndexOpOperator builds a hash index from the source solutions. | 
| class  | HashIndexOpBaseBase 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  IAccessPathbased on theHTreeand
 suitable for very large intermediate result sets. | 
| class  | HTreeMergeJoinAn N-way merge join based on the  HTree. | 
| class  | HTreeSolutionSetHashJoinOp | 
| class  | JVMHashJoinOp<E>A hash join against an  IAccessPathbased on the Java collections
 classes. | 
| class  | JVMMergeJoinAn N-way merge join on the Java heap. | 
| class  | JVMSolutionSetHashJoinOp | 
| class  | NestedLoopJoinOpThis operator performs a nested loop join for solutions. | 
| class  | PipelinedHashIndexAndSolutionSetJoinOpOperator for pipelined hash index construction and subsequent join. | 
| class  | PipelineJoin<E>Pipelined join operator for online (selective) queries. | 
| class  | SolutionSetHashJoinOpOperator joins a solution set modeled as a hash index into the pipeline. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | JoinGraphA 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  | ZeroLengthPathOpDeprecated. 
 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  | AVERAGEOperator computes the running sum over the presented binding sets for the
 given variable. | 
| class  | COUNTOperator computes the number of non-null values over the presented binding
 sets for the given variable. | 
| class  | GROUP_CONCATOperator combines the string values over the presented binding sets for the
 given variable. | 
| class  | MAXOperator reports the minimum observed value over the presented binding sets
 for the given variable using SPARQL ORDER_BY semantics. | 
| class  | MINOperator reports the minimum observed value over the presented binding sets
 for the given variable using SPARQL ORDER_BY semantics. | 
| class  | SAMPLEOperator reports an arbitrary value from presented binding sets for the given
 variable. | 
| class  | SUMOperator computes the running sum over the presented binding sets for the
 given variable. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | NativeDistinctFilterA scalable DISTINCT operator based for  SPOs. | 
| class  | StripContextFilterStrips the context information from an  SPO. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ChunkedMaterializationOpA vectored materialization operator based on pretty much the same logic as
  BigdataBindingSetResolverator. | 
| class  | DataSetJoinDataSetJoin(left)[var=g; graphs={graphIds}] | 
| class  | InlineMaterializeOp<E>This operator is used as part of the BigdataValue materialization step inside
 the pipeline. | 
| class  | MockTermResolverOpA vectored operator that resolves variables bound to mocked terms in binding
 sets through a dictionary join. | 
| class  | VariableUnificationOpOperator 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  | AbstractAddRemoveStatementsOpAbstract base class for operations which add or remove statements from the
 statement indices. | 
| class  | ChunkedResolutionOpVectored operator adds and/or resolves the RDF  Values associated with
 mockIVs. | 
| class  | CommitOpCommit the operation. | 
| class  | InsertDataOpOperator to insert  ISPOs into bigdata. | 
| class  | InsertStatementsOpVectored insert operator for RDF Statements. | 
| class  | ParseOpOperator parses a RDF data source, writing bindings which represent
 statements onto the output sink. | 
| class  | RemoveStatementsOpVectored remove operator for RDF Statements. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DropOpOperator drops the identified variables from the solutions | 
| class  | GroupByOpBase class for operators which perform aggregation operations on binding
 sets. | 
| class  | HTreeDistinctBindingSetsOpA pipelined DISTINCT operator based on the persistence capable  HTreesuitable for very large solution sets. | 
| class  | JVMDistinctBindingSetsOpA pipelined DISTINCT operator based on a hash table. | 
| class  | MemoryGroupByOpAn in-memory at-once generalized aggregation operator. | 
| class  | MemorySortOpAn in-memory merge sort for binding sets. | 
| class  | MockQuery | 
| class  | PipelinedAggregationOpA 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  | ProjectionOpOperator projects only the identified variables. | 
| class  | SliceOpAn operator which imposes an offset/limit on a binding set pipeline. | 
| class  | SortOpBase class for operators which sort binding sets. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AndBOpImposes the constraint  x AND y. | 
| class  | BNodeBOpThe BNODE()/BNODE(Literal) function as defined in SPARQL 1.1 Query
 Language for RDF. | 
| class  | CoalesceBOpCoalesce BOp The COALESCE function form returns the RDF term value of the first expression that evaluates without error. | 
| class  | CompareBOpPerform 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  | DatatypeBOpReturn the datatype of the literal argument. | 
| class  | DateBOpA date expression involving a left IValueExpression operand. | 
| class  | DigestBOpA Digest expression involving a  IValueExpressionoperand. | 
| class  | EBVBOpCalculates the "effective boolean value" of an IValueExpression. | 
| class  | EncodeForURIBOp | 
| class  | FalseBOpAlways evaluates to false. | 
| class  | FuncBOpCall one of the Sesame casting functions. | 
| class  | IfBOpConditional if BOp | 
| class  | InBinaryBOpA constraint that a variable may only take on the bindings enumerated by some
 set. | 
| class  | InBOpAbstract base class for "IN"  IConstraintimplementations. | 
| class  | InferenceBVE | 
| class  | InHashBOpA constraint that a value expression which may only take on the bindings
 enumerated by some set of constants. | 
| class  | IriBOpThe IRI function, as defined in SPARQL 1.1 Query
 Language for RDF. | 
| class  | IsBNodeBOpImposes the constraint  isBNode(x). | 
| class  | IsBoundBOpImposes the constraint  bound(x)for the variable x. | 
| class  | IsInlineBOpImposes the constraint  isInline(x). | 
| class  | IsLiteralBOpImposes the constraint  isLiteral(x). | 
| class  | IsMaterializedBOpImposes the constraint  isMaterialized(x). | 
| class  | IsNumericBOpImposes the constraint  isLiteral(x). | 
| class  | IsURIBOpImposes the constraint  isURI(x). | 
| class  | IVValueExpression<T extends IV>A specialized IValueExpression that evaluates to an IV. | 
| class  | LangBOpReturn the language tag of the literal argument. | 
| class  | LangMatchesBOpImplements the langMatches
 SPARQL operator. | 
| class  | LcaseBOphttp://www.w3.org/2005/xpath-functions#lower-case | 
| class  | MathBOpA math expression involving a left and right IValueExpression operand. | 
| class  | NeedsMaterializationBOpAttempts to run a constraint prior to materialization. | 
| class  | NotBOpImposes the constraint  !x. | 
| class  | NowBOpImplements the now() operator. | 
| class  | NumericBOpA math expression involving a left and right IValueExpression operand. | 
| class  | OrBOpImposes the constraint  x OR y. | 
| class  | ProjectedConstraintThis class implements 'AS' in a projection as found in both 
 subselects and bind, e.g. | 
| class  | RandBOp | 
| class  | RangeBOpOperator used to impose a key-range constraint on a variable on access path. | 
| class  | RegexBOpSPARQL REGEX operator. | 
| class  | ReplaceBOp | 
| class  | SameTermBOpCompare two terms for exact equality. | 
| class  | SPARQLConstraint<X extends XSDBooleanIV>BOpConstraint that wraps a  EBVBOp, which itself computes the 
 effective boolean value of anIValueExpression. | 
| class  | SparqlTypeErrorBOpAlways throws a SparqlTypeError. | 
| class  | StrAfterBOp | 
| class  | StrBeforeBOp | 
| class  | StrBOpConvert the  IVto axsd:string. | 
| class  | StrcontainsBOp | 
| class  | StrdtBOp | 
| class  | StrendsBOp | 
| class  | StrlangBOp | 
| class  | StrlenBOp | 
| class  | StrstartsBOp | 
| class  | SubstrBOpThis function has an origin of ONE (1) not ZERO (0). | 
| class  | TrueBOpAlways evaluates to true. | 
| class  | TryBeforeMaterializationConstraintThis is useful when a solution can be filtered out before it goes through the
 materialization pipeline. | 
| class  | UcaseBOp | 
| class  | UUIDBOpImplements the now() operator. | 
| class  | XSDBooleanIVValueExpressionBase class for RDF value expression BOps that happen to evaluate to an
  XSDBooleanIV. | 
| class  | XsdLongBOpConvert the  IVto axsd:long. | 
| class  | XsdStrBOpConvert the  IVto axsd:string. | 
| class  | XsdUnsignedLongBOpConvert the  IVto axsd:unsignedLong. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CacheValueFilterCache the  BigdataValueon theIV(create a cross linkage). | 
| class  | LexPredicateA  
 lex(BigdataValue,IV)
 predicate used for querying theLexiconRelation's TERMS
 index. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RejectAnythingSameAsItselfRejects (x y z) iff x==z and y==owl:sameAs, where x, y, and z are variables. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractFromToGraphManagementAny of the operations which has a FROM and/or TO graph. | 
| class  | AbstractGraphDataUpdateAbstract base class for the  INSERT DATAandDELETE DATAoperations. | 
| class  | AbstractOneGraphManagementAny of the operations which acts on a single target graph. | 
| class  | AbstractStatementContainer<E extends IStatementContainer>Recursive container for ground  StatementPatternNodes. | 
| class  | AddGraphGraph management operation inserts all data from one graph into another. | 
| class  | ArbitraryLengthPathNodeA special kind of AST node that represents the SPARQL 1.1 arbitrary length
 path operator. | 
| class  | AssignmentNodeAST node models the assignment of a value expression to a variable | 
| class  | ASTBaseBase class for the AST. | 
| class  | ASTContainerA super container for the AST. | 
| class  | BindingsClauseThe solutions declared by a BINDINGS clause. | 
| class  | ClearGraphThe CLEAR operation removes all the triples in the specified graph(s) in the
 Graph Store. | 
| class  | ConstantNodeUsed to represent a constant in the AST. | 
| class  | ConstructNodeA template for the construction of one or more graphs based on the solutions
 projected by a query. | 
| class  | CopyGraphThe COPY operation is a shortcut for inserting all data from an input graph
 into a destination graph. | 
| class  | CreateEntailmentsThe CREATE ENTAILMENTS operation compute entailments in the Graph Store. | 
| class  | CreateGraphThis operation creates a graph in the Graph Store (this operation is a NOP
 for bigdata). | 
| class  | DatasetNodeAST node models a SPARQL default graph and/or named graph data set. | 
| class  | DeleteDataThe DELETE DATA operation removes some triples, given inline in the request,
 if the respective graphs in the Graph Store contain those: | 
| class  | DeleteInsertGraphThe 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  | DisableEntailmentsThe DISABLE ENTAILMENTS operation disable incremental truth maintenance. | 
| class  | DropEntailmentsThe DROP ENTAILMENTS operation removes all entailments from the Graph Store. | 
| class  | DropGraphThe DROP operation removes the specified graph(s) from the Graph Store. | 
| class  | DummyConstantNodeThe dummy constant node is used to represent constants in the AST that do not
 actually exist in the database. | 
| class  | EnableEntailmentsThe ENABLE ENTAILMENTS operation enable incremental truth maintenance. | 
| class  | ExistsNodeA special function node for modeling EXISTS. | 
| class  | FilterNodeAST node models a value expression which imposes a constraint. | 
| class  | FunctionNodeAST node for anything which is neither a constant nor a variable, including
 math operators, string functions, etc. | 
| static class  | FunctionRegistry.UnknownFunctionBOp | 
| class  | GraphManagementA Graph Management operation. | 
| class  | GraphPatternGroup<E extends IGroupMemberNode>Join group or union. | 
| class  | GraphUpdateA Graph Update operation. | 
| class  | GroupByNodeAST 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  | HavingNodeAST node for a HAVING clause. | 
| class  | InsertDataThe INSERT DATA operation adds some triples, given inline in the request,
 into the Graph Store: | 
| class  | JoinGroupNodeAn optional or non-optional collection of query nodes that run together in
 a group. | 
| class  | LoadGraphThe LOAD operation reads an RDF document from a IRI and inserts its triples
 into the specified graph in the Graph Store. | 
| class  | MoveGraphThe MOVE operation is a shortcut for moving all data from an input graph into
 a destination graph. | 
| class  | NamedSubqueriesNodeA node whose children are a list of  NamedSubqueryRoots. | 
| class  | NamedSubqueryIncludeAn AST node which provides a reference in an  IGroupNodeand indicates
 that a named solution set should be joined with the solutions in the group. | 
| class  | NamedSubqueryRootA subquery with a named solution set which can be referenced from other parts
 of the query. | 
| class  | NotExistsNodeA special function node for modeling NOT EXISTS. | 
| class  | OrderByExprAn  IValueExpressionNodepaired with a flag to indicating an ascending
 or descending sort order. | 
| class  | OrderByNodeAST node models an ORDER BY clause. | 
| class  | PathNodeAST Node used to represent a property path. | 
| static class  | PathNode.PathAlternativeUsed to signify an OR (UNION) of multiple possible subpaths. | 
| static class  | PathNode.PathEltA specific path element. | 
| static class  | PathNode.PathNegatedPropertySet | 
| static class  | PathNode.PathOneInPropertySet | 
| static class  | PathNode.PathSequenceA sequence of paths (JOINS). | 
| class  | ProjectionNodeAST node modeling projected value expressions. | 
| class  | PropertyPathNodeA node in the AST representing a triple pattern with a property path. | 
| class  | PropertyPathUnionNodeThis node is purely to trick the ASTJoinOrderByTypeOptimizer - we need to
 keep the property path stuff in the right order, even the UNIONs. | 
| class  | QuadDataRecursive container for ground  StatementPatternNodes. | 
| class  | QuadsDataOrNamedSolutionSetAn AST node which models either  QuadDataor a named solution set in
 support of the INSERT clause and DELETE clause of aDeleteInsertGraphoperations. | 
| class  | QueryBaseContains the projection clause, where clause, and solution modified clauses. | 
| class  | QueryNodeBaseAST node base class. | 
| class  | QueryNodeListBaseNode<E extends IQueryNode>Base class for AST nodes which model an ordered list of children. | 
| class  | QueryRootThe top-level Query. | 
| class  | RangeNodeIt's a value expression because it does eventually evaluate to a value -
 a  Rangevalue. | 
| class  | SliceNodeAST node for a SLICE (offset/limit). | 
| class  | SolutionModifierBaseAST node for solution modifiers (SLICE, ORDER BY, GROUP BY) | 
| class  | StatementPatternNodeA node in the AST representing a statement pattern. | 
| class  | SubqueryBaseAST node for subqueries. | 
| class  | SubqueryFunctionNodeBaseA special function node for modeling value expression nodes which are
 evaluated against an inner graph expression, such as EXISTS and NOT EXISTS. | 
| class  | SubqueryRootA SPARQL 1.1 style subquery. | 
| class  | TermNodeUsed to represent a variable or constant in the AST (a term in a statement
 pattern for example). | 
| class  | UnionNodeA special kind of group  IGroupNodethat represents the sparql union
 operator. | 
| class  | UpdateA SPARQL Update operation. | 
| class  | UpdateRootThe 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  | ValueExpressionNodeAST node for value expressions. | 
| class  | VarNodeUsed to represent a variable in the AST. | 
| class  | ZeroLengthPathNodeDeprecated. 
 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  | ServiceNodeAn extension point for external service calls which produce solution
 multisets (a SPARQL  SERVICE). | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SPOPredicateA predicate that is a triple with one or more variables. | 
| class  | SPOStarJoinImplementation of a star join for SPOs. | 
| protected static class  | TestSPORelation.P | 
| Modifier and Type | Class and Description | 
|---|---|
| protected static class  | AbstractRuleTestCase.P | 
Copyright © 2006–2019 SYSTAP, LLC DBA Blazegraph. All rights reserved.