org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator.getTransformation()方法的使用及代码示例

x33g5p2x  于2022-01-30 转载在 其他  
字(11.8k)|赞(0)|评价(0)|浏览(110)

本文整理了Java中org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator.getTransformation()方法的一些代码示例,展示了SingleOutputStreamOperator.getTransformation()的具体用法。这些代码示例主要来源于Github/Stackoverflow/Maven等平台,是从一些精选项目中提取出来的代码,具有较强的参考意义,能在一定程度帮忙到你。SingleOutputStreamOperator.getTransformation()方法的具体详情如下:
包路径:org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
类名称:SingleOutputStreamOperator
方法名:getTransformation

SingleOutputStreamOperator.getTransformation介绍

暂无

代码示例

代码示例来源:origin: apache/flink

public DataStreamSource(SingleOutputStreamOperator<T> operator) {
  super(operator.environment, operator.getTransformation());
  this.isParallel = true;
}

代码示例来源:origin: apache/flink

private StreamTransformation<IN> getStreamTransformation() {
  return sink2.getTransformation();
}

代码示例来源:origin: apache/flink

@Override
@PublicEvolving
public <R> SingleOutputStreamOperator<R> transform(String operatorName,
    TypeInformation<R> outTypeInfo, OneInputStreamOperator<T, R> operator) {
  SingleOutputStreamOperator<R> returnStream = super.transform(operatorName, outTypeInfo, operator);
  // inject the key selector and key type
  OneInputTransformation<T, R> transform = (OneInputTransformation<T, R>) returnStream.getTransformation();
  transform.setStateKeySelector(keySelector);
  transform.setStateKeyType(keyType);
  return returnStream;
}

代码示例来源:origin: apache/flink

/**
   * Gets the {@link DataStream} that contains the elements that are emitted from an operation
   * into the side output with the given {@link OutputTag}.
   *
   * @see org.apache.flink.streaming.api.functions.ProcessFunction.Context#output(OutputTag, Object)
   */
  public <X> DataStream<X> getSideOutput(OutputTag<X> sideOutputTag) {
    if (wasSplitApplied) {
      throw new UnsupportedOperationException("getSideOutput() and split() may not be called on the same DataStream. " +
        "As a work-around, please add a no-op map function before the split() call.");
    }

    sideOutputTag = clean(requireNonNull(sideOutputTag));

    // make a defensive copy
    sideOutputTag = new OutputTag<X>(sideOutputTag.getId(), sideOutputTag.getTypeInfo());

    TypeInformation<?> type = requestedSideOutputs.get(sideOutputTag);
    if (type != null && !type.equals(sideOutputTag.getTypeInfo())) {
      throw new UnsupportedOperationException("A side output with a matching id was " +
          "already requested with a different type. This is not allowed, side output " +
          "ids need to be unique.");
    }

    requestedSideOutputs.put(sideOutputTag, sideOutputTag.getTypeInfo());

    SideOutputTransformation<X> sideOutputTransformation = new SideOutputTransformation<>(this.getTransformation(), sideOutputTag);
    return new DataStream<>(this.getExecutionEnvironment(), sideOutputTransformation);
  }
}

代码示例来源:origin: apache/flink

private void validateStateDescriptorConfigured(SingleOutputStreamOperator<?> result) {
  OneInputTransformation<?, ?> transform = (OneInputTransformation<?, ?>) result.getTransformation();
  WindowOperator<?, ?, ?, ?, ?> op = (WindowOperator<?, ?, ?, ?, ?>) transform.getOperator();
  StateDescriptor<?, ?> descr = op.getStateDescriptor();
  // this would be the first statement to fail if state descriptors were not properly initialized
  TypeSerializer<?> serializer = descr.getSerializer();
  assertTrue(serializer instanceof KryoSerializer);
  Kryo kryo = ((KryoSerializer<?>) serializer).getKryo();
  assertTrue("serializer registration was not properly passed on",
      kryo.getSerializer(File.class) instanceof JavaSerializer);
}

代码示例来源:origin: apache/flink

private void validateListStateDescriptorConfigured(SingleOutputStreamOperator<?> result) {
    OneInputTransformation<?, ?> transform = (OneInputTransformation<?, ?>) result.getTransformation();
    WindowOperator<?, ?, ?, ?, ?> op = (WindowOperator<?, ?, ?, ?, ?>) transform.getOperator();
    StateDescriptor<?, ?> descr = op.getStateDescriptor();

    assertTrue(descr instanceof ListStateDescriptor);

    ListStateDescriptor<?> listDescr = (ListStateDescriptor<?>) descr;

    // this would be the first statement to fail if state descriptors were not properly initialized
    TypeSerializer<?> serializer = listDescr.getSerializer();
    assertTrue(serializer instanceof ListSerializer);

    TypeSerializer<?> elementSerializer = listDescr.getElementSerializer();
    assertTrue(elementSerializer instanceof KryoSerializer);

    Kryo kryo = ((KryoSerializer<?>) elementSerializer).getKryo();

    assertTrue("serializer registration was not properly passed on",
        kryo.getSerializer(File.class) instanceof JavaSerializer);
  }
}

代码示例来源:origin: apache/flink

Assert.assertEquals(-1, operator.getTransformation().getMaxParallelism());
Assert.assertEquals(-1, operator.getTransformation().getMaxParallelism());
Assert.assertEquals(42, operator.getTransformation().getMaxParallelism());
Assert.assertEquals(1, operator.getTransformation().getMaxParallelism());
Assert.assertEquals(1 << 15, operator.getTransformation().getMaxParallelism());
Assert.assertEquals(1 << 15 , operator.getTransformation().getMaxParallelism());

代码示例来源:origin: org.apache.flink/flink-streaming-java

public DataStreamSource(SingleOutputStreamOperator<T> operator) {
  super(operator.environment, operator.getTransformation());
  this.isParallel = true;
}

代码示例来源:origin: org.apache.flink/flink-streaming-java_2.10

public DataStreamSource(SingleOutputStreamOperator<T> operator) {
  super(operator.environment, operator.getTransformation());
  this.isParallel = true;
}

代码示例来源:origin: org.apache.flink/flink-streaming-java_2.11

public DataStreamSource(SingleOutputStreamOperator<T> operator) {
  super(operator.environment, operator.getTransformation());
  this.isParallel = true;
}

代码示例来源:origin: org.apache.flink/flink-streaming-java_2.11

@Override
@PublicEvolving
public <R> SingleOutputStreamOperator<R> transform(String operatorName,
    TypeInformation<R> outTypeInfo, OneInputStreamOperator<T, R> operator) {
  SingleOutputStreamOperator<R> returnStream = super.transform(operatorName, outTypeInfo, operator);
  // inject the key selector and key type
  OneInputTransformation<T, R> transform = (OneInputTransformation<T, R>) returnStream.getTransformation();
  transform.setStateKeySelector(keySelector);
  transform.setStateKeyType(keyType);
  return returnStream;
}

代码示例来源:origin: org.apache.flink/flink-streaming-java_2.10

@Override
@PublicEvolving
public <R> SingleOutputStreamOperator<R> transform(String operatorName,
    TypeInformation<R> outTypeInfo, OneInputStreamOperator<T, R> operator) {
  SingleOutputStreamOperator<R> returnStream = super.transform(operatorName, outTypeInfo, operator);
  // inject the key selector and key type
  OneInputTransformation<T, R> transform = (OneInputTransformation<T, R>) returnStream.getTransformation();
  transform.setStateKeySelector(keySelector);
  transform.setStateKeyType(keyType);
  return returnStream;
}

代码示例来源:origin: org.apache.flink/flink-streaming-java

@Override
@PublicEvolving
public <R> SingleOutputStreamOperator<R> transform(String operatorName,
    TypeInformation<R> outTypeInfo, OneInputStreamOperator<T, R> operator) {
  SingleOutputStreamOperator<R> returnStream = super.transform(operatorName, outTypeInfo, operator);
  // inject the key selector and key type
  OneInputTransformation<T, R> transform = (OneInputTransformation<T, R>) returnStream.getTransformation();
  transform.setStateKeySelector(keySelector);
  transform.setStateKeyType(keyType);
  return returnStream;
}

代码示例来源:origin: org.apache.flink/flink-streaming-java_2.10

@Override
protected DataStream<T> setConnectionType(StreamPartitioner<T> partitioner) {
  return new SingleOutputStreamOperator<>(this.getExecutionEnvironment(), new PartitionTransformation<>(this.getTransformation(), partitioner));
}

代码示例来源:origin: org.apache.flink/flink-streaming-java_2.11

/**
   * Gets the {@link DataStream} that contains the elements that are emitted from an operation
   * into the side output with the given {@link OutputTag}.
   *
   * @see org.apache.flink.streaming.api.functions.ProcessFunction.Context#output(OutputTag, Object)
   */
  public <X> DataStream<X> getSideOutput(OutputTag<X> sideOutputTag) {
    if (wasSplitApplied) {
      throw new UnsupportedOperationException("getSideOutput() and split() may not be called on the same DataStream. " +
        "As a work-around, please add a no-op map function before the split() call.");
    }

    sideOutputTag = clean(requireNonNull(sideOutputTag));

    // make a defensive copy
    sideOutputTag = new OutputTag<X>(sideOutputTag.getId(), sideOutputTag.getTypeInfo());

    TypeInformation<?> type = requestedSideOutputs.get(sideOutputTag);
    if (type != null && !type.equals(sideOutputTag.getTypeInfo())) {
      throw new UnsupportedOperationException("A side output with a matching id was " +
          "already requested with a different type. This is not allowed, side output " +
          "ids need to be unique.");
    }

    requestedSideOutputs.put(sideOutputTag, sideOutputTag.getTypeInfo());

    SideOutputTransformation<X> sideOutputTransformation = new SideOutputTransformation<>(this.getTransformation(), sideOutputTag);
    return new DataStream<>(this.getExecutionEnvironment(), sideOutputTransformation);
  }
}

代码示例来源:origin: org.apache.flink/flink-streaming-java

/**
   * Gets the {@link DataStream} that contains the elements that are emitted from an operation
   * into the side output with the given {@link OutputTag}.
   *
   * @see org.apache.flink.streaming.api.functions.ProcessFunction.Context#output(OutputTag, Object)
   */
  public <X> DataStream<X> getSideOutput(OutputTag<X> sideOutputTag) {
    if (wasSplitApplied) {
      throw new UnsupportedOperationException("getSideOutput() and split() may not be called on the same DataStream. " +
        "As a work-around, please add a no-op map function before the split() call.");
    }

    sideOutputTag = clean(requireNonNull(sideOutputTag));

    // make a defensive copy
    sideOutputTag = new OutputTag<X>(sideOutputTag.getId(), sideOutputTag.getTypeInfo());

    TypeInformation<?> type = requestedSideOutputs.get(sideOutputTag);
    if (type != null && !type.equals(sideOutputTag.getTypeInfo())) {
      throw new UnsupportedOperationException("A side output with a matching id was " +
          "already requested with a different type. This is not allowed, side output " +
          "ids need to be unique.");
    }

    requestedSideOutputs.put(sideOutputTag, sideOutputTag.getTypeInfo());

    SideOutputTransformation<X> sideOutputTransformation = new SideOutputTransformation<>(this.getTransformation(), sideOutputTag);
    return new DataStream<>(this.getExecutionEnvironment(), sideOutputTransformation);
  }
}

代码示例来源:origin: org.apache.flink/flink-streaming-java_2.10

/**
   * Gets the {@link DataStream} that contains the elements that are emitted from an operation
   * into the side output with the given {@link OutputTag}.
   *
   * @see org.apache.flink.streaming.api.functions.ProcessFunction.Context#output(OutputTag, Object)
   */
  public <X> DataStream<X> getSideOutput(OutputTag<X> sideOutputTag) {
    sideOutputTag = clean(requireNonNull(sideOutputTag));

    // make a defensive copy
    sideOutputTag = new OutputTag<X>(sideOutputTag.getId(), sideOutputTag.getTypeInfo());

    TypeInformation<?> type = requestedSideOutputs.get(sideOutputTag);
    if (type != null && !type.equals(sideOutputTag.getTypeInfo())) {
      throw new UnsupportedOperationException("A side output with a matching id was " +
          "already requested with a different type. This is not allowed, side output " +
          "ids need to be unique.");
    }

    requestedSideOutputs.put(sideOutputTag, sideOutputTag.getTypeInfo());

    SideOutputTransformation<X> sideOutputTransformation = new SideOutputTransformation<>(this.getTransformation(), sideOutputTag);
    return new DataStream<>(this.getExecutionEnvironment(), sideOutputTransformation);
  }
}

代码示例来源:origin: org.apache.flink/flink-storm

SingleOutputStreamOperator<Tuple> outStream = splitSource.select(streamId)
    .map(new SplitStreamMapper<Tuple>());
outStream.getTransformation().setOutputType(declarer.getOutputType(streamId));
outputStreams.put(streamId, outStream);

代码示例来源:origin: org.apache.flink/flink-storm

SingleOutputStreamOperator<Tuple> outStream = splitStream
    .select(outputStreamId).map(new SplitStreamMapper<Tuple>());
outStream.getTransformation().setOutputType(declarer.getOutputType(outputStreamId));
op.put(outputStreamId, outStream);

相关文章

微信公众号

最新文章

更多