Package org.apache.flink.api.common.typeinfo

Examples of org.apache.flink.api.common.typeinfo.NothingTypeInfo


  // --------------------------------------------------------------------------------------------
 
  protected GenericDataSinkBase<T> translateToDataFlow(Operator<T> input) {
    // select the name (or create a default one)
    String name = this.name != null ? this.name : this.format.toString();
    GenericDataSinkBase<T> sink = new GenericDataSinkBase<T>(this.format, new UnaryOperatorInformation<T, Nothing>(this.type, new NothingTypeInfo()), name);
    // set input
    sink.setInput(input);
    // set dop
    if(this.dop > 0) {
      // use specified dop
View Full Code Here


  }
 
  public static class SingleRootJoiner extends TwoInputNode {
   
    SingleRootJoiner() {
      super(new NoOpBinaryUdfOp<Nothing>(new NothingTypeInfo()));
     
      setDegreeOfParallelism(1);
    }
View Full Code Here

* candidate selection works correctly with nodes that have multiple outputs is transparently reused.
*/
public class SinkJoiner extends TwoInputNode {
 
  public SinkJoiner(OptimizerNode input1, OptimizerNode input2) {
    super(new NoOpBinaryUdfOp<Nothing>(new NothingTypeInfo()));

    PactConnection conn1 = new PactConnection(input1, this);
    PactConnection conn2 = new PactConnection(input2, this);
   
    this.input1 = conn1;
View Full Code Here

   *
   * @param f The {@link OutputFormat} implementation used to sink the data.
   * @param name The given name for the sink, used in plans, logs and progress messages.
   */
  public GenericDataSink(OutputFormat<Record> f, String name) {
    super(f, new UnaryOperatorInformation<Record, Nothing>(new RecordTypeInfo(), new NothingTypeInfo()), name);
  }
View Full Code Here

   * @param f The {@link OutputFormat} implementation used to sink the data.
   * @param name The given name for the sink, used in plans, logs and progress messages.
   */
  public GenericDataSink(Class<? extends OutputFormat<Record>> f, String name) {
    super(new UserCodeClassWrapper<OutputFormat<Record>>(f),
        new UnaryOperatorInformation<Record, Nothing>(new RecordTypeInfo(), new NothingTypeInfo()), name);
  }
View Full Code Here

   * @param f The {@link FileOutputFormat} implementation used to encode the data.
   * @param filePath The path to the file to write the contents to.
   * @param name The given name for the sink, used in plans, logs and progress messages.
   */
  public FileDataSink(FileOutputFormat<Record> f, String filePath, String name) {
    super(f,  new UnaryOperatorInformation<Record, Nothing>(new RecordTypeInfo(), new NothingTypeInfo()), filePath, name);
  }
View Full Code Here

   * @param filePath The path to the file to write the contents to.
   * @param name The given name for the sink, used in plans, logs and progress messages.
   */
  public FileDataSink(Class<? extends FileOutputFormat<Record>> f, String filePath, String name) {
    super(new UserCodeClassWrapper<FileOutputFormat<Record>>(f),
        new UnaryOperatorInformation<Record, Nothing>(new RecordTypeInfo(), new NothingTypeInfo()),
        filePath, name);
  }
View Full Code Here

TOP

Related Classes of org.apache.flink.api.common.typeinfo.NothingTypeInfo

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.