IN1 - IN2 - OUT - public class PythonCoGroup<IN1,IN2,OUT>
extends org.apache.flink.api.common.functions.RichCoGroupFunction<IN1,IN2,OUT>
implements org.apache.flink.api.java.typeutils.ResultTypeQueryable<OUT>
| Constructor and Description |
|---|
PythonCoGroup(org.apache.flink.configuration.Configuration config,
int envID,
int setID,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInformation) |
| Modifier and Type | Method and Description |
|---|---|
void |
close()
Closes this function.
|
void |
coGroup(Iterable<IN1> first,
Iterable<IN2> second,
org.apache.flink.util.Collector<OUT> out)
Calls the external python function.
|
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> |
getProducedType() |
void |
open(org.apache.flink.configuration.Configuration config)
Opens this function.
|
public PythonCoGroup(org.apache.flink.configuration.Configuration config,
int envID,
int setID,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInformation)
public void open(org.apache.flink.configuration.Configuration config)
throws IOException
open in interface org.apache.flink.api.common.functions.RichFunctionopen in class org.apache.flink.api.common.functions.AbstractRichFunctionconfig - configurationIOExceptionpublic final void coGroup(Iterable<IN1> first, Iterable<IN2> second, org.apache.flink.util.Collector<OUT> out) throws Exception
public void close()
throws IOException
close in interface org.apache.flink.api.common.functions.RichFunctionclose in class org.apache.flink.api.common.functions.AbstractRichFunctionIOExceptionCopyright © 2014–2018 The Apache Software Foundation. All rights reserved.