Package org.apache.flink.runtime.executiongraph

Examples of org.apache.flink.runtime.executiongraph.ExecutionJobVertex


    if (graph == null) {
      LOG.error("Cannot find execution graph to job ID " + jobID);
      return null;
    }

    final ExecutionJobVertex vertex = graph.getJobVertex(vertexId);
    if (vertex == null) {
      LOG.error("Cannot find execution vertex for vertex ID " + vertexId);
      return null;
    }

    InputSplitAssigner splitAssigner = vertex.getSplitAssigner();
    if (splitAssigner == null) {
      LOG.error("No InputSplitAssigner for vertex ID " + vertexId);
      return null;
    }
   
View Full Code Here


    json.append("\"backwardEdges\": [");
   
    List<IntermediateResult> inputs = jobVertex.getInputs();
   
    for (int inputNumber = 0; inputNumber < inputs.size(); inputNumber++) {
      ExecutionJobVertex input = inputs.get(inputNumber).getProducer();
     
      json.append("{");
      json.append("\"groupvertexid\": \"" + input.getJobVertexId() + "\",");
      json.append("\"groupvertexname\": \"" +  StringUtils.escapeHtml(jobVertex.getJobVertex().getName()) + "\",");
      json.append("\"channelType\": \"" +  ChannelType.NETWORK + "\"");
      json.append("}");
     
      // print delimiter
View Full Code Here

    public void executionStateChanged(JobID jobID, JobVertexID vertexId, int subtask, ExecutionAttemptID executionId,
        ExecutionState newExecutionState, String optionalMessage)
    {
      final long timestamp = System.currentTimeMillis();

      final ExecutionJobVertex vertex = graph.getJobVertex(vertexId);
     
      final String taskName = vertex == null ? "(null)" : vertex.getJobVertex().getName();
      final int totalNumberOfSubtasks = vertex == null ? -1 : vertex.getParallelism();

      // Create a new vertex event
      final VertexEvent vertexEvent = new VertexEvent(timestamp, vertexId, taskName, totalNumberOfSubtasks,
          subtask, executionId, newExecutionState, optionalMessage);
View Full Code Here

   */
  private void writeJsonForArchivedJobGroupvertex(PrintWriter wrt, RecentJobEvent jobEvent, JobVertexID vertexId) {
    try {
      ExecutionGraph graph = jobmanager.getRecentExecutionGraph(jobEvent.getJobID());
     
      ExecutionJobVertex jobVertex = graph.getJobVertex(vertexId);
     
      // Serialize ManagementGraph to json
      wrt.write("{\"groupvertex\": " + JsonFactory.toJson(jobVertex) + ",");
     
      wrt.write("\"verticetimes\": {");
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.executiongraph.ExecutionJobVertex

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.