Examples of Flow


Examples of com.isencia.passerelle.model.Flow

             ***/
            // End Complete if...else block commented out...
            // Bug 17641
            // displayViewComp(flow, step);
            try {
                Flow flow = step.getFlow();
                if (flow == null) {
                    flow = createFlow(step, false);
                    step.setFlow(flow);
                }

View Full Code Here

Examples of com.ontology2.haruhi.flows.Flow

        ApplicationContext enrichedContext=fetcher.enrichedContext();
        if (!a.hasNext())
            usage();
       
        String flowId=a.next();
        Flow f=enrichedContext.getBean(flowId,Flow.class);
       
        List<String> flowArgs=Lists.newArrayList();
        Iterators.addAll(flowArgs, a);
        cluster.runFlow(jar, f, flowArgs);
    }
View Full Code Here

Examples of com.sogou.qadev.service.cynthia.bean.Flow

          }else if(type.equals("t")){
            Template template = TemplateCache.getInstance().get(id);
            if(template == null){
              continue;
            }
            Flow flow = FlowCache.getInstance().get(template.getFlowId());
            if (flow == null) {
              continue;
            }
            flowList.add(flow);
          }
         
          for(Flow flow : flowList){
            if(flow == null){
              continue;
            }
           
            if(fieldValue.equals("[逻辑开始]") && flow.getBeginStats() != null){
              for(Stat stat : flow.getBeginStats()){
                if(statusIdStrb.length() > 0){
                  statusIdStrb.append(",");
                }
               
                statusIdStrb.append(stat.getId());
              }
            }
            else if(fieldValue.equals("[逻辑关闭]") && flow.getEndStats() != null){
              for(Stat stat : flow.getEndStats()){
                if(statusIdStrb.length() > 0){
                  statusIdStrb.append(",");
                }
               
                statusIdStrb.append(stat.getId());
              }
            }
          }
         
          if(statusIdStrb.length() == 0){
            continue;
          }
         
          if(fieldMethod.equals("=")){
            XMLUtil.setAttribute(whereFieldNode, "method", "in");
          }
          else if(fieldMethod.equals("!=")){
            XMLUtil.setAttribute(whereFieldNode, "method", "not in");
          }
         
          whereFieldNode.setTextContent(statusIdStrb.toString());
        }
       
       
        //创建人 指派人可以指派给角色
        if((fieldId.equals("create_user") || fieldId.equals("assign_user") || fieldId.equals("log_create_user")) && (fieldValue.startsWith("role_"))){
         
          String roleIdStr = fieldValue.substring(5);
         
          if (!CommonUtil.isPosNum(roleIdStr))
            continue;
         
          StringBuffer roleUsers = new StringBuffer();
          if (type.equals("t")) {
            Template template = TemplateCache.getInstance().get(id);
            if(template == null){
              continue;
            }
            Flow flow = FlowCache.getInstance().get(template.getFlowId());
            if (flow == null) {
              continue;
            }
            UUID roleId = DataAccessFactory.getInstance().createUUID(roleIdStr);
            Set<Right> allRoleRight = flow.queryRightsByRole(roleId);
           
            for (Right right : allRoleRight) {
              roleUsers.append(roleUsers.length() > 0 ? "," : "").append(right.getUsername());
            }
          }
View Full Code Here

Examples of com.twitter.hraven.Flow

  private void updateFlowQueue(FlowQueueKey key) throws IOException {
    updateFlowQueue(key, null);
  }

  private void updateFlowQueue(FlowQueueKey key, Integer progress) throws IOException {
    Flow flow = new Flow(flowKey);
    if (progress != null) {
      flow.setProgress(progress);
    }
    flow.setQueueKey(key);
    flow.setFlowName(appId);
    flow.setUserName(username);
    flow.setJobGraphJSON(JSONUtil.toJson(dagNodeNameMap));
    hRavenPool.submit(new HRavenQueueRunnable(flowQueueService, flowQueueKey, flow));
  }
View Full Code Here

Examples of javax.faces.flow.Flow

                if (null != url && matches.hasMoreElements()) {
                    boolean keepGoing = true;
                    FacesContext context = FacesContext.getCurrentInstance();
                    Application application = context.getApplication();
                    FlowHandler fh = application.getFlowHandler();
                    Flow currentFlow = fh.getCurrentFlow(context);
                    do {
                        if (null != currentFlow && 0 < currentFlow.getDefiningDocumentId().length()) {
                            String definingDocumentId = currentFlow.getDefiningDocumentId();
                            ExternalContext extContext = context.getExternalContext();
                            ApplicationAssociate associate = ApplicationAssociate.getInstance(extContext);
                            if (associate.urlIsRelatedToDefiningDocumentInJar(url, definingDocumentId)) {
                                keepGoing = false;
                                doNotCache = true;
View Full Code Here

Examples of model.tools.flowmanager.Flow

   
    if (!obj.isNull(dpid)) {
      json = obj.getJSONArray(dpid);
      for (int i = 0; i < json.length(); i++) {
        obj = (JSONObject) json.get(i);
        Flow flow = new Flow(dpid);
        flow.setActions(ActionJSON.getActions(obj
            .getJSONArray("actions")));
        flow.setMatch(MatchJSON.getMatch(obj.getJSONObject("match")));
        flow.setPriority(String.valueOf(obj.getInt("priority")));
        if (obj.getInt("idleTimeout") != 0)
          flow.setIdleTimeOut(String.valueOf(obj
              .getInt("idleTimeout")));
        if (obj.getInt("hardTimeout") != 0)
          flow.setHardTimeOut(String.valueOf(obj
              .getInt("hardTimeout")));
        flow.setDurationSeconds(String.valueOf(obj
            .getInt("durationSeconds")));
        flow.setPacketCount(String.valueOf(obj.getInt("packetCount")));
        flow.setByteCount(FormatLong.formatBytes(obj.getLong("byteCount"),false,false));
        flows.add(flow);
      }
    }
    return flows;
  }
View Full Code Here

Examples of net.ripe.hadoop.pcap.packet.Flow

          PROTOCOL_TCP == protocol) {
 
        byte[] packetPayload = buildTcpAndUdpPacket(packet, packetData, ipProtocolHeaderVersion, ipStart, ipHeaderLen, totalLength);

        if (isReassemble() && PROTOCOL_TCP == protocol) {
          Flow flow = packet.getFlow();

          if (packetPayload.length > 0) {
            Long seq = (Long)packet.get(Packet.TCP_SEQ);
            SequencePayload sequencePayload = new SequencePayload(seq, packetPayload);
            flows.put(flow, sequencePayload);
View Full Code Here

Examples of nexj.core.meta.workflow.Flow

               return null;
            }
         }
      }

      Flow flow = getFlow(sName);

      if (primary != null)
      {
         if (flow.getMetaclass() == null || !flow.getMetaclass().isUpcast(primary.getMetaclass()))
         {
            throw new WorkflowException("err.workflow.invalidClass",
               new Object[]{flow.getName(), primary.getMetaclass().getName()});
         }

         if (primary.getMetaclass().getPersistenceMapping() == null)
         {
            throw new MetadataException("err.meta.workflow.nonPersistentClass",
               new Object[]{primary.getMetaclass().getName(), flow.getFullName()});
         }
      }

      if (s_logger.isDebugEnabled())
      {
         s_logger.debug("Starting " + flow + " for " + primary);
      }

      boolean bSecure = m_context.isSecure();
      Instance instance = null;

      try
      {
         m_context.setSecure(false);
         instance = new Instance(metaclass, m_context);

         if (list != null)
         {
            list.add(instance);

            if (m_key == null)
            {
               m_key = new FlowKey();
            }

            m_key.instance = primary;
            m_context.getUnitOfWork().cacheTransient(m_key, list);
            m_key = null;
         }

         State state = new State(flow, true);

         state.setReservedValue(0, instance);
         state.setReservedValue(1, state);

         instance.setNew();
         instance.setValue("name", flow.getName());
         instance.setValue("version", Primitive.createInteger(flow.getVersion()));
         instance.setValue("oid", EMPTY_BINARY);
         instance.setValue("class", (primary == null) ? "" : primary.getMetaclass().getName());
         instance.setValue("local", (bGlobal) ? EMPTY_BINARY : GUIDUtil.generateGUID());
         instance.setValue("object", primary);
         instance.setValue("state", state);
View Full Code Here

Examples of nz.co.abrahams.asithappens.flow.Flow

    /**
     * Parses a packet trace file and populates the data sets.
     */
    public void parseTrace() throws FileNotFoundException, IOException, EOPacketStream, StreamFormatException, SyntaxError, DBException {
        PacketTraceIterator source;
        Flow flow;
        boolean foundMatch;
        boolean firstPacket;
        Flow[] temporaryFlows;
        Vector<DataPoint>[] temporaryData;
       
        source = new PacketTraceIterator(fileName);
        firstPacket = true;
       
        while ( (flow = source.next()) != null ) {
           
            if ( flow.timestamp >= startTime && flow.timestamp <= finishTime ) {
               
                foundMatch = false;
                for (int set = 0; set < data.size(); set++) {
                    if ( flow.matches(flows[set], options) ) {
                        foundMatch = true;
                        data.elementAt(set).add(new DataPoint(flow.timestamp, flow.length * 8));
                        logger.debug("Adding data to flow" + set + ": " + flow.timestamp + " " + flow.length);
                    }
                }
               
                if ( foundMatch == false ) {
                    temporaryFlows = new Flow[data.size() + 1];
                    System.arraycopy(flows, 0, temporaryFlows, 0, data.size());
                    flows = temporaryFlows;
                    flows[data.size()] = flow;
                   
                    logger.debug("Adding new data set " + flow.printable(options));
                    addSet(flow.printable(options));
                    data.elementAt(data.size() - 1).add(new DataPoint(flow.timestamp, flow.length * 8));
                }
            }
            /*
            if ( firstPacket ) {
View Full Code Here

Examples of nz.co.abrahams.asithappens.flow.Flow

    /**
     * Parses a packet trace file and populates the data sets.
     */
    public void parseTrace() throws FileNotFoundException, IOException, EOPacketStream, StreamFormatException, SyntaxError, DBException {
        PacketTraceIterator source;
        Flow flow;
        boolean foundMatch;
        boolean firstPacket;
        Flow[] temporaryFlows;
        Vector<DataPoint>[] temporaryData;
       
        source = new PacketTraceIterator(fileName);
        firstPacket = true;
       
        taskLength = PacketCounter.newInstance(new File(fileName), PacketCounterModel.statistical).getCount();
       
        while ( (flow = source.next()) != null && ! isCancelled() ) {
           
            taskProgress++;
            if ( flow.timestamp >= startTime && flow.timestamp <= finishTime ) {

                foundMatch = false;
                for (int set = 0; set < dataSets.getDataSetCount(); set++) {
                    if ( flow.matches(dataSets.flows[set], options) ) {
                        foundMatch = true;
                        dataSets.getDataSet(set).add(new DataPoint(flow.timestamp, flow.length * 8));
                        logger.debug("Adding data to flow" + set + ": " + flow.timestamp + " " + flow.length);
                    }
                }
               
                if ( foundMatch == false ) {
                    temporaryFlows = new Flow[dataSets.getDataSetCount() + 1];
                    System.arraycopy(dataSets.flows, 0, temporaryFlows, 0, dataSets.getDataSetCount());
                    dataSets.flows = temporaryFlows;
                    dataSets.flows[dataSets.getDataSetCount()] = flow;
                   
                    logger.debug("Adding new data set " + flow.printable(options));
                    dataSets.addSet(flow.printable(options));
                    dataSets.getDataSet(dataSets.getDataSetCount() - 1).add(new DataPoint(flow.timestamp, flow.length * 8));
                }
            }
            /*
            if ( firstPacket ) {
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.