Uses of Interface
org.openrefine.util.CloseableIterator
-
Packages that use CloseableIterator Package Description org.openrefine.browsing org.openrefine.model org.openrefine.model.changes org.openrefine.runners.local Supplies aRunner
which is designed for execution on a single machine, with parallelism.org.openrefine.runners.local.logging org.openrefine.runners.local.pll org.openrefine.runners.local.pll.util org.openrefine.runners.testing org.openrefine.templating org.openrefine.util -
-
Uses of CloseableIterator in org.openrefine.browsing
Methods in org.openrefine.browsing that return CloseableIterator Modifier and Type Method Description CloseableIterator<Record>
Engine. getMatchingRecords(SortingConfig sortingConfig)
Iterates over the records matched by the given filters.CloseableIterator<IndexedRow>
Engine. getMatchingRows(SortingConfig sortingConfig)
Iterates over the rows matched by the given filters. -
Uses of CloseableIterator in org.openrefine.model
Methods in org.openrefine.model that return CloseableIterator Modifier and Type Method Description static CloseableIterator<Record>
Record. groupIntoRecords(CloseableIterator<IndexedRow> parentIter, int keyCellIndex, boolean ignoreFirstRows, List<Row> additionalRows)
Groups a stream of indexed rows into a stream of records.CloseableIterator<Record>
Grid. iterateRecords(RecordFilter filter)
Iterate over records matched by a filter.CloseableIterator<IndexedRow>
Grid. iterateRows(RowFilter filter)
Iterate over rows matched by a filter, in the order determined by a sorting configuration.Methods in org.openrefine.model with parameters of type CloseableIterator Modifier and Type Method Description static CloseableIterator<Record>
Record. groupIntoRecords(CloseableIterator<IndexedRow> parentIter, int keyCellIndex, boolean ignoreFirstRows, List<Row> additionalRows)
Groups a stream of indexed rows into a stream of records. -
Uses of CloseableIterator in org.openrefine.model.changes
Methods in org.openrefine.model.changes that return CloseableIterator Modifier and Type Method Description static <T> CloseableIterator<IndexedData<T>>
IndexedData. completeIterator(CloseableIterator<IndexedData<T>> originalIterator)
Completes an iterator over a set of indexed data, by appending an infinite stream of pending indexed data objects after the original stream ends.Methods in org.openrefine.model.changes with parameters of type CloseableIterator Modifier and Type Method Description static <T> CloseableIterator<IndexedData<T>>
IndexedData. completeIterator(CloseableIterator<IndexedData<T>> originalIterator)
Completes an iterator over a set of indexed data, by appending an infinite stream of pending indexed data objects after the original stream ends. -
Uses of CloseableIterator in org.openrefine.runners.local
Methods in org.openrefine.runners.local with parameters of type CloseableIterator Modifier and Type Method Description protected static <T> CloseableIterator<Tuple2<Long,IndexedData<T>>>
LocalRunner. fillWithIncompleteIndexedData(CloseableIterator<Tuple2<Long,IndexedData<T>>> originalIterator, long initialIndex, long upperBound)
Utility function used to pad a stream of elements read from an incomplete change data with "virtual", pending IndexedData elements to represent those which may be computed later.protected static <T> CloseableIterator<Tuple2<Long,T>>
LocalChangeData. wrapStreamWithProgressReporting(long startIdx, CloseableIterator<Tuple2<Long,T>> iterator, TaskSignalling taskSignalling)
-
Uses of CloseableIterator in org.openrefine.runners.local.logging
Methods in org.openrefine.runners.local.logging that return CloseableIterator Modifier and Type Method Description CloseableIterator<Record>
LoggedGrid. iterateRecords(RecordFilter filter)
CloseableIterator<IndexedRow>
LoggedGrid. iterateRows(RowFilter filter)
CloseableIterator<IndexedData<T>>
LoggedChangeData. iterator()
-
Uses of CloseableIterator in org.openrefine.runners.local.pll
Fields in org.openrefine.runners.local.pll with type parameters of type CloseableIterator Modifier and Type Field Description protected BiFunction<Integer,CloseableIterator<U>,CloseableIterator<T>>
MapPartitionsPLL. mapFunction
protected BiFunction<Integer,CloseableIterator<U>,CloseableIterator<T>>
MapPartitionsPLL. mapFunction
Methods in org.openrefine.runners.local.pll that return CloseableIterator Modifier and Type Method Description protected CloseableIterator<T>
CroppedPLL. compute(Partition partition)
protected CloseableIterator<T>
DropPartitionsPLL. compute(Partition partition)
protected CloseableIterator<Tuple2<Long,T>>
IndexedPLL. compute(Partition partition)
CloseableIterator<T>
InMemoryPLL. compute(Partition partition)
CloseableIterator<T>
MapPartitionsPLL. compute(Partition partition)
protected CloseableIterator<Tuple2<K,Tuple2<V,W>>>
OrderedJoinPLL. compute(Partition partition)
protected CloseableIterator<Tuple2<K,V>>
PairPLL. compute(Partition partition)
protected abstract CloseableIterator<T>
PLL. compute(Partition partition)
Iterate over the elements of the given partition.protected CloseableIterator<Tuple2<Long,Record>>
RecordPLL. compute(Partition partition)
protected CloseableIterator<T>
SinglePartitionPLL. compute(Partition partition)
protected CloseableIterator<String>
TextFilePLL. compute(Partition partition)
protected CloseableIterator<T>
UnionPLL. compute(Partition partition)
protected static CloseableIterator<Tuple2<Long,Record>>
RecordPLL. groupIntoRecords(CloseableIterator<IndexedRow> indexedRows, int keyCellIndex, boolean ignoreFirstRows, List<Row> additionalRows)
CloseableIterator<Tuple2<K,V>>
PairPLL. iterate(Partition partition)
CloseableIterator<T>
PLL. iterate(Partition partition)
Iterate over the elements of the given partition.protected CloseableIterator<T>
PLL. iterateFromPartition(int partitionId)
Stream over the part of the collection that starts at given partition boundary.CloseableIterator<T>
PLL. iterator()
Returns an iterator over the listprotected static <K,V,W>
CloseableIterator<Tuple2<K,Tuple2<V,W>>>OrderedJoinPLL. joinStreams(CloseableIterator<Tuple2<K,V>> firstIterator, CloseableIterator<Tuple2<K,W>> secondIterator, Comparator<K> comparator, OrderedJoinPLL.JoinType joinType)
Merges two key-ordered streams where each key is guaranteed to appear at most once in each stream.protected static <T,S,U>
CloseableIterator<U>PLL. scanMapStream(CloseableIterator<T> iterator, S initialState, Function<T,S> feed, BiFunction<S,S,S> combine, BiFunction<S,T,U> map)
CloseableIterator<Tuple2<K,V>>
PairPLL. streamBetweenKeys(Optional<K> from, Optional<K> upTo, Comparator<K> comparator)
Iterates over the elements of this PLL between the given keys, where both boundaries are optional.CloseableIterator<Tuple2<K,V>>
PairPLL. streamBetweenKeys(K from, K upTo, Comparator<K> comparator)
Iterates over the elements of this PLL from the given key (inclusive) and up to the other given key (exclusive).CloseableIterator<Tuple2<K,V>>
PairPLL. streamFromKey(K from, Comparator<K> comparator)
Iterates over the elements of this PLL starting from a given key (inclusive).CloseableIterator<Tuple2<K,V>>
PairPLL. streamUpToKey(K upTo, Comparator<K> comparator)
Iterates over the elements of this PLL up to the given key (exclusive).Methods in org.openrefine.runners.local.pll with parameters of type CloseableIterator Modifier and Type Method Description protected static RecordPLL.RecordEnd
RecordPLL. extractRecordEnd(CloseableIterator<IndexedRow> iterator, int keyColumnIndex)
protected static <K,V>
List<Tuple2<K,V>>PairPLL. gatherElementsBefore(K upperBound, int limit, CloseableIterator<Tuple2<K,V>> stream, Comparator<K> comparator)
Returns the last n elements whose key is strictly less than the supplied upper bound.protected static CloseableIterator<Tuple2<Long,Record>>
RecordPLL. groupIntoRecords(CloseableIterator<IndexedRow> indexedRows, int keyCellIndex, boolean ignoreFirstRows, List<Row> additionalRows)
protected static <K,V,W>
CloseableIterator<Tuple2<K,Tuple2<V,W>>>OrderedJoinPLL. joinStreams(CloseableIterator<Tuple2<K,V>> firstIterator, CloseableIterator<Tuple2<K,W>> secondIterator, Comparator<K> comparator, OrderedJoinPLL.JoinType joinType)
Merges two key-ordered streams where each key is guaranteed to appear at most once in each stream.protected static <T,S,U>
CloseableIterator<U>PLL. scanMapStream(CloseableIterator<T> iterator, S initialState, Function<T,S> feed, BiFunction<S,S,S> combine, BiFunction<S,T,U> map)
protected void
PLL. writePartition(int partitionIndex, CloseableIterator<T> iterator, File partFile, Optional<TaskSignalling> taskSignalling, boolean flushRegularly)
Method parameters in org.openrefine.runners.local.pll with type arguments of type CloseableIterator Modifier and Type Method Description <U> PLL<U>
PLL. flatMap(Function<T,CloseableIterator<U>> mapFunction, String mapDescription)
Derives a new PLL by applying a map function on each element, which can return multiple elements of the new list.<U> PLL<U>
PLL. mapPartitions(BiFunction<Integer,CloseableIterator<T>,CloseableIterator<U>> map, String mapDescription, boolean preservesSizes)
Maps each partition by applying an arbitrary function to it.<U> PLL<U>
PLL. mapPartitions(BiFunction<Integer,CloseableIterator<T>,CloseableIterator<U>> map, String mapDescription, boolean preservesSizes)
Maps each partition by applying an arbitrary function to it.Constructor parameters in org.openrefine.runners.local.pll with type arguments of type CloseableIterator Constructor Description MapPartitionsPLL(PLL<U> parent, BiFunction<Integer,CloseableIterator<U>,CloseableIterator<T>> mapFunction, String mapFunctionDescription)
Constructs a PLL with partitions derived one-to-one from the parent.MapPartitionsPLL(PLL<U> parent, BiFunction<Integer,CloseableIterator<U>,CloseableIterator<T>> mapFunction, String mapFunctionDescription)
Constructs a PLL with partitions derived one-to-one from the parent.MapPartitionsPLL(PLL<U> parent, BiFunction<Integer,CloseableIterator<U>,CloseableIterator<T>> mapFunction, String mapFunctionDescription, boolean preservesSizes)
Constructs a PLL with partitions derived one-to-one from the parent.MapPartitionsPLL(PLL<U> parent, BiFunction<Integer,CloseableIterator<U>,CloseableIterator<T>> mapFunction, String mapFunctionDescription, boolean preservesSizes)
Constructs a PLL with partitions derived one-to-one from the parent. -
Uses of CloseableIterator in org.openrefine.runners.local.pll.util
Methods in org.openrefine.runners.local.pll.util that return CloseableIterator Modifier and Type Method Description <T> CloseableIterator<T>
TaskSignalling. wrapStream(CloseableIterator<T> stream, int reportBatchSize, int reportOffset)
Wraps a stream by updating the progress reporter when it is iterated from.Methods in org.openrefine.runners.local.pll.util with parameters of type CloseableIterator Modifier and Type Method Description <T> CloseableIterator<T>
TaskSignalling. wrapStream(CloseableIterator<T> stream, int reportBatchSize, int reportOffset)
Wraps a stream by updating the progress reporter when it is iterated from. -
Uses of CloseableIterator in org.openrefine.runners.testing
Methods in org.openrefine.runners.testing that return CloseableIterator Modifier and Type Method Description CloseableIterator<Record>
TestingGrid. iterateRecords(RecordFilter filter)
CloseableIterator<IndexedRow>
TestingGrid. iterateRows(RowFilter filter)
CloseableIterator<IndexedData<T>>
TestingChangeData. iterator()
-
Uses of CloseableIterator in org.openrefine.templating
Methods in org.openrefine.templating with parameters of type CloseableIterator Modifier and Type Method Description void
Template. writeRecords(CloseableIterator<Record> records, Writer writer, ColumnModel columnModel, Map<String,OverlayModel> overlayModels, long projectId, int limit)
void
Template. writeRows(CloseableIterator<IndexedRow> rows, Writer writer, ColumnModel columnModel, Map<String,OverlayModel> overlayModels, long projectId, int limit)
-
Uses of CloseableIterator in org.openrefine.util
Classes in org.openrefine.util that implement CloseableIterator Modifier and Type Class Description static class
CloseableIterator.Wrapper<T>
A wrapper which takes a plain iterator and turns it into a closeable one.Methods in org.openrefine.util that return CloseableIterator Modifier and Type Method Description default <R> CloseableIterator<R>
CloseableIterator. collect(io.vavr.PartialFunction<? super T,? extends R> partialFunction)
default CloseableIterator<T>
CloseableIterator. concat(CloseableIterator<? extends T> that)
default CloseableIterator<T>
CloseableIterator. distinct()
default CloseableIterator<T>
CloseableIterator. distinctBy(Comparator<? super T> comparator)
default <U> CloseableIterator<T>
CloseableIterator. distinctBy(Function<? super T,? extends U> keyExtractor)
default CloseableIterator<T>
CloseableIterator. drop(int n)
default CloseableIterator<T>
CloseableIterator. dropRight(int n)
default CloseableIterator<T>
CloseableIterator. dropUntil(Predicate<? super T> predicate)
default CloseableIterator<T>
CloseableIterator. dropWhile(Predicate<? super T> predicate)
static <T> CloseableIterator<T>
CloseableIterator. empty()
default CloseableIterator<T>
CloseableIterator. filter(Predicate<? super T> predicate)
default <U> CloseableIterator<U>
CloseableIterator. flatMapCloseable(Function<? super T,? extends CloseableIterator<? extends U>> mapper)
static CloseableIterator<Long>
CloseableIterator. from(long start)
default CloseableIterator<io.vavr.collection.Seq<T>>
CloseableIterator. grouped(int size)
default CloseableIterator<T>
CloseableIterator. init()
default CloseableIterator<T>
CloseableIterator. intersperse(T element)
CloseableIterator<T>
CloseableIterable. iterator()
CloseableIterator<T>
CloseableIterable.Wrapper. iterator()
default CloseableIterator<T>
CloseableIterator. iterator()
default <U> CloseableIterator<U>
CloseableIterator. map(Function<? super T,? extends U> mapper)
static <T> CloseableIterator<T>
CloseableIterator. of(T... elements)
static <T> CloseableIterator<T>
CloseableIterator. ofAll(Iterable<? extends T> ts)
default CloseableIterator<T>
CloseableIterator. orElse(Supplier<? extends Iterable<? extends T>> supplier)
Deprecated.This method should not be called as it discards the pointers to the closeable resources.default CloseableIterator<T>
CloseableIterator. orElse(CloseableIterator<T> other)
default CloseableIterator<T>
CloseableIterator. peek(Consumer<? super T> action)
default CloseableIterator<T>
CloseableIterator. reject(Predicate<? super T> predicate)
default CloseableIterator<T>
CloseableIterator. replace(T currentElement, T newElement)
default CloseableIterator<T>
CloseableIterator. replaceAll(T currentElement, T newElement)
default CloseableIterator<T>
CloseableIterator. retainAll(Iterable<? extends T> elements)
default <U> CloseableIterator<U>
CloseableIterator. scanLeft(U zero, BiFunction<? super U,? super T,? extends U> operation)
default <U> CloseableIterator<U>
CloseableIterator. scanRight(U zero, BiFunction<? super T,? super U,? extends U> operation)
default CloseableIterator<io.vavr.collection.Seq<T>>
CloseableIterator. slideBy(Function<? super T,?> classifier)
default CloseableIterator<io.vavr.collection.Seq<T>>
CloseableIterator. sliding(int size)
default CloseableIterator<io.vavr.collection.Seq<T>>
CloseableIterator. sliding(int size, int step)
default CloseableIterator<T>
CloseableIterator. tail()
default CloseableIterator<T>
CloseableIterator. take(int n)
default CloseableIterator<T>
CloseableIterator. takeRight(int n)
default CloseableIterator<T>
CloseableIterator. takeUntil(Predicate<? super T> predicate)
default CloseableIterator<T>
CloseableIterator. takeWhile(Predicate<? super T> predicate)
static <T> CloseableIterator<T>
CloseableIterator. wrapping(io.vavr.collection.Iterator<? extends T> ts)
static <T> CloseableIterator<T>
CloseableIterator. wrapping(Iterator<? extends T> ts)
static <T> CloseableIterator<T>
CloseableIterator. wrapping(Iterator<? extends T> iterator, AutoCloseable closeable)
default <U> CloseableIterator<io.vavr.Tuple2<T,U>>
CloseableIterator. zip(CloseableIterator<? extends U> that)
default <U> CloseableIterator<io.vavr.Tuple2<T,U>>
CloseableIterator. zipAll(CloseableIterator<? extends U> that, T thisElem, U thatElem)
default <U,R>
CloseableIterator<R>CloseableIterator. zipWith(CloseableIterator<? extends U> that, BiFunction<? super T,? super U,? extends R> mapper)
default CloseableIterator<io.vavr.Tuple2<T,Integer>>
CloseableIterator. zipWithIndex()
default <U> CloseableIterator<U>
CloseableIterator. zipWithIndex(BiFunction<? super T,? super Integer,? extends U> mapper)
Methods in org.openrefine.util with parameters of type CloseableIterator Modifier and Type Method Description default CloseableIterator<T>
CloseableIterator. concat(CloseableIterator<? extends T> that)
default CloseableIterator<T>
CloseableIterator. orElse(CloseableIterator<T> other)
default <U> CloseableIterator<io.vavr.Tuple2<T,U>>
CloseableIterator. zip(CloseableIterator<? extends U> that)
default <U> CloseableIterator<io.vavr.Tuple2<T,U>>
CloseableIterator. zipAll(CloseableIterator<? extends U> that, T thisElem, U thatElem)
default <U,R>
CloseableIterator<R>CloseableIterator. zipWith(CloseableIterator<? extends U> that, BiFunction<? super T,? super U,? extends R> mapper)
Method parameters in org.openrefine.util with type arguments of type CloseableIterator Modifier and Type Method Description default <U> CloseableIterator<U>
CloseableIterator. flatMapCloseable(Function<? super T,? extends CloseableIterator<? extends U>> mapper)
-