Examples of run()


Examples of org.apache.mesos.MesosExecutorDriver.run()

    LOG.info("Executor asked to shutdown");
  }

  public static void main(String[] args) {
    MesosExecutorDriver driver = new MesosExecutorDriver(new MesosExecutor());
    System.exit(driver.run() == Status.DRIVER_STOPPED ? 0 : 1);
  }
}
View Full Code Here

Examples of org.apache.muse.tools.inspector.ResourceInspector.run()

   *       The <code>ResourceInspector</code> that analyzed the
   *       given document.
   */
  private ResourceInspector inspect(Document wsdlDocument) {     
    ResourceInspector inspector = new ResourceInspector();
    inspector.run(wsdlDocument.getDocumentElement(), null);
    return inspector;
  }

  /**
   * Create the <code>ConfigurationData</code> that we wil pass back to the
View Full Code Here

Examples of org.apache.nutch.crawl.DbUpdaterJob.run()

        parseSegment.parse(batchId, false, false);    // parse it, if needed
        delta = System.currentTimeMillis() - start;
        res.addTiming("parse", i + "", delta);
      }
      start = System.currentTimeMillis();
      crawlDbTool.run(new String[0]); // update crawldb
      delta = System.currentTimeMillis() - start;
      res.addTiming("update", i + "", delta);
    }
    if (i == 0) {
      LOG.warn("No URLs to fetch - check your seed list and URL filters.");
View Full Code Here

Examples of org.apache.ode.bpel.extension.ExtensionOperation.run()

                // act like <empty> - do nothing
                context.complete(_self.parent.export());
                return;
            }

            ea.run(context, _self.parent.export(), eao.nestedElement.getElement());
        } catch (FaultException fault) {
            __log.error(fault);
            context.completeWithFault(_self.parent.export(), fault);
        }
    }
View Full Code Here

Examples of org.apache.ode.bpel.iapi.Scheduler.MapSerializableRunnable.run()

                            MapSerializableRunnable runnable = (MapSerializableRunnable)jobInfo.jobDetail.getDetailsExt().get("runnable");
                            runnable.restoreFromDetails(jobInfo.jobDetail);
                            if( runnable instanceof ContextsAware ) {
                                ((ContextsAware)runnable).setContexts(_contexts);
                            }
                            runnable.run();
                            synchronized( resultsByJobId ) {
                                resultsByJobId.put(jobInfo.jobName, new PolledRunnableResults(JOB_STATUS.COMPLETED, null));
                            }
                        } catch( Exception e) {
                            __log.error("", e);
View Full Code Here

Examples of org.apache.oodt.cas.cli.CmdLineUtility.run()

         System.getProperties().load(new FileInputStream(propertiesFile));
      }

      // Run Command line.
      CmdLineUtility cmdLineUtility = new CmdLineUtility();
      cmdLineUtility.run(args);
  }
}
View Full Code Here

Examples of org.apache.oodt.cas.workflow.structs.WorkflowTaskInstance.run()

        WorkflowLifecycle lifecycle = getLifecycle(taskProcessor);
        WorkflowTask workflowTask = getTaskFromProcessor(taskProcessor);
        WorkflowTaskInstance inst = GenericWorkflowObjectFactory
            .getTaskObjectFromClassName(workflowTask.getTaskInstanceClassName());
        try {
          inst.run(taskProcessor.getWorkflowInstance().getSharedContext(),
              workflowTask.getTaskConfig());
          String msg = "Task: [" + workflowTask.getTaskName()
              + "] for instance id: ["
              + taskProcessor.getWorkflowInstance().getId()
              + "] completed successfully";
View Full Code Here

Examples of org.apache.oozie.client.OozieClient.run()

            if (propertiesFile != null) {
                conf.load(new FileInputStream(propertiesFile));
            }

            // submit and start the workflow job
            String jobId = wc.run(conf);
            Thread.sleep(1000);
            System.out.println("Workflow job submitted");

            // wait until the workflow job finishes printing the status every 10 seconds
            while (wc.getJobInfo(jobId).getStatus() == WorkflowJob.Status.RUNNING) {
View Full Code Here

Examples of org.apache.oozie.client.XOozieClient.run()

            }
            else if (options.contains(CHANGE_OPTION)) {
                wc.change(commandLine.getOptionValue(CHANGE_OPTION), getChangeValue(commandLine));
            }
            else if (options.contains(RUN_OPTION)) {
                System.out.println(JOB_ID_PREFIX + wc.run(getConfiguration(wc, commandLine)));
            }
            else if (options.contains(RERUN_OPTION)) {
                if (commandLine.getOptionValue(RERUN_OPTION).contains("-W")) {
                    wc.reRun(commandLine.getOptionValue(RERUN_OPTION), getConfiguration(wc, commandLine));
                }
View Full Code Here

Examples of org.apache.oozie.service.AbandonedCoordCheckerService.AbandonedCoordCheckerRunnable.run()

        final CoordinatorJobBean job2 = addRecordToCoordJobTable(CoordinatorJob.Status.RUNNING, start, end,
                createdTime, true, false, 4);
        addRecordToCoordActionTable(job2.getId(), 4, CoordinatorAction.Status.FAILED);

        AbandonedCoordCheckerRunnable coordChecked = new AbandonedCoordCheckerRunnable(5);
        coordChecked.run();
        String msg = coordChecked.getMessage();
        assertTrue(msg.contains(job1.getId()));
        assertFalse(msg.contains(job2.getId()));

    }
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. 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.