接口 OperatorWrapper<T,R>
-
- 所有超级接口:
Serializable
public interface OperatorWrapper<T,R> extends Serializable
Wrappers for the given operator factory.
-
-
方法概要
所有方法 实例方法 抽象方法 修饰符和类型 方法 说明 Class<? extends org.apache.flink.streaming.api.operators.StreamOperator>getStreamOperatorClass(ClassLoader classLoader, org.apache.flink.streaming.api.operators.StreamOperatorFactory<T> operatorFactory)org.apache.flink.api.common.typeinfo.TypeInformation<R>getWrappedTypeInfo(org.apache.flink.api.common.typeinfo.TypeInformation<T> typeInfo)org.apache.flink.streaming.api.operators.StreamOperator<R>wrap(org.apache.flink.streaming.api.operators.StreamOperatorParameters<R> operatorParameters, org.apache.flink.streaming.api.operators.StreamOperatorFactory<T> operatorFactory)<KEY> org.apache.flink.api.java.functions.KeySelector<R,KEY>wrapKeySelector(org.apache.flink.api.java.functions.KeySelector<T,KEY> keySelector)org.apache.flink.util.OutputTag<R>wrapOutputTag(org.apache.flink.util.OutputTag<T> outputTag)org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<R>wrapStreamPartitioner(org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<T> streamPartitioner)
-
-
-
方法详细资料
-
wrap
org.apache.flink.streaming.api.operators.StreamOperator<R> wrap(org.apache.flink.streaming.api.operators.StreamOperatorParameters<R> operatorParameters, org.apache.flink.streaming.api.operators.StreamOperatorFactory<T> operatorFactory)
-
getStreamOperatorClass
Class<? extends org.apache.flink.streaming.api.operators.StreamOperator> getStreamOperatorClass(ClassLoader classLoader, org.apache.flink.streaming.api.operators.StreamOperatorFactory<T> operatorFactory)
-
wrapKeySelector
<KEY> org.apache.flink.api.java.functions.KeySelector<R,KEY> wrapKeySelector(org.apache.flink.api.java.functions.KeySelector<T,KEY> keySelector)
-
wrapStreamPartitioner
org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<R> wrapStreamPartitioner(org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<T> streamPartitioner)
-
wrapOutputTag
org.apache.flink.util.OutputTag<R> wrapOutputTag(org.apache.flink.util.OutputTag<T> outputTag)
-
-