JobVertex.<init>
Code IndexAdd Codota to your IDE (free)

Best Java code snippets using org.apache.flink.runtime.jobgraph.JobVertex.<init> (Showing top 20 results out of 315)

Refine search

  • JobVertex.setInvokableClass
  • Common ways to obtain JobVertex
private void myMethod () {
JobVertex j =
  • String name;new JobVertex(name)
  • JobGraphGenerator.TaskInChain jobGraphGeneratorTaskInChain;jobGraphGeneratorTaskInChain.getContainingVertex()
  • JobGraphGenerator jobGraphGenerator;Object key;jobGraphGenerator.vertices.get(key)
  • Smart code suggestions by Codota
}
origin: apache/flink

private static JobGraph getWorkingJobGraph() {
  final JobVertex jobVertex = new JobVertex("Working job vertex.");
  jobVertex.setInvokableClass(NoOpInvokable.class);
  return new JobGraph("Working testing job", jobVertex);
}
origin: apache/flink

  taskConfig.setStubWrapper(new UserCodeObjectWrapper<Object>(streamNode.getInputFormat()));
} else {
  jobVertex = new JobVertex(
      chainedNames.get(streamNodeId),
      jobVertexId,
jobVertex.setInvokableClass(streamNode.getJobVertexClass());
origin: apache/flink

final JobID jobID = new JobID();
final JobVertex imalock = new JobVertex("imalock");
imalock.setInvokableClass(SemaphoreInvokable.class);
origin: apache/flink

@Nonnull
private JobGraph createJobGraph(long delay, int parallelism) throws IOException {
  SlotSharingGroup slotSharingGroup = new SlotSharingGroup();
  final JobVertex source = new JobVertex("source");
  source.setInvokableClass(OneTimeFailingInvokable.class);
  source.setParallelism(parallelism);
  source.setSlotSharingGroup(slotSharingGroup);
  final JobVertex sink = new JobVertex("sink");
  sink.setInvokableClass(NoOpInvokable.class);
  sink.setParallelism(parallelism);
  sink.setSlotSharingGroup(slotSharingGroup);
  sink.connectNewDataSetAsInput(source, DistributionPattern.POINTWISE, ResultPartitionType.PIPELINED);
  JobGraph jobGraph = new JobGraph(source, sink);
  jobGraph.setScheduleMode(ScheduleMode.EAGER);
  ExecutionConfig executionConfig = new ExecutionConfig();
  executionConfig.setRestartStrategy(RestartStrategies.fixedDelayRestart(1, delay));
  jobGraph.setExecutionConfig(executionConfig);
  return jobGraph;
}
origin: apache/flink

headVertex.setInvokableClass(IterationHeadTask.class);
headConfig = new TaskConfig(headVertex.getConfiguration());
toReturn = null;
headVertex = new JobVertex("PartialSolution ("+iteration.getNodeName()+")");
headVertex.setResources(iteration.getMinResources(), iteration.getPreferredResources());
headVertex.setInvokableClass(IterationHeadTask.class);
headConfig = new TaskConfig(headVertex.getConfiguration());
headConfig.setDriver(NoOpDriver.class);
origin: apache/flink

headVertex.setInvokableClass(IterationHeadTask.class);
headConfig = new TaskConfig(headVertex.getConfiguration());
toReturn = null;
headVertex = new JobVertex("IterationHead("+iteration.getNodeName()+")");
headVertex.setResources(iteration.getMinResources(), iteration.getPreferredResources());
headVertex.setInvokableClass(IterationHeadTask.class);
headConfig = new TaskConfig(headVertex.getConfiguration());
headConfig.setDriver(NoOpDriver.class);
origin: apache/flink

SlotSharingGroup sharingGroup = new SlotSharingGroup();
JobVertex producer = new JobVertex("Speed Test Producer");
jobGraph.addVertex(producer);
producer.setSlotSharingGroup(sharingGroup);
producer.setInvokableClass(SpeedTestProducer.class);
producer.setParallelism(numSubtasks);
producer.getConfiguration().setInteger(DATA_VOLUME_GB_CONFIG_KEY, dataVolumeGb);
  forwarder = new JobVertex("Speed Test Forwarder");
  jobGraph.addVertex(forwarder);
  forwarder.setSlotSharingGroup(sharingGroup);
  forwarder.setInvokableClass(SpeedTestForwarder.class);
  forwarder.setParallelism(numSubtasks);
JobVertex consumer = new JobVertex("Speed Test Consumer");
jobGraph.addVertex(consumer);
consumer.setSlotSharingGroup(sharingGroup);
consumer.setInvokableClass(SpeedTestConsumer.class);
consumer.setParallelism(numSubtasks);
consumer.getConfiguration().setBoolean(IS_SLOW_RECEIVER_CONFIG_KEY, isSlowReceiver);
origin: apache/flink

} else {
  vertex = new JobVertex(taskName);
  vertex.setResources(node.getMinResources(), node.getPreferredResources());
  vertex.setInvokableClass((this.currentIteration != null && node.isOnDynamicPath()) ? IterationIntermediateTask.class : BatchTask.class);
origin: apache/flink

final JobVertex sender = new JobVertex("Sender");
sender.setParallelism(2);
sender.setInvokableClass(BlockingInvokable.class);
origin: apache/flink

final JobVertex sync = new JobVertex("Sync (" + bulkNode.getNodeName() + ")");
sync.setResources(bulkNode.getMinResources(), bulkNode.getPreferredResources());
sync.setInvokableClass(IterationSynchronizationSinkTask.class);
sync.setParallelism(1);
sync.setMaxParallelism(1);
  rootOfStepFunctionVertex.setInvokableClass(IterationTailTask.class);
  rootOfTerminationCriterionVertex.setInvokableClass(IterationTailTask.class);
origin: apache/flink

final ClusterClient<?> client = cluster.getClusterClient();
final JobVertex vertex = new JobVertex("Blocking vertex");
vertex.setInvokableClass(BlockingNoOpInvokable.class);
vertex.setParallelism(1);
origin: apache/flink

private JobVertex createDualInputVertex(DualInputPlanNode node) throws CompilerException {
  final String taskName = node.getNodeName();
  final DriverStrategy ds = node.getDriverStrategy();
  final JobVertex vertex = new JobVertex(taskName);
  final TaskConfig config = new TaskConfig(vertex.getConfiguration());
  vertex.setResources(node.getMinResources(), node.getPreferredResources());
  vertex.setInvokableClass( (this.currentIteration != null && node.isOnDynamicPath()) ? IterationIntermediateTask.class : BatchTask.class);
  
  // set user code
  config.setStubWrapper(node.getProgramOperator().getUserCodeWrapper());
  config.setStubParameters(node.getProgramOperator().getParameters());
  
  // set the driver strategy
  config.setDriver(ds.getDriverClass());
  config.setDriverStrategy(ds);
  if (node.getComparator1() != null) {
    config.setDriverComparator(node.getComparator1(), 0);
  }
  if (node.getComparator2() != null) {
    config.setDriverComparator(node.getComparator2(), 1);
  }
  if (node.getPairComparator() != null) {
    config.setDriverPairComparator(node.getPairComparator());
  }
  
  // assign memory, file-handles, etc.
  assignDriverResources(node, config);
  return vertex;
}
origin: apache/flink

JobVertex sender = new JobVertex("sender");
JobVertex receiver = new JobVertex("receiver");
sender.setInvokableClass(Tasks.Sender.class);
receiver.setInvokableClass(Tasks.BlockingOnceReceiver.class);
origin: apache/flink

final JobVertex sender = new JobVertex("Sender");
sender.setParallelism(2);
sender.setInvokableClass(BlockingInvokable.class);
origin: apache/flink

final JobVertex sync = new JobVertex("Sync (" + iterNode.getNodeName() + ")");
sync.setResources(iterNode.getMinResources(), iterNode.getPreferredResources());
sync.setInvokableClass(IterationSynchronizationSinkTask.class);
sync.setParallelism(1);
sync.setMaxParallelism(1);
    nextWorksetVertex.setInvokableClass(IterationTailTask.class);
    solutionDeltaVertex.setInvokableClass(IterationTailTask.class);
origin: apache/flink

JobVertex blockingVertex = new JobVertex("Blocking vertex");
blockingVertex.setInvokableClass(BlockingNoOpInvokable.class);
JobGraph jobGraph = new JobGraph(blockingVertex);
origin: uber/AthenaX

 static JobGraph trivialJobGraph() {
  JobGraph g = new JobGraph();
  JobVertex v = new JobVertex("1");
  v.setInvokableClass(DummyInvokable.class);
  g.addVertex(v);
  return g;
 }
}
origin: org.apache.flink/flink-streaming-java_2.10

  taskConfig.setStubWrapper(new UserCodeObjectWrapper<Object>(streamNode.getInputFormat()));
} else {
  jobVertex = new JobVertex(
      chainedNames.get(streamNodeId),
      jobVertexId,
jobVertex.setInvokableClass(streamNode.getJobVertexClass());
origin: org.apache.flink/flink-streaming-java_2.11

  taskConfig.setStubWrapper(new UserCodeObjectWrapper<Object>(streamNode.getInputFormat()));
} else {
  jobVertex = new JobVertex(
      chainedNames.get(streamNodeId),
      jobVertexId,
jobVertex.setInvokableClass(streamNode.getJobVertexClass());
origin: org.apache.flink/flink-streaming-java

  taskConfig.setStubWrapper(new UserCodeObjectWrapper<Object>(streamNode.getInputFormat()));
} else {
  jobVertex = new JobVertex(
      chainedNames.get(streamNodeId),
      jobVertexId,
jobVertex.setInvokableClass(streamNode.getJobVertexClass());
org.apache.flink.runtime.jobgraphJobVertex<init>

Javadoc

Constructs a new job vertex and assigns it with the given name.

Popular methods of JobVertex

  • getConfiguration
    Returns the vertex's configuration object which can be used to pass custom settings to the task at r
  • getParallelism
    Gets the parallelism of the task.
  • getName
    Returns the name of the vertex.
  • setParallelism
    Sets the parallelism for the task.
  • setInvokableClass
  • setMaxParallelism
    Sets the maximum parallelism for the task.
  • getID
    Returns the ID of this job vertex.
  • isInputVertex
  • connectNewDataSetAsInput
  • getOperatorDescription
  • getOperatorName
  • getOperatorPrettyName
  • getOperatorName,
  • getOperatorPrettyName,
  • getResultOptimizerProperties,
  • setResources,
  • setSlotSharingGroup,
  • getMinResources,
  • updateCoLocationGroup,
  • getPreferredResources,
  • getProducedDataSets

Popular in Java

  • Making http requests using okhttp
  • getSystemService (Context)
  • findViewById (Activity)
  • setScale (BigDecimal)
    Returns a BigDecimal whose scale is the specified value, and whose value is numerically equal to thi
  • Menu (java.awt)
  • BufferedImage (java.awt.image)
    The BufferedImage subclass describes an java.awt.Image with an accessible buffer of image data. All
  • InetAddress (java.net)
    An Internet Protocol (IP) address. This can be either an IPv4 address or an IPv6 address, and in pra
  • Date (java.sql)
    A class which can consume and produce dates in SQL Date format. Dates are represented in SQL as yyyy
  • ResourceBundle (java.util)
    ResourceBundle is an abstract class which is the superclass of classes which provide Locale-specifi
  • BlockingQueue (java.util.concurrent)
    A java.util.Queue that additionally supports operations that wait for the queue to become non-empty

For IntelliJ IDEA,
Android Studio or Eclipse

  • Search for JavaScript code betaCodota IntelliJ IDEA pluginCodota Android Studio pluginCode IndexSign in
  • EnterpriseFAQAboutBlogContact Us
  • Plugin user guideTerms of usePrivacy policyCodeboxFind Usages
Add Codota to your IDE (free)