Uses of Class
org.apache.flink.runtime.plugable.SerializationDelegate
-
-
Uses of SerializationDelegate in org.apache.flink.runtime.operators.shipping
Methods in org.apache.flink.runtime.operators.shipping that return types with arguments of type SerializationDelegate Modifier and Type Method Description List<RecordWriter<SerializationDelegate<T>>>OutputCollector. getWriters()List of writers that are associated with this output collectorMethods in org.apache.flink.runtime.operators.shipping with parameters of type SerializationDelegate Modifier and Type Method Description intOutputEmitter. selectChannel(SerializationDelegate<T> record)Constructor parameters in org.apache.flink.runtime.operators.shipping with type arguments of type SerializationDelegate Constructor Description OutputCollector(List<RecordWriter<SerializationDelegate<T>>> writers, org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer)Initializes the output collector with a set of writers. -
Uses of SerializationDelegate in org.apache.flink.streaming.runtime.io
Constructor parameters in org.apache.flink.streaming.runtime.io with type arguments of type SerializationDelegate Constructor Description RecordWriterOutput(RecordWriter<SerializationDelegate<StreamRecord<OUT>>> recordWriter, org.apache.flink.api.common.typeutils.TypeSerializer<OUT> outSerializer, org.apache.flink.util.OutputTag outputTag, boolean supportsUnalignedCheckpoints) -
Uses of SerializationDelegate in org.apache.flink.streaming.runtime.partitioner
Methods in org.apache.flink.streaming.runtime.partitioner with parameters of type SerializationDelegate Modifier and Type Method Description intBroadcastPartitioner. 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.intCustomPartitionerWrapper. selectChannel(SerializationDelegate<StreamRecord<T>> record)intForwardForConsecutiveHashPartitioner. selectChannel(SerializationDelegate<StreamRecord<T>> record)intForwardForUnspecifiedPartitioner. selectChannel(SerializationDelegate<StreamRecord<T>> record)intForwardPartitioner. selectChannel(SerializationDelegate<StreamRecord<T>> record)intGlobalPartitioner. selectChannel(SerializationDelegate<StreamRecord<T>> record)intKeyGroupStreamPartitioner. selectChannel(SerializationDelegate<StreamRecord<T>> record)intRebalancePartitioner. selectChannel(SerializationDelegate<StreamRecord<T>> record)intRescalePartitioner. selectChannel(SerializationDelegate<StreamRecord<T>> record)intShufflePartitioner. selectChannel(SerializationDelegate<StreamRecord<T>> record) -
Uses of SerializationDelegate in org.apache.flink.streaming.runtime.tasks
Fields in org.apache.flink.streaming.runtime.tasks with type parameters of type SerializationDelegate Modifier and Type Field Description protected RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>StreamTask. recordWriterMethods in org.apache.flink.streaming.runtime.tasks that return types with arguments of type SerializationDelegate Modifier and Type Method Description static <OUT> RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>StreamTask. createRecordWriterDelegate(StreamConfig configuration, Environment environment)Constructor parameters in org.apache.flink.streaming.runtime.tasks with type arguments of type SerializationDelegate Constructor 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)
-