Modifier and Type | Interface and Description |
---|---|
interface |
PullingAsyncDataInput<T>
Interface defining couple of essential methods for asynchronous and non blocking data polling.
|
Modifier and Type | Class and Description |
---|---|
static class |
AvailabilityProvider.AvailabilityHelper
A availability implementation for providing the helpful functions of resetting the
available/unavailable states.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<?> |
AvailabilityProvider.AvailabilityHelper.and(AvailabilityProvider other) |
CompletableFuture<?> |
AvailabilityProvider.AvailabilityHelper.or(AvailabilityProvider other) |
Modifier and Type | Interface and Description |
---|---|
interface |
RecordWriterDelegate<T extends IOReadableWritable>
The record writer delegate provides the availability function for task processor, and it might
represent a single
RecordWriter or multiple RecordWriter instances in specific
implementations. |
interface |
ResultPartitionWriter
A record-oriented runtime result writer API for producing results.
|
Modifier and Type | Class and Description |
---|---|
class |
BroadcastRecordWriter<T extends IOReadableWritable>
A special record-oriented runtime result writer only for broadcast mode.
|
class |
ChannelSelectorRecordWriter<T extends IOReadableWritable>
A regular record-oriented runtime result writer.
|
class |
MultipleRecordWriters<T extends IOReadableWritable>
The specific delegate implementation for the multiple outputs case.
|
class |
NonRecordWriter<T extends IOReadableWritable>
The specific delegate implementation for the non output case like sink task.
|
class |
RecordWriter<T extends IOReadableWritable>
An abstract record-oriented runtime result writer.
|
class |
SingleRecordWriter<T extends IOReadableWritable>
The specific delegate implementation for the single output case.
|
Modifier and Type | Interface and Description |
---|---|
interface |
BufferPool
A dynamically sized buffer pool.
|
interface |
BufferProvider
A buffer provider to request buffers from in a synchronous or asynchronous fashion.
|
Modifier and Type | Class and Description |
---|---|
class |
NetworkBufferPool
The NetworkBufferPool is a fixed size pool of
MemorySegment instances for the network
stack. |
Modifier and Type | Class and Description |
---|---|
class |
BoundedBlockingResultPartition
A output data result of an individual task (one partition of an intermediate result), produced
and communicated in a batch manner: The result must be produced completely before it can be
consumed.
|
class |
BufferWritingResultPartition
A
ResultPartition which writes buffers directly to ResultSubpartition s. |
class |
PipelinedResultPartition
A result output of a task, pipelined (streamed) to the receivers.
|
class |
ResultPartition
A result partition for data produced by a single task.
|
class |
SortMergeResultPartition
SortMergeResultPartition appends records and events to SortBuffer and after the
SortBuffer is full, all data in the SortBuffer will be copied and spilled to a
PartitionedFile in subpartition index order sequentially. |
Modifier and Type | Class and Description |
---|---|
class |
IndexedInputGate
An
InputGate with a specific index. |
class |
InputGate
An input gate consumes one or more partitions of a single produced intermediate result.
|
class |
SingleInputGate
An input gate consumes one or more partitions of a single produced intermediate result.
|
class |
UnionInputGate
Input gate wrapper to union the input from multiple input gates.
|
Modifier and Type | Class and Description |
---|---|
class |
InputGateWithMetrics
This class wraps
InputGate provided by shuffle service and it is mainly used for
increasing general input metrics from TaskIOMetricGroup . |
Modifier and Type | Class and Description |
---|---|
class |
SourceOperator<OUT,SplitT extends SourceSplit>
Base source operator only used for integrating the source reader which is proposed by FLIP-27.
|
Modifier and Type | Class and Description |
---|---|
class |
MultiInputSortingDataInput<IN,K>
An input that wraps an underlying input and sorts the incoming records.
|
class |
SortingDataInput<T,K>
A
StreamTaskInput which sorts in the incoming records from a chained input. |
Modifier and Type | Interface and Description |
---|---|
interface |
PushingAsyncDataInput<T>
The variant of
PullingAsyncDataInput that is defined for handling both network input and
source input in a unified way via PushingAsyncDataInput.emitNext(DataOutput) instead of returning Optional.empty() via PullingAsyncDataInput.pollNext() . |
interface |
StreamInputProcessor
Interface for processing records by
StreamTask . |
interface |
StreamTaskInput<T>
Basic interface for inputs of stream operators.
|
Modifier and Type | Class and Description |
---|---|
class |
CheckpointedInputGate
The
CheckpointedInputGate uses CheckpointBarrierHandler to handle incoming CheckpointBarrier from the InputGate . |
class |
StreamMultipleInputProcessor
Input processor for
MultipleInputStreamOperator . |
class |
StreamOneInputProcessor<IN>
Input reader for
OneInputStreamTask . |
class |
StreamTaskExternallyInducedSourceInput<T>
A subclass of
StreamTaskSourceInput for ExternallyInducedSourceReader . |
class |
StreamTaskNetworkInput<T>
Implementation of
StreamTaskInput that wraps an input from network taken from CheckpointedInputGate . |
class |
StreamTaskSourceInput<T>
Implementation of
StreamTaskInput that reads data from the SourceOperator and
returns the InputStatus to indicate whether the source state is available, unavailable or
finished. |
class |
StreamTwoInputProcessor<IN1,IN2>
Input reader for
TwoInputStreamTask . |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.