Package | Description |
---|---|
org.apache.flink.runtime.operators.shipping | |
org.apache.flink.streaming.runtime.io | |
org.apache.flink.streaming.runtime.partitioner | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
org.apache.flink.table.runtime.partitioner |
Modifier and Type | Method and Description |
---|---|
List<RecordWriter<SerializationDelegate<T>>> |
OutputCollector.getWriters()
List of writers that are associated with this output collector
|
Modifier and Type | Method and Description |
---|---|
int |
OutputEmitter.selectChannel(SerializationDelegate<T> record) |
Constructor and Description |
---|
OutputCollector(List<RecordWriter<SerializationDelegate<T>>> writers,
TypeSerializer<T> serializer)
Initializes the output collector with a set of writers.
|
Constructor and Description |
---|
RecordWriterOutput(RecordWriter<SerializationDelegate<StreamRecord<OUT>>> recordWriter,
TypeSerializer<OUT> outSerializer,
OutputTag outputTag,
boolean supportsUnalignedCheckpoints) |
Modifier and Type | Method and Description |
---|---|
int |
GlobalPartitioner.selectChannel(SerializationDelegate<StreamRecord<T>> record) |
int |
BroadcastPartitioner.selectChannel(SerializationDelegate<StreamRecord<T>> record)
Note: Broadcast mode could be handled directly for all the output channels in record writer,
so it is no need to select channels via this method.
|
int |
CustomPartitionerWrapper.selectChannel(SerializationDelegate<StreamRecord<T>> record) |
int |
ForwardForConsecutiveHashPartitioner.selectChannel(SerializationDelegate<StreamRecord<T>> record) |
int |
ShufflePartitioner.selectChannel(SerializationDelegate<StreamRecord<T>> record) |
int |
RescalePartitioner.selectChannel(SerializationDelegate<StreamRecord<T>> record) |
int |
RebalancePartitioner.selectChannel(SerializationDelegate<StreamRecord<T>> record) |
int |
KeyGroupStreamPartitioner.selectChannel(SerializationDelegate<StreamRecord<T>> record) |
int |
ForwardForUnspecifiedPartitioner.selectChannel(SerializationDelegate<StreamRecord<T>> record) |
int |
ForwardPartitioner.selectChannel(SerializationDelegate<StreamRecord<T>> record) |
Modifier and Type | Method and Description |
---|---|
static <OUT> RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> |
StreamTask.createRecordWriterDelegate(StreamConfig configuration,
Environment environment) |
Constructor and Description |
---|
FinishedOperatorChain(StreamTask<OUT,OP> containingTask,
RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> recordWriterDelegate) |
OperatorChain(StreamTask<OUT,OP> containingTask,
RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> recordWriterDelegate) |
RegularOperatorChain(StreamTask<OUT,OP> containingTask,
RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>> recordWriterDelegate) |
Modifier and Type | Method and Description |
---|---|
int |
BinaryHashPartitioner.selectChannel(SerializationDelegate<StreamRecord<RowData>> record) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.