Search in sources :

Example 1 with InputTypeConfigurable

use of org.apache.flink.api.java.typeutils.InputTypeConfigurable in project flink by apache.

the class StreamGraph method addOperator.

public <IN, OUT> void addOperator(Integer vertexID, String slotSharingGroup, StreamOperator<OUT> operatorObject, TypeInformation<IN> inTypeInfo, TypeInformation<OUT> outTypeInfo, String operatorName) {
    if (operatorObject instanceof StoppableStreamSource) {
        addNode(vertexID, slotSharingGroup, StoppableSourceStreamTask.class, operatorObject, operatorName);
    } else if (operatorObject instanceof StreamSource) {
        addNode(vertexID, slotSharingGroup, SourceStreamTask.class, operatorObject, operatorName);
    } else {
        addNode(vertexID, slotSharingGroup, OneInputStreamTask.class, operatorObject, operatorName);
    }
    TypeSerializer<IN> inSerializer = inTypeInfo != null && !(inTypeInfo instanceof MissingTypeInfo) ? inTypeInfo.createSerializer(executionConfig) : null;
    TypeSerializer<OUT> outSerializer = outTypeInfo != null && !(outTypeInfo instanceof MissingTypeInfo) ? outTypeInfo.createSerializer(executionConfig) : null;
    setSerializers(vertexID, inSerializer, null, outSerializer);
    if (operatorObject instanceof OutputTypeConfigurable && outTypeInfo != null) {
        @SuppressWarnings("unchecked") OutputTypeConfigurable<OUT> outputTypeConfigurable = (OutputTypeConfigurable<OUT>) operatorObject;
        // sets the output type which must be know at StreamGraph creation time
        outputTypeConfigurable.setOutputType(outTypeInfo, executionConfig);
    }
    if (operatorObject instanceof InputTypeConfigurable) {
        InputTypeConfigurable inputTypeConfigurable = (InputTypeConfigurable) operatorObject;
        inputTypeConfigurable.setInputType(inTypeInfo, executionConfig);
    }
    if (LOG.isDebugEnabled()) {
        LOG.debug("Vertex: {}", vertexID);
    }
}
Also used : MissingTypeInfo(org.apache.flink.api.java.typeutils.MissingTypeInfo) OutputTypeConfigurable(org.apache.flink.streaming.api.operators.OutputTypeConfigurable) OneInputStreamTask(org.apache.flink.streaming.runtime.tasks.OneInputStreamTask) StoppableStreamSource(org.apache.flink.streaming.api.operators.StoppableStreamSource) StreamSource(org.apache.flink.streaming.api.operators.StreamSource) InputTypeConfigurable(org.apache.flink.api.java.typeutils.InputTypeConfigurable) StoppableSourceStreamTask(org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask) SourceStreamTask(org.apache.flink.streaming.runtime.tasks.SourceStreamTask) StoppableStreamSource(org.apache.flink.streaming.api.operators.StoppableStreamSource)

Example 2 with InputTypeConfigurable

use of org.apache.flink.api.java.typeutils.InputTypeConfigurable in project flink by apache.

the class OutputFormatSinkFunction method setInputType.

@Override
public void setInputType(TypeInformation<?> type, ExecutionConfig executionConfig) {
    if (format instanceof InputTypeConfigurable) {
        InputTypeConfigurable itc = (InputTypeConfigurable) format;
        itc.setInputType(type, executionConfig);
    }
}
Also used : InputTypeConfigurable(org.apache.flink.api.java.typeutils.InputTypeConfigurable)

Example 3 with InputTypeConfigurable

use of org.apache.flink.api.java.typeutils.InputTypeConfigurable in project flink by apache.

the class CommonExecSink method createSinkFunctionTransformation.

private Transformation<?> createSinkFunctionTransformation(SinkFunction<RowData> sinkFunction, StreamExecutionEnvironment env, Transformation<RowData> inputTransformation, int rowtimeFieldIndex, TransformationMetadata transformationMetadata, int sinkParallelism) {
    final SinkOperator operator = new SinkOperator(env.clean(sinkFunction), rowtimeFieldIndex);
    if (sinkFunction instanceof InputTypeConfigurable) {
        ((InputTypeConfigurable) sinkFunction).setInputType(getInputTypeInfo(), env.getConfig());
    }
    final Transformation<?> transformation = new LegacySinkTransformation<>(inputTransformation, transformationMetadata.getName(), SimpleOperatorFactory.of(operator), sinkParallelism);
    transformationMetadata.fill(transformation);
    return transformation;
}
Also used : SinkOperator(org.apache.flink.table.runtime.operators.sink.SinkOperator) LegacySinkTransformation(org.apache.flink.streaming.api.transformations.LegacySinkTransformation) InputTypeConfigurable(org.apache.flink.api.java.typeutils.InputTypeConfigurable)

Aggregations

InputTypeConfigurable (org.apache.flink.api.java.typeutils.InputTypeConfigurable)3 MissingTypeInfo (org.apache.flink.api.java.typeutils.MissingTypeInfo)1 OutputTypeConfigurable (org.apache.flink.streaming.api.operators.OutputTypeConfigurable)1 StoppableStreamSource (org.apache.flink.streaming.api.operators.StoppableStreamSource)1 StreamSource (org.apache.flink.streaming.api.operators.StreamSource)1 LegacySinkTransformation (org.apache.flink.streaming.api.transformations.LegacySinkTransformation)1 OneInputStreamTask (org.apache.flink.streaming.runtime.tasks.OneInputStreamTask)1 SourceStreamTask (org.apache.flink.streaming.runtime.tasks.SourceStreamTask)1 StoppableSourceStreamTask (org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask)1 SinkOperator (org.apache.flink.table.runtime.operators.sink.SinkOperator)1