Examples of execute()


Examples of com.sleepycat.je.rep.stream.FeederReplicaSyncup.execute()

                 * FeederReplicaSyncup so that the replica's local CBVLSN can
                 * be updated while the global CBVLSN update is locked out.
                 */
                this.replicaCBVLSN = new LocalCBVLSNUpdater(replicaNameIdPair,
                                                            repNode);
                feederVLSN = syncup.execute(replicaCBVLSN);
                feederSource.init(feederVLSN);

                /* Start the thread to pump out log records */
                outputThread.start();
                lastResponseTime = System.currentTimeMillis();
View Full Code Here

Examples of com.sleepycat.je.rep.stream.ReplicaFeederHandshake.execute()

               HardRecoveryElectionException {

        createReplicaFeederChannel();
        ReplicaFeederHandshake handshake =
            new ReplicaFeederHandshake(repNode, replicaFeederChannel);
        protocol = handshake.execute();

        final boolean hardRecoveryNeedsElection;

        if (hardRecoveryElectionException != null) {
            LoggerUtils.info(logger, repImpl,
View Full Code Here

Examples of com.sleepycat.je.rep.stream.ReplicaFeederSyncup.execute()

        hardRecoveryElectionException = null;

        ReplicaFeederSyncup syncup =
            new ReplicaFeederSyncup(repNode, replay, replicaFeederChannel,
                                    protocol, hardRecoveryNeedsElection);
        syncup.execute(repNode.getCBVLSNTracker());

        VLSN matchedTxnVLSN = syncup.getMatchedVLSN();
        long matchedTxnEndTime = syncup.getMatchedVLSNTime();
        consistencyTracker.reinit(matchedTxnVLSN.getSequence(),
                                  matchedTxnEndTime);
View Full Code Here

Examples of com.socialnetworkshirts.twittershirts.dataaccess.spreadshirt.http.HttpCallCommand.execute()

            throws Exception {
        Element elem = shopCache.get(id);
        if (elem == null) {
            HttpCallCommand command =
                    commandFactory.createJaxbHttpCallCommand(shopUrl + "/" + id, HttpMethod.GET, null);
            command.execute();
            if (command.getStatus() >= 400) {
                throw new Exception("Could fetch shop xml!");
            }
            ShopDTO shop =
                    (ShopDTO) ((JAXBElement) command.getOutput()).getValue();
View Full Code Here

Examples of com.sos.DataExchange.SOSDataExchangeEngine.Execute()

      logger.debug(objO.toString());
    }
   
    logger.info(String.format("%1$s with operation %2$s started.", conMethodName, objO.operation.Value()));
    objR.setJSJobUtilites(this);
    objR.Execute();
    objR.Logout();
    logger.info(String.format("%1$s with operation %2$s ended.", conMethodName, objO.operation.Value()));
  } // doProcessing

}
View Full Code Here

Examples of com.splunk.shuttl.server.distributed.RequestOnSearchPeers.execute()

    JSONObject jsonObject = JsonUtils.writeKeyValueAsJson(
        JsonObjectNames.BUCKET_COLLECTION, bucketsWithSize);

    RequestOnSearchPeers requestOnSearchPeers = RequestOnSearchPeers.createGet(
        ShuttlConstants.ENDPOINT_LIST_BUCKETS, index, from, to);
    SearchPeerResponse peerResponse = requestOnSearchPeers.execute();
    List<JSONObject> jsons = peerResponse.jsons;
    jsons.add(jsonObject);

    return RestUtil.mergeBucketCollectionsAndAddTotalSize(jsons)
        .put(JsonObjectNames.EXCEPTIONS, peerResponse.exceptions).toString();
View Full Code Here

Examples of com.springsource.insight.plugin.jdbc.helpers.AbstractStatement.execute()

        final AtomicInteger callsCount = new AtomicInteger(0);
        final DatabaseMetaData metaData = new Jdk16DatabaseMetaData() {
            @Override
            public String getURL() throws SQLException {
                callsCount.incrementAndGet();
                return "jdbc:test:call=" + metaDataStmt.execute("SHOW META DATA");
            }
        };
        Connection metaDataConn = new Jdk16Connection() {
            @Override
            public DatabaseMetaData getMetaData() throws SQLException {
View Full Code Here

Examples of com.starflow.wf.engine.ExecutorService.execute()

   
    ExecutorService executor = processEngine.getExecutorService();
    if(Constants.ACT_AUTO_CALL_SYN.equalsIgnoreCase(invokePattern)) {
      //同步调用可以返回运行结果,前提是要设置返回运行结果。
      try {
        executor.execute(new Callable<Object>() {
          public Object call() throws Exception {
            if(Constants.ACT_TRANSACTION_JOIN.equalsIgnoreCase(transactionType)) {
              action.execute(activityXml, activityInst);
            } else {
              executeLogicInNewTransaction(activityXml, activityInst, action);
View Full Code Here

Examples of com.starflow.wf.engine.core.expression.IExpressionHandler.execute()

      }
     
      IExpressionHandler expressionHandler =
        ExpressionHandlerFactory.buildExpressionHandler(transitionXml.getIsSimpleExpression());
     
      if(expressionHandler.execute(event.getProcessEngine().getScriptEngineManager(), transitionXml, conditions))
        tranEls.add(transitionXml);
    }
   
    //当为单一分支的时候,连线按照优先级降序排列。
    if(isSort && tranEls.size()>1) {
View Full Code Here

Examples of com.starflow.wf.engine.transaction.TransactionTemplate.execute()

   * @return
   */
  protected Object executeLogicInNewTransaction(final AbstractFlowEvent event, final ActivityInst activityInst, final IAction action) {
    TransactionTemplate template = event.getProcessEngine().getTransactionTemplate();
   
    return template.execute(TransactionDefinition.PROPAGATION_REQUIRES_NEW,
        new TransactionCallback<Object>() {

      @Override
      public Object doInTransaction(TransactionStatus status) {
        return action.execute(event, activityInst);
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.