Uses of Interface
org.eclipse.rdf4j.common.iteration.CloseableIteration
- 
- 
Uses of CloseableIteration in org.eclipse.rdf4j.common.concurrent.locksClasses in org.eclipse.rdf4j.common.concurrent.locks that implement CloseableIteration Modifier and Type Class Description classLockingIteration<E>Deprecated.Methods in org.eclipse.rdf4j.common.concurrent.locks that return CloseableIteration Modifier and Type Method Description static <T,R extends Exception>
 CloseableIteration<T>LockingIteration. getInstance(Lock lock, CloseableIteration<T> iter)Deprecated.Methods in org.eclipse.rdf4j.common.concurrent.locks with parameters of type CloseableIteration Modifier and Type Method Description static <T,R extends Exception>
 CloseableIteration<T>LockingIteration. getInstance(Lock lock, CloseableIteration<T> iter)Deprecated.Constructors in org.eclipse.rdf4j.common.concurrent.locks with parameters of type CloseableIteration Constructor Description LockingIteration(Lock lock, CloseableIteration<? extends E> iter)Deprecated, for removal: This API element is subject to removal in a future version.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.common.concurrent.locks.diagnosticsClasses in org.eclipse.rdf4j.common.concurrent.locks.diagnostics that implement CloseableIteration Modifier and Type Class Description classCleanerGraphQueryResultclassCleanerTupleQueryResult
- 
Uses of CloseableIteration in org.eclipse.rdf4j.common.iterationClasses in org.eclipse.rdf4j.common.iteration that implement CloseableIteration Modifier and Type Class Description classAbstractCloseableIteration<E>Deprecated.classCloseableIteratorIteration<E>Deprecated.classConvertingIteration<S,T>Deprecated.classDelayedIteration<E>Deprecated.classDistinctIteration<E>Deprecated.classDualUnionIteration<E>Deprecated.classEmptyIteration<E>Deprecated.classExceptionConvertingIteration<E,X extends RuntimeException>Deprecated.classFilterIteration<E>Deprecated.classIntersectIteration<E>Deprecated.classIterationWrapper<E>Deprecated.classIteratorIteration<E>Deprecated.classLimitIteration<E>Deprecated.classLookAheadIteration<E>Deprecated.classMinusIteration<E>Deprecated.classOffsetIteration<E>Deprecated.classQueueIteration<E,T extends RuntimeException>Deprecated.classReducedIteration<E>Deprecated.classSilentIteration<T>Deprecated.classSingletonIteration<E>Deprecated.classTimeLimitIteration<E>Deprecated.classUnionIteration<E>Deprecated.Fields in org.eclipse.rdf4j.common.iteration declared as CloseableIteration Modifier and Type Field Description protected CloseableIteration<? extends E>IntersectIteration. arg2Deprecated.protected CloseableIteration<? extends E>IterationWrapper. wrappedIterDeprecated.This will be changed to private, possibly with an accessor in future.Methods in org.eclipse.rdf4j.common.iteration that return CloseableIteration Modifier and Type Method Description protected abstract CloseableIteration<? extends E>DelayedIteration. createIteration()Deprecated.Creates the iteration that should be iterated over.static <E,X extends Exception>
 CloseableIteration<E>DualUnionIteration. getInstance(CloseableIteration<E> leftIteration, CloseableIteration<E> rightIteration)Deprecated.static <E,X extends Exception>
 CloseableIteration<? extends E>DualUnionIteration. getWildcardInstance(CloseableIteration<? extends E> leftIteration, CloseableIteration<? extends E> rightIteration)Deprecated.Methods in org.eclipse.rdf4j.common.iteration with parameters of type CloseableIteration Modifier and Type Method Description static <E,X extends Exception,C extends Collection<E>>
 CIterations. addAll(CloseableIteration<? extends E> iter, C collection)Deprecated.Adds all elements from the suppliedCloseableIterationto the specified collection then closes theCloseableIteration.Set<E>IntersectIteration. addSecondSet(CloseableIteration<? extends E> arg2, Set<E> set)Deprecated.static <E,X extends Exception>
 List<E>Iterations. asList(CloseableIteration<? extends E> iter)Deprecated.Get a List containing all elements obtained from the specified iteration.static <E,X extends Exception>
 Set<E>Iterations. asSet(CloseableIteration<? extends E> iter)Deprecated.Get a Set containing all elements obtained from the specified iteration.static <E,X extends Exception>
 Set<E>Iterations. asSet(CloseableIteration<? extends E> iteration, Supplier<Set<E>> setMaker)Deprecated.Get a Set containing all elements obtained from the specified iteration.static <E,X extends Exception>
 CloseableIteration<E>DualUnionIteration. getInstance(CloseableIteration<E> leftIteration, CloseableIteration<E> rightIteration)Deprecated.static <E,X extends Exception>
 CloseableIteration<? extends E>DualUnionIteration. getWildcardInstance(CloseableIteration<? extends E> leftIteration, CloseableIteration<? extends E> rightIteration)Deprecated.static <T> Stream<T>Iterations. stream(CloseableIteration<T> iteration)Deprecated.Get a sequentialStreamwith the suppliedCloseableIterationas its source.static <X extends Exception>
 StringIterations. toString(CloseableIteration<?> iteration, String separator)Deprecated.Converts aCloseableIterationto a string by concatenating all the string representations of objects in the iteration, divided by a separator.static <X extends Exception>
 voidIterations. toString(CloseableIteration<?> iteration, String separator, StringBuilder sb)Deprecated.Converts aCloseableIterationto a string by concatenating all the string representations of objects in the iteration, divided by a separator.Constructors in org.eclipse.rdf4j.common.iteration with parameters of type CloseableIteration Constructor Description ConvertingIteration(CloseableIteration<? extends S> iter)Deprecated.Creates a new ConvertingIteration that operates on the supplied source type iteration.DistinctIteration(CloseableIteration<? extends E> iter)Deprecated.Creates a new DistinctIterator.DistinctIteration(CloseableIteration<? extends E> iter, Supplier<Set<E>> setMaker)Deprecated.ExceptionConvertingIteration(CloseableIteration<? extends E> iter)Deprecated.Creates a new ExceptionConvertingIteration that operates on the supplied iteration.FilterIteration(CloseableIteration<? extends E> iter)Deprecated.IntersectIteration(CloseableIteration<? extends E> arg1, CloseableIteration<? extends E> arg2)Deprecated.Creates a new IntersectIteration that returns the intersection of the results of two Iterations.IntersectIteration(CloseableIteration<? extends E> arg1, CloseableIteration<? extends E> arg2, boolean distinct)Deprecated.Creates a new IntersectIteration that returns the intersection of the results of two Iterations.IntersectIteration(CloseableIteration<? extends E> arg1, CloseableIteration<? extends E> arg2, boolean distinct, Supplier<Set<E>> setMaker)Deprecated.Creates a new IntersectIteration that returns the intersection of the results of two Iterations.IntersectIteration(CloseableIteration<? extends E> arg1, CloseableIteration<? extends E> arg2, Supplier<Set<E>> setMaker)Deprecated.IterationSpliterator(CloseableIteration<T> iteration)Deprecated.Creates aSpliteratorimplementation that wraps the suppliedCloseableIteration.IterationWrapper(CloseableIteration<? extends E> iter)Deprecated.Creates a new IterationWrapper that operates on the supplied Iteration.LimitIteration(CloseableIteration<? extends E> iter, long limit)Deprecated.Creates a new LimitIteration.MinusIteration(CloseableIteration<? extends E> leftArg, CloseableIteration<? extends E> rightArg)Deprecated.Creates a new MinusIteration that returns the results of the left argument minus the results of the right argument.MinusIteration(CloseableIteration<? extends E> leftArg, CloseableIteration<? extends E> rightArg, boolean distinct)Deprecated.Creates a new MinusIteration that returns the results of the left argument minus the results of the right argument.MinusIteration(CloseableIteration<? extends E> leftArg, CloseableIteration<? extends E> rightArg, boolean distinct, Supplier<Set<E>> setMaker)Deprecated.Creates a new MinusIteration that returns the results of the left argument minus the results of the right argument.OffsetIteration(CloseableIteration<? extends E> iter, long offset)Deprecated.Creates a new OffsetIteration.ReducedIteration(CloseableIteration<? extends E> delegate)Deprecated.SilentIteration(CloseableIteration<T> iter)Deprecated.TimeLimitIteration(CloseableIteration<? extends E> iter, long timeLimit)Deprecated.UnionIteration(CloseableIteration<? extends E>... args)Deprecated.Creates a new UnionIteration that returns the bag union of the results of a number of Iterations.Constructor parameters in org.eclipse.rdf4j.common.iteration with type arguments of type CloseableIteration Constructor Description UnionIteration(Iterable<? extends CloseableIteration<? extends E>> args)Deprecated.Creates a new UnionIteration that returns the bag union of the results of a number of Iterations.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.common.iteratorConstructors in org.eclipse.rdf4j.common.iterator with parameters of type CloseableIteration Constructor Description CloseableIterationIterator(CloseableIteration<? extends E> iteration)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.federatedMethods in org.eclipse.rdf4j.federated that return CloseableIteration Modifier and Type Method Description protected CloseableIteration<? extends BindingSet>FedXConnection. evaluateInternal(TupleExpr query, Dataset dataset, BindingSet bindings, boolean includeInferred)protected CloseableIteration<? extends Resource>FedXConnection. getContextIDsInternal()protected CloseableIteration<? extends Namespace>FedXConnection. getNamespacesInternal()protected CloseableIteration<? extends Statement>FedXConnection. getStatementsInternal(Resource subj, IRI pred, Value obj, boolean includeInferred, Resource... contexts)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.federated.algebraMethods in org.eclipse.rdf4j.federated.algebra that return CloseableIteration Modifier and Type Method Description CloseableIteration<BindingSet>CheckStatementPattern. evaluate(BindingSet bindings)CloseableIteration<BindingSet>ExclusiveGroup. evaluate(BindingSet bindings)CloseableIteration<BindingSet>ExclusiveStatement. evaluate(BindingSet bindings)CloseableIteration<BindingSet>StatementSourcePattern. evaluate(BindingSet bindings)CloseableIteration<BindingSet>StatementTupleExpr. evaluate(BindingSet bindings)Evaluate this expression using the provided bindingsprotected CloseableIteration<BindingSet>StatementSourcePattern. handleStatementSourcePatternCheck(BindingSet bindings)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.federated.cacheMethods in org.eclipse.rdf4j.federated.cache that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends Statement>EndpointEntry. getStatements()
- 
Uses of CloseableIteration in org.eclipse.rdf4j.federated.evaluationFields in org.eclipse.rdf4j.federated.evaluation declared as CloseableIteration Modifier and Type Field Description protected CloseableIteration<T>TripleSourceBase.ResultHolder. resultMethods in org.eclipse.rdf4j.federated.evaluation that return CloseableIteration Modifier and Type Method Description CloseableIteration<BindingSet>FederationEvalStrategy. evaluate(DescribeOperator operator, BindingSet bindings)CloseableIteration<BindingSet>FederationEvalStrategy. evaluate(TupleExpr expr, BindingSet bindings)Deprecated, for removal: This API element is subject to removal in a future version.protected CloseableIteration<BindingSet>FederationEvalStrategy. evaluateAtStatementSources(Object preparedQuery, List<StatementSource> statementSources, QueryInfo queryInfo)protected CloseableIteration<BindingSet>FederationEvalStrategy. evaluateAtStatementSources(String preparedQuery, List<StatementSource> statementSources, QueryInfo queryInfo)protected CloseableIteration<BindingSet>FederationEvalStrategy. evaluateAtStatementSources(TupleExpr preparedQuery, List<StatementSource> statementSources, QueryInfo queryInfo)abstract CloseableIteration<BindingSet>FederationEvalStrategy. evaluateBoundJoinStatementPattern(StatementTupleExpr stmt, List<BindingSet> bindings)Evaluate a bound join at the relevant endpoint, i.e.CloseableIteration<BindingSet>SailFederationEvalStrategy. evaluateBoundJoinStatementPattern(StatementTupleExpr stmt, List<BindingSet> bindings)CloseableIteration<BindingSet>SparqlFederationEvalStrategy. evaluateBoundJoinStatementPattern(StatementTupleExpr stmt, List<BindingSet> bindings)protected CloseableIteration<BindingSet>SparqlFederationEvalStrategy. evaluateBoundJoinStatementPattern_UNION(StatementTupleExpr stmt, List<BindingSet> bindings)Deprecated.abstract CloseableIteration<BindingSet>FederationEvalStrategy. evaluateExclusiveGroup(ExclusiveGroup group, BindingSet bindings)CloseableIteration<BindingSet>SailFederationEvalStrategy. evaluateExclusiveGroup(ExclusiveGroup group, BindingSet bindings)CloseableIteration<BindingSet>SparqlFederationEvalStrategy. evaluateExclusiveGroup(ExclusiveGroup group, BindingSet bindings)protected CloseableIteration<BindingSet>FederationEvalStrategy. evaluateExclusiveTupleExpr(ExclusiveTupleExpr expr, BindingSet bindings)Evaluate anExclusiveTupleExpr.abstract CloseableIteration<BindingSet>FederationEvalStrategy. evaluateGroupedCheck(CheckStatementPattern stmt, List<BindingSet> bindings)Perform a grouped check at the relevant endpoints, i.e.CloseableIteration<BindingSet>SailFederationEvalStrategy. evaluateGroupedCheck(CheckStatementPattern stmt, List<BindingSet> bindings)CloseableIteration<BindingSet>SparqlFederationEvalStrategy. evaluateGroupedCheck(CheckStatementPattern stmt, List<BindingSet> bindings)protected CloseableIteration<BindingSet>FederationEvalStrategy. evaluateLeftJoin(FedXLeftJoin leftJoin, BindingSet bindings)Evaluate aFedXLeftJoin(i.e.CloseableIteration<BindingSet>FederationEvalStrategy. evaluateNaryUnion(NUnion union, BindingSet bindings)CloseableIteration<BindingSet>FederationEvalStrategy. evaluateNJoin(NJoin join, BindingSet bindings)CloseableIteration<BindingSet>FederationEvalStrategy. evaluateService(FedXService service, List<BindingSet> bindings)Evaluate a SERVICE using vectored evaluation, taking the provided bindings as input.CloseableIteration<BindingSet>FederationEvalStrategy. evaluateService(FedXService service, BindingSet bindings)CloseableIteration<BindingSet>FederationEvalStrategy. evaluateSingleSourceQuery(SingleSourceQuery query, BindingSet bindings)protected abstract CloseableIteration<BindingSet>FederationEvalStrategy. executeJoin(ControlledWorkerScheduler<BindingSet> joinScheduler, CloseableIteration<BindingSet> leftIter, TupleExpr rightArg, Set<String> joinVariables, BindingSet bindings, QueryInfo queryInfo)Execute the join in a separate thread using some join executor.CloseableIteration<BindingSet>SailFederationEvalStrategy. executeJoin(ControlledWorkerScheduler<BindingSet> joinScheduler, CloseableIteration<BindingSet> leftIter, TupleExpr rightArg, Set<String> joinVars, BindingSet bindings, QueryInfo queryInfo)CloseableIteration<BindingSet>SparqlFederationEvalStrategy. executeJoin(ControlledWorkerScheduler<BindingSet> joinScheduler, CloseableIteration<BindingSet> leftIter, TupleExpr rightArg, Set<String> joinVars, BindingSet bindings, QueryInfo queryInfo)CloseableIteration<T>TripleSourceBase.ResultHolder. get()CloseableIteration<Statement>FederationEvalStrategy. getStatements(QueryInfo queryInfo, Resource subj, IRI pred, Value obj, Resource... contexts)Retrieve the statements matching the provided subject, predicate and object value from the federation members.CloseableIteration<Statement>SailTripleSource. getStatements(Resource subj, IRI pred, Value obj, QueryInfo queryInfo, Resource... contexts)CloseableIteration<BindingSet>SailTripleSource. getStatements(StatementPattern stmt, BindingSet bindings, FilterValueExpr filterExpr, QueryInfo queryInfo)CloseableIteration<BindingSet>SailTripleSource. getStatements(TupleExpr preparedQuery, BindingSet bindings, FilterValueExpr filterExpr, QueryInfo queryInfo)CloseableIteration<Statement>SparqlTripleSource. getStatements(Resource subj, IRI pred, Value obj, QueryInfo queryInfo, Resource... contexts)CloseableIteration<BindingSet>SparqlTripleSource. getStatements(StatementPattern stmt, BindingSet bindings, FilterValueExpr filterExpr, QueryInfo queryInfo)CloseableIteration<BindingSet>SparqlTripleSource. getStatements(TupleExpr preparedQuery, BindingSet bindings, FilterValueExpr filterExpr, QueryInfo queryInfo)CloseableIteration<BindingSet>TripleSource. getStatements(String preparedQuery, BindingSet bindings, FilterValueExpr filterExpr, QueryInfo queryInfo)Evaluate the prepared query (SPARQL query as String) on the provided endpoint.CloseableIteration<BindingSet>TripleSource. getStatements(String preparedQuery, BindingSet queryBindings, QueryType queryType, QueryInfo queryInfo)Evaluate a given SPARQL query of the provided query type at the given source.CloseableIteration<Statement>TripleSource. getStatements(Resource subj, IRI pred, Value obj, QueryInfo queryInfo, Resource... contexts)Return the statements matching the given pattern as aStatementiteration.CloseableIteration<BindingSet>TripleSource. getStatements(StatementPattern stmt, BindingSet bindings, FilterValueExpr filterExpr, QueryInfo queryInfo)Evaluate the query expression on the provided endpoint.CloseableIteration<BindingSet>TripleSource. getStatements(TupleExpr preparedQuery, BindingSet bindings, FilterValueExpr filterExpr, QueryInfo queryInfo)Evaluate the prepared query in its internal representation on the provided endpoint.CloseableIteration<BindingSet>TripleSourceBase. getStatements(String preparedQuery, BindingSet bindings, FilterValueExpr filterExpr, QueryInfo queryInfo)CloseableIteration<BindingSet>TripleSourceBase. getStatements(String preparedQuery, BindingSet queryBindings, QueryType queryType, QueryInfo queryInfo)protected <T> CloseableIteration<T>TripleSourceBase. withConnection(TripleSourceBase.ConnectionOperation<T> operation)Convenience method to perform an operation on aRepositoryConnection.Methods in org.eclipse.rdf4j.federated.evaluation with parameters of type CloseableIteration Modifier and Type Method Description protected abstract CloseableIteration<BindingSet>FederationEvalStrategy. executeJoin(ControlledWorkerScheduler<BindingSet> joinScheduler, CloseableIteration<BindingSet> leftIter, TupleExpr rightArg, Set<String> joinVariables, BindingSet bindings, QueryInfo queryInfo)Execute the join in a separate thread using some join executor.CloseableIteration<BindingSet>SailFederationEvalStrategy. executeJoin(ControlledWorkerScheduler<BindingSet> joinScheduler, CloseableIteration<BindingSet> leftIter, TupleExpr rightArg, Set<String> joinVars, BindingSet bindings, QueryInfo queryInfo)CloseableIteration<BindingSet>SparqlFederationEvalStrategy. executeJoin(ControlledWorkerScheduler<BindingSet> joinScheduler, CloseableIteration<BindingSet> leftIter, TupleExpr rightArg, Set<String> joinVars, BindingSet bindings, QueryInfo queryInfo)voidTripleSourceBase.ResultHolder. set(CloseableIteration<T> result)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.federated.evaluation.concurrentClasses in org.eclipse.rdf4j.federated.evaluation.concurrent that implement CloseableIteration Modifier and Type Class Description classFedXQueueCursor<T>Specialized variants ofQueueCursorwhich avoids converting any exception if it is already of typeQueryEvaluationException.classParallelExecutorBase<T>Base class for common parallel executors such asJoinExecutorBaseandUnionExecutorBase.classParallelServiceExecutorParallel executor forFedXServicenodes, which wrap SERVICE expressions.Fields in org.eclipse.rdf4j.federated.evaluation.concurrent declared as CloseableIteration Modifier and Type Field Description protected CloseableIteration<T>ParallelExecutorBase. rightIterprotected CloseableIteration<BindingSet>ParallelServiceExecutor. rightIterMethods in org.eclipse.rdf4j.federated.evaluation.concurrent that return CloseableIteration Modifier and Type Method Description CloseableIteration<T>ParallelTask. performTask()CloseableIteration<T>ParallelTaskBase. performTask()protected abstract CloseableIteration<T>ParallelTaskBase. performTaskInternal()Methods in org.eclipse.rdf4j.federated.evaluation.concurrent with parameters of type CloseableIteration Modifier and Type Method Description voidParallelExecutor. addResult(CloseableIteration<T> res)Handle the result appropriately, e.g.voidParallelExecutorBase. addResult(CloseableIteration<T> res)voidParallelServiceExecutor. addResult(CloseableIteration<BindingSet> res)voidControlledWorkerScheduler. handleResult(CloseableIteration<T> res)voidScheduler. handleResult(CloseableIteration<T> res)Callback to handle the result.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.federated.evaluation.iteratorClasses in org.eclipse.rdf4j.federated.evaluation.iterator that implement CloseableIteration Modifier and Type Class Description classBoundJoinConversionIterationDeprecated.classBoundJoinVALUESConversionIterationDeprecated.classCloseDependentConnectionIteration<T>A wrapping iteration that attempts to close the dependentRepositoryConnectionafter consumption.classConsumingIterationA specializedCloseableIterationthat consumes part (or the entire input iteration if it fits into the buffer) and keeps data for further processing in memory.classFederatedDescribeIterationSpecializedDescribeIterationfor evaluation of DESCRIBE queries in the federation.classFilteringInsertBindingsIterationDeprecated.classFilteringIterationDeprecated.classGraphToBindingSetConversionIterationConverts graph results into a binding set iterationclassGroupedCheckConversionIterationDeprecated.classIndependentJoingroupBindingsIterationInserts original bindings into the result.classIndependentJoingroupBindingsIteration2Inserts original bindings into the result.classIndependentJoingroupBindingsIteration3Inserts original bindings into the result.classInsertBindingsIterationDeprecated.classLazyMutableClosableIterationA specializedCloseableIterationthat allows repetitive iterations after resetting the cursor usingLazyMutableClosableIteration.resetCursor().classPrintingIterationPrint the bindings of the inner iteration to stdout, however maintain a copy, which is accessible through this iteration.classQueryResultIterationAn iteration which wraps the final result and in case of exceptions aborts query evaluation for the corresponding query in fedx (potentially subqueries are still running, and jobs are scheduled).classSingleBindingSetIterationRepresents an iteration that contains only a single binding set.classStatementConversionIterationConverts Statement iteration (i.e.classStopRemainingExecutionsOnCloseIterationA wrapping iteration that attempts to close all running scheduledFutures for the given query evaluation.Fields in org.eclipse.rdf4j.federated.evaluation.iterator declared as CloseableIteration Modifier and Type Field Description protected CloseableIteration<T>CloseDependentConnectionIteration. innerprotected CloseableIteration<BindingSet>LazyMutableClosableIteration. innerprotected CloseableIteration<BindingSet>PrintingIteration. innerprotected CloseableIteration<BindingSet>QueryResultIteration. innerprotected CloseableIteration<? extends BindingSet>StopRemainingExecutionsOnCloseIteration. innerprotected CloseableIteration<BindingSet>IndependentJoingroupBindingsIteration. iterprotected CloseableIteration<BindingSet>IndependentJoingroupBindingsIteration2. iterprotected CloseableIteration<BindingSet>IndependentJoingroupBindingsIteration3. iterMethods in org.eclipse.rdf4j.federated.evaluation.iterator that return CloseableIteration Modifier and Type Method Description protected CloseableIteration<BindingSet>FederatedDescribeIteration. createNextIteration(Value subject, Value object)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.federated.evaluation.joinClasses in org.eclipse.rdf4j.federated.evaluation.join that implement CloseableIteration Modifier and Type Class Description classControlledWorkerBoundJoinExecute the nested loop join in an asynchronous fashion, using grouped requests, i.e.classControlledWorkerJoinExecute the nested loop join in an asynchronous fashion, i.e.classControlledWorkerLeftJoinExecute the nested loop join in an asynchronous fashion, i.e.classHashJoinOperator for a hash join of tuple expressions.classJoinExecutorBase<T>Base class for any join parallel join executor.classSynchronousBoundJoinExecute the nested loop join in a synchronous fashion, using grouped requests, i.e.classSynchronousJoinExecute the nested loop join in a synchronous fashion, i.e.Fields in org.eclipse.rdf4j.federated.evaluation.join declared as CloseableIteration Modifier and Type Field Description protected CloseableIteration<T>JoinExecutorBase. leftIterMethods in org.eclipse.rdf4j.federated.evaluation.join that return CloseableIteration Modifier and Type Method Description protected CloseableIteration<BindingSet>ParallelBoundJoinTask. performTaskInternal()protected CloseableIteration<BindingSet>ParallelCheckJoinTask. performTaskInternal()protected CloseableIteration<BindingSet>ParallelJoinTask. performTaskInternal()protected CloseableIteration<BindingSet>ParallelLeftJoinTask. performTaskInternal()protected CloseableIteration<BindingSet>ParallelServiceJoinTask. performTaskInternal()
- 
Uses of CloseableIteration in org.eclipse.rdf4j.federated.evaluation.unionClasses in org.eclipse.rdf4j.federated.evaluation.union that implement CloseableIteration Modifier and Type Class Description classControlledWorkerUnion<T>Execution of union tasks withControlledWorkerScheduler.classSynchronousWorkerUnion<T>Synchronous execution of union tasks, i.e.classUnionExecutorBase<T>Base class for any parallel union executor.classWorkerUnionBase<T>Base class for worker unions providing convenience functions to add tasks.Methods in org.eclipse.rdf4j.federated.evaluation.union that return CloseableIteration Modifier and Type Method Description protected CloseableIteration<Statement>ParallelGetStatementsTask. performTaskInternal()protected CloseableIteration<BindingSet>ParallelPreparedAlgebraUnionTask. performTaskInternal()protected CloseableIteration<BindingSet>ParallelPreparedUnionTask. performTaskInternal()protected CloseableIteration<BindingSet>ParallelUnionOperatorTask. performTaskInternal()protected CloseableIteration<BindingSet>ParallelUnionTask. performTaskInternal()
- 
Uses of CloseableIteration in org.eclipse.rdf4j.federated.optimizerMethods in org.eclipse.rdf4j.federated.optimizer that return CloseableIteration Modifier and Type Method Description protected CloseableIteration<BindingSet>SourceSelection.ParallelCheckTask. performTaskInternal()Methods in org.eclipse.rdf4j.federated.optimizer with parameters of type CloseableIteration Modifier and Type Method Description voidSourceSelection.SourceSelectionExecutorWithLatch. addResult(CloseableIteration<BindingSet> res)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.querySubinterfaces of CloseableIteration in org.eclipse.rdf4j.query Modifier and Type Interface Description interfaceGraphQueryResultA representation of a query result as a sequence ofStatementobjects.interfaceQueryResult<T>Super type of all query result types (TupleQueryResult, GraphQueryResult, etc.).interfaceTupleQueryResultA representation of a variable-binding query result as a sequence ofBindingSetobjects.Methods in org.eclipse.rdf4j.query with parameters of type CloseableIteration Modifier and Type Method Description static ModelQueryResults. asModel(CloseableIteration<? extends Statement> iteration)Get aModelcontaining all elements obtained from the specified query result.static ModelQueryResults. asModel(CloseableIteration<? extends Statement> iteration, ModelFactory modelFactory)Get aModelcontaining all elements obtained from the specified query result.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.query.algebraMethods in org.eclipse.rdf4j.query.algebra with parameters of type CloseableIteration Modifier and Type Method Description voidBinaryTupleOperator. setAlgorithm(CloseableIteration<?> iteration)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.query.algebra.evaluationClasses in org.eclipse.rdf4j.query.algebra.evaluation that implement CloseableIteration Modifier and Type Class Description static classQueryEvaluationStep.DelayedEvaluationIterationDeprecated, for removal: This API element is subject to removal in a future version.Methods in org.eclipse.rdf4j.query.algebra.evaluation that return CloseableIteration Modifier and Type Method Description protected CloseableIteration<? extends BindingSet>QueryEvaluationStep.DelayedEvaluationIteration. createIteration()Deprecated, for removal: This API element is subject to removal in a future version.CloseableIteration<BindingSet>EvaluationStrategy. evaluate(TupleExpr expr, BindingSet bindings)Evaluates the tuple expression against the supplied triple source with the specified set of variable bindings as input.CloseableIteration<BindingSet>QueryEvaluationStep. evaluate(BindingSet bindings)CloseableIteration<? extends Triple>RDFStarTripleSource. getRdfStarTriples(Resource subj, IRI pred, Value obj)Gets all Triple nodes that have a specific subject, predicate and/or object.CloseableIteration<? extends Statement>TripleSource. getStatements(Resource subj, IRI pred, Value obj, Resource... contexts)Gets all statements that have a specific subject, predicate and/or object.Method parameters in org.eclipse.rdf4j.query.algebra.evaluation with type arguments of type CloseableIteration Modifier and Type Method Description static QueryEvaluationStepQueryEvaluationStep. wrap(QueryEvaluationStep qes, Function<CloseableIteration<BindingSet>,CloseableIteration<BindingSet>> wrap)Wrap an QueryEvalationStep: where we apply a function on every evaluation result of the wrapped EvaluationStep.static QueryEvaluationStepQueryEvaluationStep. wrap(QueryEvaluationStep qes, Function<CloseableIteration<BindingSet>,CloseableIteration<BindingSet>> wrap)Wrap an QueryEvalationStep: where we apply a function on every evaluation result of the wrapped EvaluationStep.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.query.algebra.evaluation.federationClasses in org.eclipse.rdf4j.query.algebra.evaluation.federation that implement CloseableIteration Modifier and Type Class Description classServiceJoinIteratorIterator for efficient SERVICE evaluation (vectored).Methods in org.eclipse.rdf4j.query.algebra.evaluation.federation that return CloseableIteration Modifier and Type Method Description CloseableIteration<BindingSet>FederatedService. evaluate(Service service, CloseableIteration<BindingSet> bindings, String baseUri)Evaluate the provided SPARQL query at this federated service, possibilities for vectored evaluation.CloseableIteration<BindingSet>FederatedService. select(Service service, Set<String> projectionVars, BindingSet bindings, String baseUri)Evaluate the provided SPARQL query at this federated service.Methods in org.eclipse.rdf4j.query.algebra.evaluation.federation with parameters of type CloseableIteration Modifier and Type Method Description CloseableIteration<BindingSet>FederatedService. evaluate(Service service, CloseableIteration<BindingSet> bindings, String baseUri)Evaluate the provided SPARQL query at this federated service, possibilities for vectored evaluation.Constructors in org.eclipse.rdf4j.query.algebra.evaluation.federation with parameters of type CloseableIteration Constructor Description ServiceJoinIterator(CloseableIteration<BindingSet> leftIter, Service service, BindingSet bindings, EvaluationStrategy strategy)Construct a service join iteration to use vectored evaluation.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.query.algebra.evaluation.functionMethods in org.eclipse.rdf4j.query.algebra.evaluation.function that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends List<? extends Value>>TupleFunction. evaluate(ValueFactory valueFactory, Value... args)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.query.algebra.evaluation.implMethods in org.eclipse.rdf4j.query.algebra.evaluation.impl that return CloseableIteration Modifier and Type Method Description CloseableIteration<BindingSet>DefaultEvaluationStrategy. evaluate(TripleRef ref, BindingSet bindings)evaluates a TripleRef node returning bindingsets from the matched Triple nodes in the dataset (or explore standard reification)CloseableIteration<BindingSet>DefaultEvaluationStrategy. evaluate(TupleExpr expr, BindingSet bindings)Deprecated, for removal: This API element is subject to removal in a future version.static CloseableIteration<BindingSet>ExtendedEvaluationStrategy. evaluate(TupleFunction func, List<Var> resultVars, BindingSet bindings, ValueFactory valueFactory, Value... argValues)Deprecated, for removal: This API element is subject to removal in a future version.CloseableIteration<BindingSet>ExtendedEvaluationStrategy. evaluate(TupleExpr expr, BindingSet bindings)Deprecated, for removal: This API element is subject to removal in a future version.CloseableIteration<BindingSet>ExtensionQueryEvaluationStep. evaluate(BindingSet bs)static CloseableIteration<BindingSet>TupleFunctionEvaluationStrategy. evaluate(TupleFunction func, List<Var> resultVars, BindingSet bindings, ValueFactory valueFactory, Value... argValues)Deprecated, for removal: This API element is subject to removal in a future version.CloseableIteration<BindingSet>TupleFunctionEvaluationStrategy. evaluate(TupleExpr expr, BindingSet bindings)Deprecated, for removal: This API element is subject to removal in a future version.CloseableIteration<BindingSet>TupleFunctionEvaluationStrategy. evaluate(TupleFunctionCall expr, BindingSet bindings)Deprecated, for removal: This API element is subject to removal in a future version.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.query.algebra.evaluation.impl.evaluationstepsMethods in org.eclipse.rdf4j.query.algebra.evaluation.impl.evaluationsteps that return CloseableIteration Modifier and Type Method Description CloseableIteration<BindingSet>BindingSetAssignmentQueryEvaluationStep. evaluate(BindingSet bindings)CloseableIteration<BindingSet>IntersectionQueryEvaluationStep. evaluate(BindingSet bs)CloseableIteration<BindingSet>JoinQueryEvaluationStep. evaluate(BindingSet bindings)CloseableIteration<BindingSet>LeftJoinQueryEvaluationStep. evaluate(BindingSet bindings)CloseableIteration<BindingSet>MinusQueryEvaluationStep. evaluate(BindingSet bindings)CloseableIteration<BindingSet>OrderQueryEvaluationStep. evaluate(BindingSet bs)CloseableIteration<BindingSet>ProjectionQueryEvaluationStep. evaluate(BindingSet bindings)CloseableIteration<BindingSet>RdfStarQueryEvaluationStep. evaluate(BindingSet bindings)CloseableIteration<BindingSet>ReificationRdfStarQueryEvaluationStep. evaluate(BindingSet bindings)CloseableIteration<BindingSet>ServiceQueryEvaluationStep. evaluate(BindingSet bindings)CloseableIteration<BindingSet>SliceQueryEvaluationStep.OffSetAndLimitQueryEvaluationStep. evaluate(BindingSet bs)CloseableIteration<BindingSet>SliceQueryEvaluationStep.OnlyLimitQueryEvaluationStep. evaluate(BindingSet bs)CloseableIteration<BindingSet>SliceQueryEvaluationStep.OnlyOffsetQueryEvaluationStep. evaluate(BindingSet bs)CloseableIteration<BindingSet>StatementPatternQueryEvaluationStep. evaluate(BindingSet bindings)CloseableIteration<BindingSet>UnionQueryEvaluationStep. evaluate(BindingSet bindings)CloseableIteration<BindingSet>ZeroLengthPathEvaluationStep. evaluate(BindingSet bindings)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.query.algebra.evaluation.iteratorClasses in org.eclipse.rdf4j.query.algebra.evaluation.iterator that implement CloseableIteration Modifier and Type Class Description classBadlyDesignedLeftJoinIteratorclassCrossProductIterationIteration which forms the cross product of a list of materialized input bindings with each result obtained from the inner iteration.classDescribeIterationDeprecated.classExtensionIteratorDeprecated.classFilterIteratorDeprecated.classGroupIteratorclassHashJoinIterationGeneric hash join implementation suitable for use by Sail implementations.classJoinIteratorInterleaved join iterator.classLeftJoinIteratorclassMultiProjectionIteratorclassOrderIteratorDeprecated.classPathIterationclassProjectionIteratorDeprecated.classQueryContextIterationMakes aQueryContextavailable during iteration.classSPARQLMinusIterationDeprecated.classZeroLengthPathIterationFields in org.eclipse.rdf4j.query.algebra.evaluation.iterator declared as CloseableIteration Modifier and Type Field Description protected CloseableIteration<BindingSet>CrossProductIteration. resultIterationMethods in org.eclipse.rdf4j.query.algebra.evaluation.iterator that return CloseableIteration Modifier and Type Method Description protected CloseableIteration<BindingSet>OrderIterator. createIteration()Deprecated.protected CloseableIteration<BindingSet>DescribeIteration. createNextIteration(Value subject, Value object)Deprecated.protected CloseableIteration<BindingSet>SPARQLMinusIteration. getRightArg()Deprecated.Methods in org.eclipse.rdf4j.query.algebra.evaluation.iterator with parameters of type CloseableIteration Modifier and Type Method Description protected Collection<BindingSet>HashJoinIteration. makeIterationCache(CloseableIteration<BindingSet> iter)Utility methods to make it easier to inserted custom store dependent listprotected Set<BindingSet>SPARQLMinusIteration. makeSet(CloseableIteration<BindingSet> rightArg)Deprecated.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.query.algebra.evaluation.utilMethods in org.eclipse.rdf4j.query.algebra.evaluation.util that return CloseableIteration Modifier and Type Method Description static CloseableIteration<Literal>TripleSources. getObjectLiterals(Resource subject, IRI predicate, TripleSource store)Deprecated, for removal: This API element is subject to removal in a future version.static CloseableIteration<Resource>TripleSources. getObjectResources(Resource subject, IRI predicate, TripleSource store)Deprecated, for removal: This API element is subject to removal in a future version.static CloseableIteration<IRI>TripleSources. getObjectURIs(Resource subject, IRI predicate, TripleSource store)Deprecated, for removal: This API element is subject to removal in a future version.static CloseableIteration<IRI>TripleSources. getSubjectURIs(IRI predicate, Value object, TripleSource store)Deprecated, for removal: This API element is subject to removal in a future version.static CloseableIteration<Value>TripleSources. list(Resource subj, TripleSource store)Deprecated, for removal: This API element is subject to removal in a future version.static CloseableIteration<Resource>TripleSources. listResources(Resource subj, TripleSource store)Deprecated, for removal: This API element is subject to removal in a future version.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.query.implClasses in org.eclipse.rdf4j.query.impl that implement CloseableIteration Modifier and Type Class Description protected classAbstractParserQuery.QueryInterruptIterationDeprecated.classBackgroundGraphResultDeprecated.classGraphQueryResultImplDeprecated.since 2.0.classIteratingGraphQueryResultDeprecated.classIteratingTupleQueryResultDeprecated.classMutableTupleQueryResultAn implementation of theTupleQueryResultinterface that stores the complete query result in memory.classQueueCursor<E>Makes working with a queue easier by adding the methodsQueueIteration.done()andQueueIteration.toss(Exception)and automatically converting the exception into a QueryEvaluationException with an appropriate stack trace.classTupleQueryResultImplDeprecated.UseIteratingTupleQueryResultinstead.Methods in org.eclipse.rdf4j.query.impl that return CloseableIteration Modifier and Type Method Description protected CloseableIteration<? extends BindingSet>AbstractParserQuery. enforceMaxQueryTime(CloseableIteration<? extends BindingSet> bindingsIter)Methods in org.eclipse.rdf4j.query.impl with parameters of type CloseableIteration Modifier and Type Method Description protected CloseableIteration<? extends BindingSet>AbstractParserQuery. enforceMaxQueryTime(CloseableIteration<? extends BindingSet> bindingsIter)Constructors in org.eclipse.rdf4j.query.impl with parameters of type CloseableIteration Constructor Description GraphQueryResultImpl(Map<String,String> namespaces, CloseableIteration<? extends Statement> statementIter)Deprecated.IteratingGraphQueryResult(Map<String,String> namespaces, CloseableIteration<? extends Statement> statementIter)Deprecated.IteratingTupleQueryResult(List<String> bindingNames, CloseableIteration<? extends BindingSet> bindingSetIter)Deprecated.Creates a query result object with the supplied binding names.MutableTupleQueryResult(Collection<String> bindingNames, CloseableIteration<? extends BindingSet> bindingSetIter)QueryInterruptIteration(CloseableIteration<? extends BindingSet> iter, long timeLimit)Deprecated.TupleQueryResultImpl(List<String> bindingNames, CloseableIteration<? extends BindingSet> bindingSetIter)Deprecated.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.query.parser.implClasses in org.eclipse.rdf4j.query.parser.impl that implement CloseableIteration Modifier and Type Class Description protected classAbstractParserQuery.QueryInterruptIterationDeprecated.Methods in org.eclipse.rdf4j.query.parser.impl that return CloseableIteration Modifier and Type Method Description protected CloseableIteration<? extends BindingSet>AbstractParserQuery. enforceMaxQueryTime(CloseableIteration<? extends BindingSet> bindingsIter)Methods in org.eclipse.rdf4j.query.parser.impl with parameters of type CloseableIteration Modifier and Type Method Description protected CloseableIteration<? extends BindingSet>AbstractParserQuery. enforceMaxQueryTime(CloseableIteration<? extends BindingSet> bindingsIter)Constructors in org.eclipse.rdf4j.query.parser.impl with parameters of type CloseableIteration Constructor Description QueryInterruptIteration(CloseableIteration<? extends BindingSet> iter, long timeLimit)Deprecated.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.query.resultio.helpersClasses in org.eclipse.rdf4j.query.resultio.helpers that implement CloseableIteration Modifier and Type Class Description classBackgroundTupleResultDeprecated.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.repositoryClasses in org.eclipse.rdf4j.repository that implement CloseableIteration Modifier and Type Class Description classRepositoryResult<T>Methods in org.eclipse.rdf4j.repository with parameters of type CloseableIteration Modifier and Type Method Description voidRepositoryConnection. add(CloseableIteration<? extends Statement> statements, Resource... contexts)Adds the supplied statements to this repository, optionally to one or more named contexts.voidRepositoryConnection. remove(CloseableIteration<? extends Statement> statements, Resource... contexts)Removes the supplied statements from a specific context in this repository, ignoring any context information carried by the statements themselves.Constructors in org.eclipse.rdf4j.repository with parameters of type CloseableIteration Constructor Description RepositoryResult(CloseableIteration<? extends T> iter)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.repository.baseMethods in org.eclipse.rdf4j.repository.base with parameters of type CloseableIteration Modifier and Type Method Description voidAbstractRepositoryConnection. add(CloseableIteration<? extends Statement> statements, Resource... contexts)voidRepositoryConnectionWrapper. add(CloseableIteration<? extends Statement> statementIter, Resource... contexts)voidAbstractRepositoryConnection. remove(CloseableIteration<? extends Statement> statements, Resource... contexts)voidRepositoryConnectionWrapper. remove(CloseableIteration<? extends Statement> statementIter, Resource... contexts)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.repository.contextawareMethods in org.eclipse.rdf4j.repository.contextaware with parameters of type CloseableIteration Modifier and Type Method Description voidContextAwareConnection. add(CloseableIteration<? extends Statement> statementIter, Resource... contexts)voidContextAwareConnection. remove(CloseableIteration<? extends Statement> statementIter, Resource... contexts)Removes the supplied statements from a specific context in this repository, ignoring any context information carried by the statements themselves.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.repository.evaluationMethods in org.eclipse.rdf4j.repository.evaluation that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends Statement>RepositoryTripleSource. getStatements(Resource subj, IRI pred, Value obj, Resource... contexts)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.repository.sailMethods in org.eclipse.rdf4j.repository.sail with parameters of type CloseableIteration Modifier and Type Method Description protected <E> RepositoryResult<E>SailRepositoryConnection. createRepositoryResult(CloseableIteration<? extends E> sailIter)Wraps a CloseableIteration coming from a Sail in a RepositoryResult object, applying the required conversions
- 
Uses of CloseableIteration in org.eclipse.rdf4j.repository.sparql.federationClasses in org.eclipse.rdf4j.repository.sparql.federation that implement CloseableIteration Modifier and Type Class Description classCollectionIteration<E>An iteration to access a materializedCollectionof BindingSets.classJoinExecutorBase<T>Base class for any join parallel join executor.classServiceJoinConversionIterationDeprecated.classSPARQLCrossProductIterationIteration which forms the cross product of a list of materialized input bindings with each result obtained from the inner iteration.Fields in org.eclipse.rdf4j.repository.sparql.federation declared as CloseableIteration Modifier and Type Field Description protected CloseableIteration<T>JoinExecutorBase. leftIterprotected CloseableIteration<BindingSet>SPARQLCrossProductIteration. resultIterationprotected CloseableIteration<T>JoinExecutorBase. rightIterFields in org.eclipse.rdf4j.repository.sparql.federation with type parameters of type CloseableIteration Modifier and Type Field Description protected QueueCursor<CloseableIteration<T>>JoinExecutorBase. rightQueueMethods in org.eclipse.rdf4j.repository.sparql.federation that return CloseableIteration Modifier and Type Method Description CloseableIteration<BindingSet>RepositoryFederatedService. evaluate(Service service, CloseableIteration<BindingSet> bindings, String baseUri)protected CloseableIteration<BindingSet>RepositoryFederatedService. evaluateInternal(Service service, CloseableIteration<BindingSet> bindings, String baseUri)Evaluate the SPARQL query that can be constructed from the SERVICE node at the initializedRepositoryof thisFederatedService.CloseableIteration<BindingSet>RepositoryFederatedService. select(Service service, Set<String> projectionVars, BindingSet bindings, String baseUri)Evaluate the provided sparqlQueryString at the initializedRepositoryof thisFederatedService.Methods in org.eclipse.rdf4j.repository.sparql.federation with parameters of type CloseableIteration Modifier and Type Method Description voidJoinExecutorBase. addResult(CloseableIteration<T> res)CloseableIteration<BindingSet>RepositoryFederatedService. evaluate(Service service, CloseableIteration<BindingSet> bindings, String baseUri)protected CloseableIteration<BindingSet>RepositoryFederatedService. evaluateInternal(Service service, CloseableIteration<BindingSet> bindings, String baseUri)Evaluate the SPARQL query that can be constructed from the SERVICE node at the initializedRepositoryof thisFederatedService.Constructors in org.eclipse.rdf4j.repository.sparql.federation with parameters of type CloseableIteration Constructor Description JoinExecutorBase(CloseableIteration<T> leftIter, TupleExpr rightArg, BindingSet bindings)ServiceJoinConversionIteration(CloseableIteration<BindingSet> iter, List<BindingSet> bindings)Deprecated.SPARQLCrossProductIteration(CloseableIteration<BindingSet> resultIteration, List<BindingSet> inputBindings)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.repository.sparql.queryClasses in org.eclipse.rdf4j.repository.sparql.query that implement CloseableIteration Modifier and Type Class Description classInsertBindingSetCursorAdds more bindings to each of the results.Constructors in org.eclipse.rdf4j.repository.sparql.query with parameters of type CloseableIteration Constructor Description InsertBindingSetCursor(CloseableIteration<BindingSet> delegate, BindingSet bindings)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sailClasses in org.eclipse.rdf4j.sail that implement CloseableIteration Modifier and Type Class Description classTripleSourceIterationWrapper<T>Methods in org.eclipse.rdf4j.sail that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends BindingSet>SailConnection. evaluate(TupleExpr tupleExpr, Dataset dataset, BindingSet bindings, boolean includeInferred)Evaluates the supplied TupleExpr on the data contained in this Sail object, using the (optional) dataset and supplied bindings as input parameters.CloseableIteration<? extends Resource>SailConnection. getContextIDs()Returns the set of all unique context identifiers that are used to store statements.CloseableIteration<? extends Namespace>SailConnection. getNamespaces()Gets the namespaces relevant to the data contained in this Sail object.CloseableIteration<? extends Statement>SailConnection. getStatements(Resource subj, IRI pred, Value obj, boolean includeInferred, Resource... contexts)Gets all statements from the specified contexts that have a specific subject, predicate and/or object.Constructors in org.eclipse.rdf4j.sail with parameters of type CloseableIteration Constructor Description TripleSourceIterationWrapper(CloseableIteration<? extends T> delegate)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.baseClasses in org.eclipse.rdf4j.sail.base that implement CloseableIteration Modifier and Type Class Description classDistinctModelReducingUnionIterationAn Iteration that takes two source.Methods in org.eclipse.rdf4j.sail.base that return CloseableIteration Modifier and Type Method Description protected CloseableIteration<? extends BindingSet>SailSourceConnection. evaluateInternal(TupleExpr tupleExpr, Dataset dataset, BindingSet bindings, boolean includeInferred)CloseableIteration<? extends Resource>SailDataset. getContextIDs()Returns the set of all unique context identifiers that are used to store statements.protected CloseableIteration<? extends Resource>SailSourceConnection. getContextIDsInternal()CloseableIteration<? extends Namespace>SailDataset. getNamespaces()Gets the namespaces relevant to the data contained in this object.protected CloseableIteration<? extends Namespace>SailSourceConnection. getNamespacesInternal()CloseableIteration<? extends Triple>SailDatasetTripleSource. getRdfStarTriples(Resource subj, IRI pred, Value obj)CloseableIteration<? extends Statement>SailDataset. getStatements(Resource subj, IRI pred, Value obj, Resource... contexts)Gets all statements that have a specific subject, predicate and/or object.CloseableIteration<? extends Statement>SailDatasetTripleSource. getStatements(Resource subj, IRI pred, Value obj, Resource... contexts)protected CloseableIteration<? extends Statement>SailSourceConnection. getStatementsInternal(Resource subj, IRI pred, Value obj, boolean includeInferred, Resource... contexts)default CloseableIteration<? extends Triple>SailDataset. getTriples(Resource subj, IRI pred, Value obj)Gets all RDF-star triples that have a specific subject, predicate and/or object.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.evaluationMethods in org.eclipse.rdf4j.sail.evaluation that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends Statement>SailTripleSource. getStatements(Resource subj, IRI pred, Value obj, Resource... contexts)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.extensiblestoreClasses in org.eclipse.rdf4j.sail.extensiblestore that implement CloseableIteration Modifier and Type Class Description classFilteringIteration<E extends ExtensibleStatement,X extends Exception>A wrapper for an Iteration that filters the statements against a pattern similar to getStatements(Resource subject, IRI predicate, Value object, Resource...Methods in org.eclipse.rdf4j.sail.extensiblestore that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends ExtensibleStatement>DataStructureInterface. getStatements(Resource subject, IRI predicate, Value object, boolean inferred, Resource... context)CloseableIteration<? extends ExtensibleStatement>EagerReadCache. getStatements(Resource subject, IRI predicate, Value object, boolean inferred, Resource... context)CloseableIteration<? extends ExtensibleStatement>LazyReadCache. getStatements(Resource subject, IRI predicate, Value object, boolean inferred, Resource... context)Constructors in org.eclipse.rdf4j.sail.extensiblestore with parameters of type CloseableIteration Constructor Description FilteringIteration(CloseableIteration<E> wrappedIteration, Resource subject, IRI predicate, Value object, boolean inferred, Resource... context)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.extensiblestore.evaluationstatisticsMethods in org.eclipse.rdf4j.sail.extensiblestore.evaluationstatistics that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends ExtensibleStatement>EvaluationStatisticsWrapper. getStatements(Resource subject, IRI predicate, Value object, boolean inferred, Resource... context)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.helpersMethods in org.eclipse.rdf4j.sail.helpers that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends BindingSet>AbstractSailConnection. evaluate(TupleExpr tupleExpr, Dataset dataset, BindingSet bindings, boolean includeInferred)CloseableIteration<? extends BindingSet>SailConnectionWrapper. evaluate(TupleExpr tupleExpr, Dataset dataset, BindingSet bindings, boolean includeInferred)protected abstract CloseableIteration<? extends BindingSet>AbstractSailConnection. evaluateInternal(TupleExpr tupleExpr, Dataset dataset, BindingSet bindings, boolean includeInferred)CloseableIteration<? extends Resource>AbstractSailConnection. getContextIDs()CloseableIteration<? extends Resource>SailConnectionWrapper. getContextIDs()protected abstract CloseableIteration<? extends Resource>AbstractSailConnection. getContextIDsInternal()CloseableIteration<? extends Namespace>AbstractSailConnection. getNamespaces()CloseableIteration<? extends Namespace>SailConnectionWrapper. getNamespaces()protected abstract CloseableIteration<? extends Namespace>AbstractSailConnection. getNamespacesInternal()CloseableIteration<? extends Statement>AbstractSailConnection. getStatements(Resource subj, IRI pred, Value obj, boolean includeInferred, Resource... contexts)CloseableIteration<? extends Statement>SailConnectionWrapper. getStatements(Resource subj, IRI pred, Value obj, boolean includeInferred, Resource... contexts)protected abstract CloseableIteration<? extends Statement>AbstractSailConnection. getStatementsInternal(Resource subj, IRI pred, Value obj, boolean includeInferred, Resource... contexts)protected <T,E extends Exception>
 CloseableIteration<T>AbstractSailConnection. registerIteration(CloseableIteration<T> iter)Registers an iteration as active by wrapping it in aSailBaseIterationobject and adding it to the list of active iterations.Methods in org.eclipse.rdf4j.sail.helpers with parameters of type CloseableIteration Modifier and Type Method Description protected <T,E extends Exception>
 CloseableIteration<T>AbstractSailConnection. registerIteration(CloseableIteration<T> iter)Registers an iteration as active by wrapping it in aSailBaseIterationobject and adding it to the list of active iterations.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.inferencerMethods in org.eclipse.rdf4j.sail.inferencer that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends BindingSet>InferencerConnectionWrapper. evaluate(TupleExpr tupleExpr, Dataset dataset, BindingSet bindings, boolean includeInferred)CallsInferencerConnectionWrapper.flushUpdates()before forwarding the call to the wrapped connection.CloseableIteration<? extends Resource>InferencerConnectionWrapper. getContextIDs()CallsInferencerConnectionWrapper.flushUpdates()before forwarding the call to the wrapped connection.CloseableIteration<? extends Statement>InferencerConnectionWrapper. getStatements(Resource subj, IRI pred, Value obj, boolean includeInferred, Resource... contexts)CallsInferencerConnectionWrapper.flushUpdates()before forwarding the call to the wrapped connection.
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.luceneMethods in org.eclipse.rdf4j.sail.lucene that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends BindingSet>LuceneSailConnection. evaluate(TupleExpr tupleExpr, Dataset dataset, BindingSet bindings, boolean includeInferred)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.memory.modelClasses in org.eclipse.rdf4j.sail.memory.model that implement CloseableIteration Modifier and Type Class Description classMemStatementIteratorA StatementIterator that can iterate over a list of Statement objects.classMemTripleIterator<X extends Exception>An Iteration that can iterate over a list ofTripleobjects.Methods in org.eclipse.rdf4j.sail.memory.model that return CloseableIteration Modifier and Type Method Description static CloseableIteration<MemStatement>MemStatementIterator. cacheAwareInstance(MemStatementList smallestList, MemResource subj, MemIRI pred, MemValue obj, Boolean explicit, int snapshot, MemResource[] memContexts, MemStatementIteratorCache iteratorCache)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.shaclMethods in org.eclipse.rdf4j.sail.shacl that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends Statement>ShaclSailConnection. getStatements(Resource subj, IRI pred, Value obj, boolean includeInferred, Resource... contexts)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.shacl.ast.planNodesClasses in org.eclipse.rdf4j.sail.shacl.ast.planNodes that implement CloseableIteration Modifier and Type Class Description classLoggingCloseableIteration
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.shacl.ast.targetsMethods in org.eclipse.rdf4j.sail.shacl.ast.targets that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends ValidationTuple>TargetChainRetriever. iterator()
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.shacl.results.lazyConstructors in org.eclipse.rdf4j.sail.shacl.results.lazy with parameters of type CloseableIteration Constructor Description ValidationResultIterator(CloseableIteration<? extends ValidationTuple> tupleIterator, long limit)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.sail.shacl.wrapper.dataClasses in org.eclipse.rdf4j.sail.shacl.wrapper.data that implement CloseableIteration Modifier and Type Class Description classCloseablePeakableIteration<E>Methods in org.eclipse.rdf4j.sail.shacl.wrapper.data that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends Statement>VerySimpleRdfsBackwardsChainingConnection. getStatements(Resource subj, IRI pred, Value obj, boolean includeInferred, Resource... contexts)Constructors in org.eclipse.rdf4j.sail.shacl.wrapper.data with parameters of type CloseableIteration Constructor Description CloseablePeakableIteration(CloseableIteration<E> parent)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.spin.functionMethods in org.eclipse.rdf4j.spin.function that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends List<? extends Value>>ConstructTupleFunction. evaluate(ValueFactory valueFactory, Value... args)CloseableIteration<? extends List<? extends Value>>SelectTupleFunction. evaluate(ValueFactory valueFactory, Value... args)CloseableIteration<? extends List<? extends Value>>SpinTupleFunction. evaluate(ValueFactory valueFactory, Value... args)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.spin.function.apfMethods in org.eclipse.rdf4j.spin.function.apf that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends List<? extends Value>>ConcatTupleFunction. evaluate(ValueFactory valueFactory, Value... args)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.spin.function.listMethods in org.eclipse.rdf4j.spin.function.list that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends List<? extends Value>>Index. evaluate(ValueFactory valueFactory, Value... args)CloseableIteration<? extends List<? extends Value>>Length. evaluate(ValueFactory valueFactory, Value... args)CloseableIteration<? extends List<? extends Value>>Member. evaluate(ValueFactory valueFactory, Value... args)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.spin.function.spifMethods in org.eclipse.rdf4j.spin.function.spif that return CloseableIteration Modifier and Type Method Description CloseableIteration<? extends List<? extends Value>>For. evaluate(ValueFactory valueFactory, Value... args)CloseableIteration<? extends List<? extends Value>>ForEach. evaluate(ValueFactory valueFactory, Value... args)CloseableIteration<? extends List<? extends Value>>Split. evaluate(ValueFactory valueFactory, Value... args)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.spring.operationlogMethods in org.eclipse.rdf4j.spring.operationlog with parameters of type CloseableIteration Modifier and Type Method Description voidLoggingRepositoryConnection. add(CloseableIteration<? extends Statement> statementIter, Resource... contexts)voidLoggingRepositoryConnection. remove(CloseableIteration<? extends Statement> statementIter, Resource... contexts)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.spring.resultcacheClasses in org.eclipse.rdf4j.spring.resultcache that implement CloseableIteration Modifier and Type Class Description classCachedGraphQueryResultclassCachedTupleQueryResultclassReusableGraphQueryResultWrapper for a TupleQueryResult, allowing the result to be replayed.classReusableTupleQueryResultWrapper for a TupleQueryResult, allowing the result to be replayed.Methods in org.eclipse.rdf4j.spring.resultcache with parameters of type CloseableIteration Modifier and Type Method Description voidCachingRepositoryConnection. add(CloseableIteration<? extends Statement> statementIter, Resource... contexts)voidCachingRepositoryConnection. remove(CloseableIteration<? extends Statement> statementIter, Resource... contexts)
- 
Uses of CloseableIteration in org.eclipse.rdf4j.spring.txMethods in org.eclipse.rdf4j.spring.tx with parameters of type CloseableIteration Modifier and Type Method Description voidTransactionalRepositoryConnection. add(CloseableIteration<? extends Statement> statementIter, Resource... contexts)voidTransactionalRepositoryConnection. remove(CloseableIteration<? extends Statement> statementIter, Resource... contexts)
 
-