Package org.apache.sandesha2.storage.beanmanagers

Examples of org.apache.sandesha2.storage.beanmanagers.SequencePropertyBeanMgr


                    .getConfigurationContext();

    StorageManager storageManager = SandeshaUtil
        .getSandeshaStorageManager(configurationContext);

    SequencePropertyBeanMgr seqPropMgr = storageManager
        .getSequencePropretyBeanMgr();

    //setting the addressing version
    String addressingNamespace = (String) firstAplicationMsgCtx.getProperty(AddressingConstants.WS_ADDRESSING_VERSION);
   
    if (addressingNamespace==null) {
      OperationContext opCtx = firstAplicationMsgCtx.getOperationContext();
      if (opCtx!=null) {
        try {
          MessageContext requestMsg = opCtx.getMessageContext(OperationContextFactory.MESSAGE_LABEL_IN_VALUE);
          if (requestMsg!=null)
            addressingNamespace = (String) requestMsg.getProperty(AddressingConstants.WS_ADDRESSING_VERSION);
        } catch (AxisFault e) {
          throw new SandeshaException (e);
        }
      }
    }
   
    if (addressingNamespace==null)
      addressingNamespace = AddressingConstants.Final.WSA_NAMESPACE;   //defaults to Final. Make sure this is synchronized with addressing.
   
    SequencePropertyBean addressingNamespaceBean = new SequencePropertyBean (
        internalSequenceId,Sandesha2Constants.SequenceProperties.ADDRESSING_NAMESPACE_VALUE,addressingNamespace);
    seqPropMgr.insert(addressingNamespaceBean);
   
    String anonymousURI = SpecSpecificConstants.getAddressingAnonymousURI(addressingNamespace);
   
    EndpointReference toEPR = firstAplicationMsgCtx.getTo();
    String acksTo = (String) firstAplicationMsgCtx
        .getProperty(SandeshaClientConstants.AcksTo);

    if (toEPR == null) {
      String message = "WS-Addressing To is null";
      log.debug(message);
      throw new SandeshaException(message);
    }

    SequencePropertyBean toBean = new SequencePropertyBean(internalSequenceId,
        Sandesha2Constants.SequenceProperties.TO_EPR, toEPR.getAddress());
    SequencePropertyBean replyToBean = null;
    SequencePropertyBean acksToBean = null;
   
    if (firstAplicationMsgCtx.isServerSide()) {
      //setting replyTo value, if this is the server side.
      OperationContext opContext = firstAplicationMsgCtx.getOperationContext();
      try {
        MessageContext requestMessage = opContext.getMessageContext(OperationContextFactory.MESSAGE_LABEL_IN_VALUE);
        if (requestMessage==null) {
          String message = "Cannot find the request message from the operation context";
          log.error(message);
          throw new SandeshaException (message);
        }
       
        EndpointReference replyToEPR = requestMessage.getTo();    //'replyTo' of the response msg is the 'to' value of the req msg.
        if (replyToEPR!=null) {
          replyToBean = new SequencePropertyBean (internalSequenceId,Sandesha2Constants.SequenceProperties.REPLY_TO_EPR,replyToEPR.getAddress());
          acksToBean = new SequencePropertyBean (internalSequenceId,Sandesha2Constants.SequenceProperties.ACKS_TO_EPR,replyToEPR.getAddress());   
        } else {
          String message = "To EPR is not present in the request message. Need this information to set acksTo & replyTo value of reply messages";
          log.error(message);
          throw new SandeshaException (message);
        }
      } catch (AxisFault e) {
        String message = "Cannot get request message from the operation context";
        log.error(message);
        log.error(e.getStackTrace());
        throw new SandeshaException (message);
      }
    }
    //Default value for acksTo is anonymous  (this happens only for the client side)
    if (acksTo==null) {
      acksTo = anonymousURI;
    }
   
      acksToBean = new SequencePropertyBean(
        internalSequenceId, Sandesha2Constants.SequenceProperties.ACKS_TO_EPR,
        acksTo);
     
    //start the in listner for the client side, if acksTo is not anonymous.
    if (!firstAplicationMsgCtx.isServerSide()  && !anonymousURI.equals(acksTo)) {
       
      String transportInProtocol = firstAplicationMsgCtx.getOptions().getTransportInProtocol();
        if (transportInProtocol==null) {
          throw new SandeshaException ("You must mention the transport in protocol for getting async acknowledgement messages");
        }
      
            try {
        ListenerManager listenerManager =
            firstAplicationMsgCtx.getConfigurationContext().getListenerManager();
        TransportInDescription transportIn = firstAplicationMsgCtx.getConfigurationContext().getAxisConfiguration().getTransportIn(new QName(transportInProtocol));
        //if acksTo is not anonymous start the in-transport
        if (!listenerManager.isListenerRunning(transportIn.getName().getLocalPart())) {
          listenerManager.addListener(transportIn, false);
        }
      } catch (AxisFault e) {
        throw new SandeshaException ("Could not stast the transport listner",e);
      }
     
     
    }
   
    SequencePropertyBean msgsBean = new SequencePropertyBean();
    msgsBean.setSequenceID(internalSequenceId);
    msgsBean.setName(Sandesha2Constants.SequenceProperties.CLIENT_COMPLETED_MESSAGES);
    msgsBean.setValue("");
   
    seqPropMgr.insert(msgsBean);
   
    seqPropMgr.insert(toBean);
    if (acksToBean!=null)
      seqPropMgr.insert(acksToBean);
    if (replyToBean!=null)
      seqPropMgr.insert(replyToBean);
   
    //saving transportTo value;
    String transportTo = (String) firstAplicationMsgCtx.getProperty(MessageContextConstants.TRANSPORT_URL);
    if (transportTo!=null) {
      SequencePropertyBean transportToBean = new SequencePropertyBean ();
      transportToBean.setSequenceID(internalSequenceId);
      transportToBean.setName(Sandesha2Constants.SequenceProperties.TRANSPORT_TO);
      transportToBean.setValue(transportTo);
     
      seqPropMgr.insert(transportToBean);
    }


    //setting the spec version for the client side.
    SequencePropertyBean specVerionBean = new SequencePropertyBean ();
    specVerionBean.setSequenceID(internalSequenceId);
    specVerionBean.setName(Sandesha2Constants.SequenceProperties.RM_SPEC_VERSION);
    specVerionBean.setValue(specVersion);
    seqPropMgr.insert(specVerionBean);
   
    //updating the last activated time.
    updateLastActivatedTime(internalSequenceId,configurationContext);
   
    SandeshaUtil.startSenderForTheSequence(configurationContext,internalSequenceId);
View Full Code Here


   * @throws SandeshaException
   */
  public static void updateLastActivatedTime (String propertyKey, ConfigurationContext configContext) throws SandeshaException {
    StorageManager storageManager = SandeshaUtil.getSandeshaStorageManager(configContext);
    //Transaction lastActivatedTransaction = storageManager.getTransaction();
    SequencePropertyBeanMgr sequencePropertyBeanMgr = storageManager.getSequencePropretyBeanMgr();
   
    SequencePropertyBean lastActivatedBean = sequencePropertyBeanMgr.retrieve(propertyKey, Sandesha2Constants.SequenceProperties.LAST_ACTIVATED_TIME);
   
    boolean added = false;
   
    if (lastActivatedBean==null) {
      added = true;
      lastActivatedBean = new SequencePropertyBean ();
      lastActivatedBean.setSequenceID(propertyKey);
      lastActivatedBean.setName(Sandesha2Constants.SequenceProperties.LAST_ACTIVATED_TIME);
    }
   
    long currentTime = System.currentTimeMillis();
    lastActivatedBean.setValue(Long.toString(currentTime));
   
    if (added)
      sequencePropertyBeanMgr.insert(lastActivatedBean);
    else
      sequencePropertyBeanMgr.update(lastActivatedBean);
   
  }
View Full Code Here

 
 
  public static long getLastActivatedTime (String propertyKey, ConfigurationContext configContext) throws SandeshaException {
   
    StorageManager storageManager = SandeshaUtil.getSandeshaStorageManager(configContext);
    SequencePropertyBeanMgr seqPropBeanMgr = storageManager.getSequencePropretyBeanMgr();
   
    SequencePropertyBean lastActivatedBean = seqPropBeanMgr.retrieve(propertyKey,Sandesha2Constants.SequenceProperties.LAST_ACTIVATED_TIME);
   
    long lastActivatedTime = -1;
   
    if (lastActivatedBean!=null) {
      lastActivatedTime = Long.parseLong(lastActivatedBean.getValue());
View Full Code Here

  }
 
  public static long getOutGoingSequenceAckedMessageCount (String internalSequenceID,ConfigurationContext configurationContext) throws SandeshaException {
    StorageManager storageManager = SandeshaUtil.getSandeshaStorageManager(configurationContext);
    Transaction transaction = storageManager.getTransaction();
    SequencePropertyBeanMgr seqPropBeanMgr = storageManager.getSequencePropretyBeanMgr();
   
    SequencePropertyBean findSeqIDBean = new SequencePropertyBean ();
    findSeqIDBean.setValue(internalSequenceID);
    findSeqIDBean.setName(Sandesha2Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
    Collection seqIDBeans = seqPropBeanMgr.find(findSeqIDBean);
   
    if (seqIDBeans.size()==0) {
      String message = "A sequence with give data has not been created";
      log.debug(message);
      throw new SandeshaException (message);
    }
   
    if (seqIDBeans.size()>1) {
      String message = "Sequence data is not unique. Cant generate report";
      log.debug(message);
      throw new SandeshaException (message);
    }
   
    SequencePropertyBean seqIDBean = (SequencePropertyBean) seqIDBeans.iterator().next();
    String sequenceID = seqIDBean.getSequenceID();

    SequencePropertyBean ackedMsgBean = seqPropBeanMgr.retrieve(sequenceID,Sandesha2Constants.SequenceProperties.NO_OF_OUTGOING_MSGS_ACKED);
    if (ackedMsgBean==null)
      return 0; //No acknowledgement has been received yet.
   
    long noOfMessagesAcked = Long.parseLong(ackedMsgBean.getValue());
    transaction.commit();
View Full Code Here

  }
 
  public static boolean isOutGoingSequenceCompleted (String internalSequenceID,ConfigurationContext configurationContext) throws SandeshaException {
    StorageManager storageManager = SandeshaUtil.getSandeshaStorageManager(configurationContext);
    Transaction transaction = storageManager.getTransaction();
    SequencePropertyBeanMgr seqPropBeanMgr = storageManager.getSequencePropretyBeanMgr();
   
    SequencePropertyBean findSeqIDBean = new SequencePropertyBean ();
    findSeqIDBean.setValue(internalSequenceID);
    findSeqIDBean.setName(Sandesha2Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);
    Collection seqIDBeans = seqPropBeanMgr.find(findSeqIDBean);
   
    if (seqIDBeans.size()==0) {
      String message = "A sequence with give data has not been created";
      log.debug(message);
      throw new SandeshaException (message);
    }
   
    if (seqIDBeans.size()>1) {
      String message = "Sequence data is not unique. Cant generate report";
      log.debug(message);
      throw new SandeshaException (message);
    }
   
    SequencePropertyBean seqIDBean = (SequencePropertyBean) seqIDBeans.iterator().next();
    String sequenceID = seqIDBean.getSequenceID();
   
    SequencePropertyBean terminateAddedBean = seqPropBeanMgr.retrieve(sequenceID,Sandesha2Constants.SequenceProperties.TERMINATE_ADDED);
    if (terminateAddedBean==null)
      return false;
   
    if ("true".equals(terminateAddedBean.getValue()))
      return true;
View Full Code Here

 
  public static boolean isIncomingSequenceCompleted (String sequenceID, ConfigurationContext configurationContext) throws SandeshaException {
   
    StorageManager storageManager = SandeshaUtil.getSandeshaStorageManager(configurationContext);
    Transaction transaction = storageManager.getTransaction();
    SequencePropertyBeanMgr seqPropBeanMgr = storageManager.getSequencePropretyBeanMgr();
   
    SequencePropertyBean terminateReceivedBean = seqPropBeanMgr.retrieve(sequenceID,Sandesha2Constants.SequenceProperties.TERMINATE_RECEIVED);
    boolean complete = false;
   
    if (terminateReceivedBean!=null && "true".equals(terminateReceivedBean.getValue()))
      complete = true;
   
View Full Code Here

    SOAPFactory factory = SOAPAbstractFactory.getSOAPFactory(SandeshaUtil
        .getSOAPVersion(applicationMsgContext.getEnvelope()));

    StorageManager storageManager = SandeshaUtil
        .getSandeshaStorageManager(context);
    SequencePropertyBeanMgr seqPropMgr = storageManager
        .getSequencePropretyBeanMgr();
    MessageContext createSeqmsgContext;
    try {
      // creating by copying common contents. (this will not set contexts
      // except for configCtx).
      AxisOperation createSequenceOperation = AxisOperationFactory
          .getAxisOperation(AxisOperation.MEP_CONSTANT_OUT_IN);

      createSeqmsgContext = SandeshaUtil.createNewRelatedMessageContext(
          applicationRMMsg, createSequenceOperation);

      initializeCreation(applicationMsgContext, createSeqmsgContext);

      OperationContext createSeqOpCtx = createSeqmsgContext
          .getOperationContext();
      String createSeqMsgId = SandeshaUtil.getUUID();
      createSeqmsgContext.setMessageID(createSeqMsgId);
      context.registerOperationContext(createSeqMsgId, createSeqOpCtx);

    } catch (AxisFault e) {
      throw new SandeshaException(e.getMessage());
    }

    AxisOperation appMsgOperationDesc = applicationMsgContext
        .getAxisOperation();

    AxisOperation createSeqOperation = createSeqmsgContext
        .getAxisOperation();
   
    createSeqOperation.setName(new QName("CreateSequenceOperation"));
    if (appMsgOperationDesc != null) {
      createSeqOperation.setPhasesOutFlow(appMsgOperationDesc
          .getPhasesOutFlow());
      createSeqOperation.setPhasesOutFaultFlow(appMsgOperationDesc
          .getPhasesOutFaultFlow());
      createSeqOperation.setPhasesInFaultFlow(appMsgOperationDesc
          .getPhasesInFaultFlow());
      createSeqOperation.setRemainingPhasesInFlow(appMsgOperationDesc
          .getRemainingPhasesInFlow());
    }

    createSeqmsgContext.setAxisOperation(createSeqOperation);

    createSeqmsgContext.setTo(applicationRMMsg.getTo());
    createSeqmsgContext.setReplyTo(applicationRMMsg.getReplyTo());

    RMMsgContext createSeqRMMsg = new RMMsgContext(createSeqmsgContext);

    String rmVersion = SandeshaUtil.getRMVersion(internalSequenceId,context);
    if (rmVersion==null)
      throw new SandeshaException ("Cant find the rmVersion of the given message");
   
    String rmNamespaceValue = SpecSpecificConstants.getRMNamespaceValue(rmVersion);
   
    String addressingNamespaceValue = SandeshaUtil.getSequenceProperty(internalSequenceId,Sandesha2Constants.SequenceProperties.ADDRESSING_NAMESPACE_VALUE,context);
   
    CreateSequence createSequencePart = new CreateSequence(factory,rmNamespaceValue,addressingNamespaceValue);

    // Adding sequence offer - if present
    OperationContext operationcontext = applicationMsgContext
        .getOperationContext();
    if (operationcontext != null) {
      String offeredSequence = (String) applicationMsgContext
          .getProperty(SandeshaClientConstants.OFFERED_SEQUENCE_ID);
      if (offeredSequence != null && !"".equals(offeredSequence)) {
        SequenceOffer offerPart = new SequenceOffer(factory,rmNamespaceValue);
        Identifier identifier = new Identifier(factory,rmNamespaceValue);
        identifier.setIndentifer(offeredSequence);
        offerPart.setIdentifier(identifier);
        createSequencePart.setSequenceOffer(offerPart);
      }
    }

    SequencePropertyBean replyToBean = seqPropMgr.retrieve(
        internalSequenceId,
        Sandesha2Constants.SequenceProperties.REPLY_TO_EPR);
    SequencePropertyBean toBean = seqPropMgr.retrieve(internalSequenceId,
        Sandesha2Constants.SequenceProperties.TO_EPR);

    if (toBean == null || toBean.getValue() == null)
      throw new SandeshaException("To EPR is not set.");
View Full Code Here

    sequenceAck.setIdentifier(id);


    StorageManager storageManager = SandeshaUtil
        .getSandeshaStorageManager(ctx);
    SequencePropertyBeanMgr seqPropMgr = storageManager
        .getSequencePropretyBeanMgr();

    SequencePropertyBean seqBean = seqPropMgr.retrieve(sequenceId,
        Sandesha2Constants.SequenceProperties.SERVER_COMPLETED_MESSAGES);
    String msgNoList = (String) seqBean.getValue();

    ArrayList ackRangeArrayList = SandeshaUtil.getAckRangeArrayList(
        msgNoList, factory,rmNamespaceValue);
    Iterator iterator = ackRangeArrayList.iterator();
    while (iterator.hasNext()) {
      AcknowledgementRange ackRange = (AcknowledgementRange) iterator
          .next();
      sequenceAck.addAcknowledgementRanges(ackRange);
    }
   
   
    SequencePropertyBean sequenceClosedBean = seqPropMgr.retrieve(sequenceId,Sandesha2Constants.SequenceProperties.SEQUENCE_CLOSED );
   
    if (sequenceClosedBean!=null && Sandesha2Constants.VALUE_TRUE.equals(sequenceClosedBean.getValue())) {
      //sequence is closed. so add the 'Final' part.
      if (SpecSpecificConstants.isAckFinalAllowed(rmVersion)) {
        AckFinal ackFinal = new AckFinal (factory,rmNamespaceValue);
View Full Code Here

   
    String sequenceID = ackRequested.getIdentifier().getIdentifier();
   
    ConfigurationContext configurationContext = rmMsgCtx.getMessageContext().getConfigurationContext();
    StorageManager storageManager = SandeshaUtil.getSandeshaStorageManager(configurationContext);
    SequencePropertyBeanMgr seqPropMgr = storageManager.getSequencePropretyBeanMgr();
   
    //Setting the ack depending on AcksTo.
    SequencePropertyBean acksToBean = seqPropMgr.retrieve(sequenceID,
        Sandesha2Constants.SequenceProperties.ACKS_TO_EPR);

    EndpointReference acksTo = new EndpointReference(acksToBean.getValue());
    String acksToStr = acksTo.getAddress();
View Full Code Here

    StorageManager storageManager = SandeshaUtil
        .getSandeshaStorageManager(rmMsgCtx.getMessageContext()
            .getConfigurationContext());
    SenderBeanMgr retransmitterMgr = storageManager
        .getRetransmitterBeanMgr();
    SequencePropertyBeanMgr seqPropMgr = storageManager
        .getSequencePropretyBeanMgr();



    Iterator ackRangeIterator = sequenceAck.getAcknowledgementRanges()
        .iterator();

    Iterator nackIterator = sequenceAck.getNackList().iterator();
    String outSequenceId = sequenceAck.getIdentifier().getIdentifier();
    if (outSequenceId == null || "".equals(outSequenceId)) {
      String message = "OutSequenceId is null";
      log.debug(message);
      throw new SandeshaException(message);
    }

    FaultManager faultManager = new FaultManager();
    RMMsgContext faultMessageContext = faultManager.checkForUnknownSequence(rmMsgCtx,outSequenceId);
    if (faultMessageContext != null) {
      ConfigurationContext configurationContext = msgCtx.getConfigurationContext();
      AxisEngine engine = new AxisEngine(configurationContext);
     
      try {
        engine.sendFault(faultMessageContext.getMessageContext());
      } catch (AxisFault e) {
        throw new SandeshaException ("Could not send the fault message",e);
      }
     
      return;
    }
   
    faultMessageContext = faultManager.checkForInvalidAcknowledgement(rmMsgCtx);
    if (faultMessageContext != null) {
      ConfigurationContext configurationContext = msgCtx.getConfigurationContext();
      AxisEngine engine = new AxisEngine(configurationContext);
     
      try {
        engine.sendFault(faultMessageContext.getMessageContext());
      } catch (AxisFault e) {
        throw new SandeshaException ("Could not send the fault message",e);
      }
     
      return;
    }
   
        String internalSequenceID = SandeshaUtil.getSequenceProperty(outSequenceId,Sandesha2Constants.SequenceProperties.INTERNAL_SEQUENCE_ID,configCtx);
   
        //updating the last activated time of the sequence.
    Transaction lastUpdatedTimeTransaction = storageManager.getTransaction();
    SequenceManager.updateLastActivatedTime(internalSequenceID,rmMsgCtx.getMessageContext().getConfigurationContext());
    lastUpdatedTimeTransaction.commit();
   
    //Starting transaction
    Transaction ackTransaction = storageManager.getTransaction();

    SequencePropertyBean internalSequenceBean = seqPropMgr.retrieve(
        outSequenceId, Sandesha2Constants.SequenceProperties.INTERNAL_SEQUENCE_ID);

    if (internalSequenceBean == null || internalSequenceBean.getValue() == null) {
      String message = "TempSequenceId is not set correctly";
      log.debug(message);
      throw new SandeshaException(message);
    }

    String internalSequenceId = (String) internalSequenceBean.getValue();

    //Following happens in the SandeshaGlobal handler
    rmMsgCtx.getMessageContext()
        .setProperty(Sandesha2Constants.ACK_PROCSSED, "true");

    //Removing relatesTo - Some v1_0 endpoints tend to set relatesTo value for ack messages.
    //Because of this dispatching may go wrong. So we set relatesTo value to null for ackMessages.
    //(this happens in the SandeshaGlobal handler). Do this only if this is a standalone ACK.
//    if (rmMsgCtx.getMessageType() == Sandesha2Constants.MessageTypes.ACK)
//      rmMsgCtx.setRelatesTo(null);

    SenderBean input = new SenderBean();
    input.setSend(true);
    input.setReSend(true);
    Collection retransmitterEntriesOfSequence = retransmitterMgr
        .find(input);

    ArrayList ackedMessagesList = new ArrayList ();
    while (ackRangeIterator.hasNext()) {
      AcknowledgementRange ackRange = (AcknowledgementRange) ackRangeIterator
          .next();
      long lower = ackRange.getLowerValue();
      long upper = ackRange.getUpperValue();

      for (long messageNo = lower; messageNo <= upper; messageNo++) {
        SenderBean retransmitterBean = getRetransmitterEntry(
            retransmitterEntriesOfSequence, messageNo);
        if (retransmitterBean != null)
          retransmitterMgr.delete(retransmitterBean.getMessageID());
       
        ackedMessagesList.add(new Long (messageNo));
      }
    }

    while (nackIterator.hasNext()) {
      Nack nack = (Nack) nackIterator.next();
      long msgNo = nack.getNackNumber();

      //TODO - Process Nack
    }
   
    //setting acked message date.
    //TODO add details specific to each message.
    long noOfMsgsAcked = getNoOfMessagesAcked(sequenceAck.getAcknowledgementRanges().iterator());
    SequencePropertyBean noOfMsgsAckedBean = seqPropMgr.retrieve(outSequenceId,Sandesha2Constants.SequenceProperties.NO_OF_OUTGOING_MSGS_ACKED);
    boolean added = false;
   
    if (noOfMsgsAckedBean==null) {
      added = true;
      noOfMsgsAckedBean = new SequencePropertyBean ();
      noOfMsgsAckedBean.setSequenceID(outSequenceId);
      noOfMsgsAckedBean.setName(Sandesha2Constants.SequenceProperties.NO_OF_OUTGOING_MSGS_ACKED);
    }
   
    noOfMsgsAckedBean.setValue(Long.toString(noOfMsgsAcked));
   
    if (added)
      seqPropMgr.insert(noOfMsgsAckedBean);
    else
      seqPropMgr.update(noOfMsgsAckedBean);
   
   
    //setting the completed_messages list. This gives all the messages of the sequence that were acked.
    SequencePropertyBean allCompletedMsgsBean = seqPropMgr.retrieve(internalSequenceId,Sandesha2Constants.SequenceProperties.CLIENT_COMPLETED_MESSAGES);
    if (allCompletedMsgsBean==null) {
      allCompletedMsgsBean = new SequencePropertyBean ();
      allCompletedMsgsBean.setSequenceID(internalSequenceId);
      allCompletedMsgsBean.setName(Sandesha2Constants.SequenceProperties.CLIENT_COMPLETED_MESSAGES);
     
      seqPropMgr.insert(allCompletedMsgsBean);
    }
       
    String str = ackedMessagesList.toString();
    allCompletedMsgsBean.setValue(str);
   
    seqPropMgr.update(allCompletedMsgsBean);   
   
    //commiting transaction
    ackTransaction.commit();
   
    String lastOutMsgNoStr = SandeshaUtil.getSequenceProperty(internalSequenceId,Sandesha2Constants.SequenceProperties.LAST_OUT_MESSAGE_NO,configCtx);
View Full Code Here

TOP

Related Classes of org.apache.sandesha2.storage.beanmanagers.SequencePropertyBeanMgr

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.