org.apache.flink.annotation.Public.<init>()方法的使用及代码示例

x33g5p2x  于2022-01-26 转载在 其他  
字(6.9k)|赞(0)|评价(0)|浏览(123)

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

Public.<init>介绍

暂无

代码示例

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

/**
 * Basic value interface for types that act as serializable values.
 * <p>
 * This interface extends {@link IOReadableWritable} and requires to implement
 * the serialization of its value.
 * 
 * @see org.apache.flink.core.io.IOReadableWritable
 */
@Public
public interface Value extends IOReadableWritable, Serializable {
}

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

/**
   * A {@link DataSet} that acts as a placeholder for the workset during the iteration.
   *
   * @param <WT> The data type of the elements in the workset.
   */
  @Public
  public static class WorksetPlaceHolder<WT> extends DataSet<WT>{
    private WorksetPlaceHolder(ExecutionEnvironment context, TypeInformation<WT> type) {
      super(context, type);
    }
  }
}

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

/**
 *
 * @param <IN> The type of the data set consumed by this operator.
 * @param <OUT> The type of the data set produced by this operator.
 */
@Public
public interface CustomUnaryOperation<IN, OUT> {

  void setInput(DataSet<IN> inputData);

  DataSet<OUT> createResult();
}

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

/**
 * A {@link org.apache.flink.api.common.functions.RichFunction} version of {@link SinkFunction}.
 */
@Public
public abstract class RichSinkFunction<IN> extends AbstractRichFunction implements SinkFunction<IN> {

  private static final long serialVersionUID = 1L;
}

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

/**
 * A {@link org.apache.flink.api.common.functions.RichFunction} version of
 * {@link AllWindowFunction}.
 */
@Public
public abstract class RichAllWindowFunction<IN, OUT, W extends Window> extends AbstractRichFunction implements AllWindowFunction<IN, OUT, W> {
  private static final long serialVersionUID = 1L;
}

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

/**
 * The base interface for all user-defined functions.
 *
 * <p>This interface is empty in order to allow extending interfaces to
 * be SAM (single abstract method) interfaces that can be implemented via Java 8 lambdas.</p>
 */
@Public
public interface Function extends java.io.Serializable {
}

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

/**
 * This interface acts as a marker for input formats for inputs which cannot be split.
 * Data sources with a non-parallel input formats are always executed with a parallelism
 * of one.
 * 
 * @see InputFormat
 */
@Public
public interface NonParallelInput {
}

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

/**
 * A type for (synthetic) operators that do not output data. For example, data sinks.
 */
@Public
public class Nothing {
  private Nothing() {}
}

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

@Public
public interface ResettableValue<T extends Value> extends Value {

  /**
   * Sets the encapsulated value to another value 
   *
   * @param value the new value of the encapsulated value
   */
  void setValue(T value);
}

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

/**
 * Similar to Accumulator, but the type of items to add and the result value
 * must be the same.
 */
@Public
public interface SimpleAccumulator<T extends Serializable> extends Accumulator<T,T> {}

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

/**
 * Factory class for execution environments.
 */
@Public
public interface ExecutionEnvironmentFactory {

  /**
   * Creates an ExecutionEnvironment from this factory.
   *
   * @return An ExecutionEnvironment.
   */
  ExecutionEnvironment createExecutionEnvironment();
}

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

/**
 * {@link OutputFormat}s may implement this interface to run a cleanup hook when the execution is not successful.
 */
@Public
public interface CleanupWhenUnsuccessful {
  
  /**
   * Hook that is called upon an unsuccessful execution.
   * 
   * @throws Exception The method may forward exceptions when the cleanup fails.
   */
  void tryCleanupOnError() throws Exception;
}

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

/**
 * A stream sink that ignores all elements.
 *
 * @param <T> The type of elements received by the sink.
 */
@Public
public class DiscardingSink<T> implements SinkFunction<T> {

  private static final long serialVersionUID = 1L;

  @Override
  public void invoke(T value) {}
}

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

/**
 * A Join transformation that needs to be finished by specifying either a
 * {@link JoinFunction} or a {@link FlatJoinFunction} before it can be used as an input
 * to other operators.
 *
 * @param <I1> The type of the first input DataSet of the Join transformation.
 * @param <I2> The type of the second input DataSet of the Join transformation.
 */
@Public
public interface JoinFunctionAssigner<I1, I2> {

  <R> JoinOperator<I1, I2, R> with(JoinFunction<I1, I2, R> joinFunction);

  <R> JoinOperator<I1, I2, R> with(FlatJoinFunction<I1, I2, R> joinFunction);

}

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

/**
 * Stores elements by serializing them with their regular serialization/deserialization functionality.
 * 
 * @see SerializedInputFormat
 */
@Public
public class SerializedOutputFormat<T extends IOReadableWritable> extends BinaryOutputFormat<T> {
  
  private static final long serialVersionUID = 1L;

  @Override
  protected void serialize(T record, DataOutputView dataOutputView) throws IOException {
    record.write(dataOutputView);
  }
}

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

/**
 * This interface may be implemented by {@link OutputFormat}s to have the master finalize them globally.
 * 
 */
@Public
public interface FinalizeOnMaster {

  /**
   * The method is invoked on the master (JobManager) after all (parallel) instances of an OutputFormat finished.
   * 
   * @param parallelism The parallelism with which the format or functions was run.
   * @throws IOException The finalization may throw exceptions, which may cause the job to abort.
   */
  void finalizeGlobal(int parallelism) throws IOException;
}

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

/**
 * A builder class for {@link Tuple0}.
 */
@Public
public class Tuple0Builder {

  private List<Tuple0> tuples = new ArrayList<Tuple0>();

  public Tuple0Builder add() {
    tuples.add(Tuple0.INSTANCE);
    return this;
  }

  public Tuple0[] build() {
    return tuples.toArray(new Tuple0[tuples.size()]);
  }

}

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

/**
 * Rich variant of the {@link FilterFunction}. As a {@link RichFunction}, it gives access to the
 * {@link org.apache.flink.api.common.functions.RuntimeContext} and provides setup and teardown methods:
 * {@link RichFunction#open(org.apache.flink.configuration.Configuration)} and
 * {@link RichFunction#close()}.
 *
 * @param <T> The type of the filtered elements.
 */
@Public
public abstract class RichFilterFunction<T> extends AbstractRichFunction implements FilterFunction<T> {

  private static final long serialVersionUID = 1L;

  @Override
  public abstract boolean filter(T value) throws Exception;
}

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

/**
 * Reads elements by deserializing them with their regular serialization/deserialization functionality.
 * 
 * @see SerializedOutputFormat
 */
@Public
public class SerializedInputFormat<T extends IOReadableWritable> extends BinaryInputFormat<T> {

  private static final long serialVersionUID = 1L;

  @Override
  protected T deserialize(T reuse, DataInputView dataInput) throws IOException {
    reuse.read(dataInput);
    return reuse;
  }
}

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

/**
 * An exception, indicating that an {@link java.lang.Iterable} can only be traversed once, but has been attempted
 * to traverse an additional time.
 */
@Public
public class TraversableOnceException extends RuntimeException {

  private static final long serialVersionUID = 7636881584773577290L;

  /**
   * Creates a new exception with a default message.
   */
  public TraversableOnceException() {
    super("The Iterable can be iterated over only once. Only the first call to 'iterator()' will succeed.");
  }
}

相关文章

Public类方法