Modifier and Type | Method and Description |
---|---|
protected void |
SourceTestSuiteBase.checkResultWithSemantic(CloseableIterator<T> resultIterator,
List<List<T>> testData,
CheckpointingMode semantic,
Integer limit)
Compare the test data with the result.
|
Modifier and Type | Method and Description |
---|---|
CloseableIterator<E> |
RocksDBCachingPriorityQueueSet.iterator() |
Modifier and Type | Method and Description |
---|---|
void |
ChannelStateWriterImpl.addInputData(long checkpointId,
InputChannelInfo info,
int startSeqNum,
CloseableIterator<Buffer> iterator) |
void |
ChannelStateWriter.addInputData(long checkpointId,
InputChannelInfo info,
int startSeqNum,
CloseableIterator<Buffer> data)
Add in-flight buffers from the
InputChannel . |
void |
ChannelStateWriter.NoOpChannelStateWriter.addInputData(long checkpointId,
InputChannelInfo info,
int startSeqNum,
CloseableIterator<Buffer> data) |
Modifier and Type | Class and Description |
---|---|
class |
FileBasedBufferIterator
CloseableIterator of buffers over file content. |
Modifier and Type | Method and Description |
---|---|
CloseableIterator<Buffer> |
RecordDeserializer.getUnconsumedBuffer()
Gets the unconsumed buffer which needs to be persisted in unaligned checkpoint scenario.
|
CloseableIterator<Buffer> |
SpillingAdaptiveSpanningRecordDeserializer.getUnconsumedBuffer() |
Modifier and Type | Method and Description |
---|---|
CloseableIterator<T> |
InternalPriorityQueue.iterator()
Iterator over all elements, no order guaranteed.
|
Modifier and Type | Method and Description |
---|---|
CloseableIterator<StateChange> |
StateChangelogHandleStreamHandleReader.getChanges(ChangelogStateHandleStreamImpl handle) |
CloseableIterator<StateChange> |
StateChangelogHandleReader.getChanges(Handle handle) |
CloseableIterator<StateChange> |
StateChangelogHandleStreamHandleReader.StateChangeIterator.read(StreamStateHandle handle,
long offset) |
Modifier and Type | Method and Description |
---|---|
CloseableIterator<T> |
AbstractHeapPriorityQueue.iterator()
Returns an iterator over the elements in this queue.
|
CloseableIterator<T> |
KeyGroupPartitionedPriorityQueue.iterator() |
Modifier and Type | Class and Description |
---|---|
class |
MultiStateKeyIterator<K>
An iterator for reading all keys in a state backend across multiple partitioned states.
|
Modifier and Type | Method and Description |
---|---|
CloseableIterator<Tuple2<KEY,W>> |
WindowReaderOperator.getKeysAndNamespaces(SavepointRuntimeContext ctx) |
abstract CloseableIterator<Tuple2<KEY,N>> |
StateReaderOperator.getKeysAndNamespaces(SavepointRuntimeContext ctx) |
CloseableIterator<Tuple2<KEY,VoidNamespace>> |
KeyedStateReaderOperator.getKeysAndNamespaces(SavepointRuntimeContext ctx) |
Modifier and Type | Method and Description |
---|---|
CloseableIterator<T> |
ChangelogKeyGroupedPriorityQueue.iterator() |
Modifier and Type | Method and Description |
---|---|
CloseableIterator<T> |
DataStream.collectAsync()
Sets up the collection of the elements in this
DataStream , and returns an iterator
over the collected elements that can be used to retrieve elements once the job execution has
started. |
CloseableIterator<T> |
DataStream.executeAndCollect()
Triggers the distributed execution of the streaming dataflow and returns an iterator over the
elements of the given DataStream.
|
CloseableIterator<T> |
DataStream.executeAndCollect(String jobExecutionName)
Triggers the distributed execution of the streaming dataflow and returns an iterator over the
elements of the given DataStream.
|
CloseableIterator<T> |
DataStream.Collector.getOutput()
Returns an iterator over the collected elements.
|
Modifier and Type | Class and Description |
---|---|
class |
CollectResultIterator<T>
An iterator which iterates through the results of a query job.
|
Modifier and Type | Field and Description |
---|---|
CloseableIterator<E> |
ClientAndIterator.iterator |
Constructor and Description |
---|
ClientAndIterator(JobClient client,
CloseableIterator<E> iterator) |
Modifier and Type | Method and Description |
---|---|
CloseableIterator<Row> |
TableResult.collect()
Get the result contents as a closeable row iterator.
|
Modifier and Type | Method and Description |
---|---|
CloseableIterator<Row> |
TableResultImpl.collect() |
CloseableIterator<RowData> |
TableResultInternal.collectInternal()
Returns an iterator that returns the iterator with the internal row data type.
|
CloseableIterator<RowData> |
TableResultImpl.collectInternal() |
CloseableIterator<Row> |
StaticResultProvider.toExternalIterator() |
CloseableIterator<Row> |
ResultProvider.toExternalIterator()
Returns the select result as row iterator using external data types.
|
CloseableIterator<RowData> |
StaticResultProvider.toInternalIterator() |
CloseableIterator<RowData> |
ResultProvider.toInternalIterator()
Returns the select result as row iterator using internal data types.
|
Modifier and Type | Class and Description |
---|---|
class |
StatementResult
Wrapped results for the
FetchResultsResponseBody . |
Constructor and Description |
---|
StatementResult(ResolvedSchema resultSchema,
CloseableIterator<RowData> resultProvider,
boolean isQueryResult,
ResultKind resultKind,
JobID jobID) |
StatementResult(ResolvedSchema resultSchema,
CloseableIterator<RowData> resultProvider,
boolean isQueryResult,
ResultKind resultKind,
JobID jobID,
RowDataToStringConverter toStringConverter) |
Constructor and Description |
---|
ResultStore(CloseableIterator<RowData> result,
int maxBufferSize) |
Modifier and Type | Class and Description |
---|---|
static class |
CloseableIterator.IteratorAdapter<E>
Adapter from
Iterator to CloseableIterator . |
Modifier and Type | Field and Description |
---|---|
static CloseableIterator<?> |
CloseableIterator.EMPTY_INSTANCE |
Modifier and Type | Method and Description |
---|---|
static <T> CloseableIterator<T> |
CloseableIterator.adapterForIterator(Iterator<T> iterator) |
static <T> CloseableIterator<T> |
CloseableIterator.adapterForIterator(Iterator<T> iterator,
AutoCloseable close) |
static <T> CloseableIterator<T> |
CloseableIterator.empty() |
static <T> CloseableIterator<T> |
CloseableIterator.flatten(CloseableIterator<T>... iterators) |
static <T> CloseableIterator<T> |
CloseableIterator.fromList(List<T> list,
Consumer<T> closeNotConsumed) |
static <E> CloseableIterator<E> |
CloseableIterator.ofElement(E element,
Consumer<E> closeIfNotConsumed) |
static <T> CloseableIterator<T> |
CloseableIterator.ofElements(Consumer<T> closeNotConsumed,
T... elements) |
Modifier and Type | Method and Description |
---|---|
static <T> CloseableIterator<T> |
CloseableIterator.flatten(CloseableIterator<T>... iterators) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.