org.apache.uima.adapter.jms.client
public abstract class BaseUIMAAsynchronousEngineCommon_impl extends java.lang.Object implements UimaAsynchronousEngine, javax.jms.MessageListener
Modifier and Type | Class and Description |
---|---|
class |
BaseUIMAAsynchronousEngineCommon_impl.ClientRequest |
static class |
BaseUIMAAsynchronousEngineCommon_impl.ClientState |
static class |
BaseUIMAAsynchronousEngineCommon_impl.SharedConnection |
protected static class |
BaseUIMAAsynchronousEngineCommon_impl.ThreadMonitor |
class |
BaseUIMAAsynchronousEngineCommon_impl.UimaASShutdownHook |
Modifier and Type | Field and Description |
---|---|
protected boolean |
abort |
protected AsynchAECasManager |
asynchManager |
protected java.util.concurrent.ConcurrentHashMap<java.lang.String,BaseUIMAAsynchronousEngineCommon_impl.ClientRequest> |
clientCache |
protected UimaASClientInfoMBean |
clientSideJmxStats |
protected org.apache.uima.collection.CollectionReader |
collectionReader |
protected javax.jms.MessageConsumer |
consumer |
protected java.util.concurrent.Semaphore |
cpcReadySemaphore |
protected java.util.concurrent.Semaphore |
cpcReplySemaphore |
protected java.util.concurrent.Semaphore |
cpcSemaphore |
protected int |
cpcTimeout |
protected static int |
CpCTimeout |
protected java.lang.Exception |
exc |
protected java.util.concurrent.Semaphore |
getMetaSemaphore |
protected UIDGenerator |
idGenerator |
protected boolean |
initialized |
protected java.util.List |
listeners |
protected int |
metadataTimeout |
protected static int |
MetadataTimeout |
protected java.util.concurrent.atomic.AtomicLong |
outstandingCasRequests |
protected java.util.concurrent.BlockingQueue<PendingMessage> |
pendingMessageQueue |
protected static int |
PingTimeout |
protected int |
processTimeout |
protected static int |
ProcessTimeout |
protected boolean |
producerInitialized |
protected java.util.concurrent.Semaphore |
producerSemaphore |
protected boolean |
remoteService |
protected org.apache.uima.resource.metadata.ProcessingResourceMetaData |
resourceMetadata |
protected boolean |
running |
protected org.apache.uima.cas.CAS |
sendAndReceiveCAS |
protected java.lang.String |
serializationStrategy |
protected ClientServiceDelegate |
serviceDelegate |
protected static java.lang.String |
SHADOW_CAS_POOL |
protected static BaseUIMAAsynchronousEngineCommon_impl.SharedConnection |
sharedConnection |
protected java.lang.Thread |
shutdownHookThread |
protected java.util.concurrent.ConcurrentHashMap |
springContainerRegistry |
protected BaseUIMAAsynchronousEngineCommon_impl.ClientState |
state |
protected java.util.concurrent.ConcurrentHashMap<java.lang.Long,BaseUIMAAsynchronousEngineCommon_impl.ThreadMonitor> |
threadMonitorMap |
protected java.util.concurrent.atomic.AtomicLong |
totalCasRequestsSentBetweenCpCs |
protected static java.lang.String |
uniqueIdentifier |
ApplicationContext, ApplicationName, CasPoolSize, CpcTimeout, DD2SpringXsltFilePath, Endpoint, GetMetaTimeout, ReplyWindow, SaxonClasspath, SerializationStrategy, ServerUri, ShadowCasPoolSize, SharedConnection, Timeout, UimaEeDebug
Constructor and Description |
---|
BaseUIMAAsynchronousEngineCommon_impl() |
Modifier and Type | Method and Description |
---|---|
protected void |
acquireCpcReadySemaphore() |
void |
addStatusCallbackListener(UimaAsBaseCallbackListener aListener)
Registers application specific listener.
|
protected void |
cancelTimer(java.lang.String identifier) |
protected abstract void |
cleanup() |
void |
collectionProcessingComplete()
Sends a Collection Processing Complete (CPC) request to a UIMA AS Service and blocks waiting
for a reply.
|
boolean |
connectionOpen() |
protected abstract javax.jms.BytesMessage |
createBytesMessage() |
protected abstract javax.jms.TextMessage |
createTextMessage() |
protected void |
decrementOutstandingCasCounter() |
boolean |
delayCasIfDelegateInTimedOutState(java.lang.String aCasReferenceId)
Checks the state of a delegate to see if it is in TIMEOUT State.
|
abstract java.lang.String |
deploy(java.lang.String[] aDeploymentDescriptorList,
java.util.Map anApplicationContext)
Deploys a single UIMA AS container and all services defined in provided deployment descriptors.
|
protected abstract java.lang.String |
deploySpringContainer(java.lang.String[] springContextFiles) |
protected org.apache.uima.cas.CAS |
deserialize(byte[] binaryData,
BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest) |
protected org.apache.uima.cas.CAS |
deserialize(java.lang.String aSerializedCAS,
org.apache.uima.cas.CAS aCAS) |
protected org.apache.uima.cas.CAS |
deserialize(java.lang.String aSerializedCAS,
org.apache.uima.cas.CAS aCAS,
org.apache.uima.cas.impl.XmiSerializationSharedData deserSharedData,
boolean deltaCas) |
protected org.apache.uima.cas.CAS |
deserializeCAS(byte[] aSerializedCAS,
BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest) |
protected org.apache.uima.cas.CAS |
deserializeCAS(byte[] aSerializedCAS,
org.apache.uima.cas.CAS aCas) |
protected org.apache.uima.cas.CAS |
deserializeCAS(byte[] aSerializedCAS,
java.lang.String aCasPoolName) |
protected org.apache.uima.cas.CAS |
deserializeCAS(java.lang.String aSerializedCAS,
BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest) |
protected org.apache.uima.cas.CAS |
deserializeCAS(java.lang.String aSerializedCAS,
BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest,
boolean deltaCas) |
protected org.apache.uima.cas.CAS |
deserializeCAS(java.lang.String aSerializedCAS,
java.lang.String aCasPoolName) |
void |
doStop() |
protected java.util.concurrent.ConcurrentHashMap |
getCache() |
org.apache.uima.cas.CAS |
getCAS()
Returns a CAS.
|
protected abstract MessageSender |
getDispatcher() |
abstract java.lang.String |
getEndPointName() |
protected javax.jms.MessageProducer |
getMessageProducer(javax.jms.Destination destination) |
org.apache.uima.resource.metadata.ProcessingResourceMetaData |
getMetaData()
Gets the ProcessingResourceMetadata for the asynchronous AnalysisEngine.
|
java.lang.String |
getPerformanceReport()
Not implemented
|
java.lang.String |
getSerializationStrategy()
Returns serialization strategy for the remote service.
|
protected void |
handleCollectionProcessCompleteReply(javax.jms.Message message)
Handles response to CollectionProcessComplete request.
|
protected void |
handleException(java.lang.Exception exception,
java.lang.String casReferenceId,
java.lang.String inputCasReferenceId,
BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest,
boolean doNotify) |
protected void |
handleException(java.lang.Exception exception,
java.lang.String casReferenceId,
java.lang.String inputCasReferenceId,
BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest,
boolean doNotify,
boolean rethrow) |
protected void |
handleException(javax.jms.Message message,
BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest,
boolean doNotify) |
protected void |
handleMetadataReply(javax.jms.Message message)
Handles response to GetMeta Request.
|
protected void |
handleNonProcessException(java.lang.Exception exception) |
protected void |
handleProcessReply(javax.jms.Message message,
boolean doNotify,
org.apache.uima.util.ProcessTrace pt)
Handles response to Process CAS request.
|
protected void |
handleServiceInfo(javax.jms.Message message)
Handles a ServiceInfo message returned from the Cas Multiplier.
|
abstract void |
initialize(java.util.Map anApplicationContext)
Initializes UIMA asynchronous client using configuration parameters provided in a Map object.
|
protected abstract void |
initializeConsumer(java.lang.String aBrokerURI,
javax.jms.Connection connection) |
protected void |
notifyListeners(org.apache.uima.cas.CAS aCAS,
org.apache.uima.collection.EntityProcessStatus aStatus,
int aCommand) |
protected void |
notifyOnTimout(org.apache.uima.cas.CAS aCAS,
java.lang.String anEndpoint,
int aTimeoutKind,
java.lang.String casReferenceId) |
void |
onBeforeMessageSend(UimaASProcessStatus status) |
void |
onException(java.lang.Exception aFailure,
java.lang.String aDestination) |
void |
onMessage(javax.jms.Message message)
Listener method receiving JMS Messages from the response queue.
|
protected void |
onProducerInitialized()
Called when the producer thread is fully initialized
|
void |
process()
Initiates processing of a collection.
|
boolean |
recoverSharedConnectionIfClosed()
Continuously tries to recover connection a broker.
|
protected void |
removeFromCache(java.lang.String aCasReferenceId) |
void |
removeStatusCallbackListener(UimaAsBaseCallbackListener aListener)
Unregisters named application listener.
|
protected void |
reset() |
java.lang.String |
sendAndReceiveCAS(org.apache.uima.cas.CAS aCAS)
This synchronous method sends a given CAS to a UIMA AS service and waits for response.
|
java.lang.String |
sendAndReceiveCAS(org.apache.uima.cas.CAS aCAS,
org.apache.uima.util.ProcessTrace pt)
This is a synchronous method which sends a message to a destination and blocks waiting for a
reply.
|
java.lang.String |
sendCAS(org.apache.uima.cas.CAS aCAS)
Sends a given CAS for analysis to the UIMA EE Service.
|
protected void |
sendMetaRequest() |
protected java.lang.String |
serializeCAS(org.apache.uima.cas.CAS aCAS) |
protected java.lang.String |
serializeCAS(org.apache.uima.cas.CAS aCAS,
org.apache.uima.cas.impl.XmiSerializationSharedData serSharedData)
Serializes a given CAS.
|
protected abstract void |
setCASMessage(java.lang.String casReferenceId,
byte[] aSerializedCAS,
javax.jms.Message msg) |
protected abstract void |
setCASMessage(java.lang.String casReferenceId,
org.apache.uima.cas.CAS aCAS,
javax.jms.Message msg) |
protected abstract void |
setCASMessage(java.lang.String casReferenceId,
java.lang.String aSerializedCAS,
javax.jms.Message msg) |
void |
setCollectionReader(org.apache.uima.collection.CollectionReader aCollectionReader)
Registers a
CollectionReader instance to process a Collection. |
abstract void |
setCPCMessage(javax.jms.Message msg) |
protected abstract void |
setMetaRequestMessage(javax.jms.Message msg) |
protected void |
setReleaseCASMessage(javax.jms.TextMessage msg,
java.lang.String aCasReferenceId) |
protected void |
setSerializationStrategy(java.lang.String aSerializationStrategy) |
protected void |
waitForCpcReply() |
protected void |
waitForMetadataReply()
Blocks while trying to acquire a semaphore awaiting receipt of GetMeta Reply.
|
protected void |
wakeUpSendThread(BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
deploy, stop, stopProducingCases, stopProducingCases, undeploy, undeploy
protected BaseUIMAAsynchronousEngineCommon_impl.ClientState state
protected static final java.lang.String SHADOW_CAS_POOL
protected static final int MetadataTimeout
protected static final int CpCTimeout
protected static final int ProcessTimeout
protected static final int PingTimeout
protected volatile boolean initialized
protected java.util.List listeners
protected AsynchAECasManager asynchManager
protected boolean remoteService
protected org.apache.uima.collection.CollectionReader collectionReader
protected volatile boolean running
protected org.apache.uima.resource.metadata.ProcessingResourceMetaData resourceMetadata
protected org.apache.uima.cas.CAS sendAndReceiveCAS
protected UIDGenerator idGenerator
protected java.util.concurrent.ConcurrentHashMap<java.lang.String,BaseUIMAAsynchronousEngineCommon_impl.ClientRequest> clientCache
protected java.util.concurrent.ConcurrentHashMap<java.lang.Long,BaseUIMAAsynchronousEngineCommon_impl.ThreadMonitor> threadMonitorMap
protected int processTimeout
protected int metadataTimeout
protected int cpcTimeout
protected volatile boolean abort
protected static final java.lang.String uniqueIdentifier
protected java.lang.Exception exc
protected java.util.concurrent.atomic.AtomicLong outstandingCasRequests
protected java.util.concurrent.atomic.AtomicLong totalCasRequestsSentBetweenCpCs
protected java.util.concurrent.ConcurrentHashMap springContainerRegistry
protected javax.jms.MessageConsumer consumer
protected java.lang.String serializationStrategy
protected UimaASClientInfoMBean clientSideJmxStats
protected ClientServiceDelegate serviceDelegate
protected java.util.concurrent.BlockingQueue<PendingMessage> pendingMessageQueue
protected java.util.concurrent.Semaphore producerSemaphore
protected java.util.concurrent.Semaphore cpcSemaphore
protected java.util.concurrent.Semaphore getMetaSemaphore
protected java.util.concurrent.Semaphore cpcReadySemaphore
protected java.util.concurrent.Semaphore cpcReplySemaphore
protected volatile boolean producerInitialized
protected static BaseUIMAAsynchronousEngineCommon_impl.SharedConnection sharedConnection
protected java.lang.Thread shutdownHookThread
public BaseUIMAAsynchronousEngineCommon_impl()
public abstract java.lang.String getEndPointName() throws java.lang.Exception
java.lang.Exception
protected abstract javax.jms.TextMessage createTextMessage() throws java.lang.Exception
java.lang.Exception
protected abstract javax.jms.BytesMessage createBytesMessage() throws java.lang.Exception
java.lang.Exception
protected abstract void setMetaRequestMessage(javax.jms.Message msg) throws java.lang.Exception
java.lang.Exception
protected abstract void setCASMessage(java.lang.String casReferenceId, org.apache.uima.cas.CAS aCAS, javax.jms.Message msg) throws java.lang.Exception
java.lang.Exception
protected abstract void setCASMessage(java.lang.String casReferenceId, java.lang.String aSerializedCAS, javax.jms.Message msg) throws java.lang.Exception
java.lang.Exception
protected abstract void setCASMessage(java.lang.String casReferenceId, byte[] aSerializedCAS, javax.jms.Message msg) throws java.lang.Exception
java.lang.Exception
public abstract void setCPCMessage(javax.jms.Message msg) throws java.lang.Exception
java.lang.Exception
public abstract void initialize(java.util.Map anApplicationContext) throws org.apache.uima.resource.ResourceInitializationException
UimaAsynchronousEngine
UimaASStatusCallbackListener.initializationComplete(EntityProcessStatus)
on the application listener.initialize
in interface UimaAsynchronousEngine
anApplicationContext
- - configuration containing UIMA EE Service Broker URI, service queue name, timeout
value, reply window size, and CAS Pool size.org.apache.uima.resource.ResourceInitializationException
protected abstract void cleanup() throws java.lang.Exception
java.lang.Exception
public abstract java.lang.String deploy(java.lang.String[] aDeploymentDescriptorList, java.util.Map anApplicationContext) throws java.lang.Exception
UimaAsynchronousEngine
deploy
in interface UimaAsynchronousEngine
aDeploymentDescriptorList
- - a list of deployment descriptors to deploy in a container.anApplicationContext
- - initialization parameters needed to configure the client and servicesjava.lang.Exception
- - if there was a problem deploying the container or UIMA AS services.protected abstract java.lang.String deploySpringContainer(java.lang.String[] springContextFiles) throws org.apache.uima.resource.ResourceInitializationException
org.apache.uima.resource.ResourceInitializationException
protected abstract MessageSender getDispatcher()
protected abstract void initializeConsumer(java.lang.String aBrokerURI, javax.jms.Connection connection) throws java.lang.Exception
java.lang.Exception
public void addStatusCallbackListener(UimaAsBaseCallbackListener aListener)
UimaAsynchronousEngine
addStatusCallbackListener
in interface UimaAsynchronousEngine
aListener
- - application listener object to addpublic java.lang.String getSerializationStrategy()
UimaAsynchronousEngine
getSerializationStrategy
in interface UimaAsynchronousEngine
protected void setSerializationStrategy(java.lang.String aSerializationStrategy)
protected java.lang.String serializeCAS(org.apache.uima.cas.CAS aCAS, org.apache.uima.cas.impl.XmiSerializationSharedData serSharedData) throws java.lang.Exception
aCAS
- - CAS to serializejava.lang.Exception
protected java.lang.String serializeCAS(org.apache.uima.cas.CAS aCAS) throws java.lang.Exception
java.lang.Exception
public void removeStatusCallbackListener(UimaAsBaseCallbackListener aListener)
UimaAsynchronousEngine
removeStatusCallbackListener
in interface UimaAsynchronousEngine
aListener
- - application listener to removepublic void onBeforeMessageSend(UimaASProcessStatus status)
public void setCollectionReader(org.apache.uima.collection.CollectionReader aCollectionReader) throws org.apache.uima.resource.ResourceInitializationException
UimaAsynchronousEngine
CollectionReader
instance to process a Collection. This method must be
called first, before calling UimaAsynchronousEngine.process()
method.setCollectionReader
in interface UimaAsynchronousEngine
aCollectionReader
- - instance of a CollectionReader
org.apache.uima.resource.ResourceInitializationException
protected void acquireCpcReadySemaphore()
public void collectionProcessingComplete() throws org.apache.uima.resource.ResourceProcessException
UimaAsynchronousEngine
collectionProcessingComplete
in interface UimaAsynchronousEngine
org.apache.uima.resource.ResourceProcessException
public void doStop()
public org.apache.uima.cas.CAS getCAS() throws java.lang.Exception
getCAS
in interface UimaAsynchronousEngine
java.lang.Exception
protected void reset()
protected void sendMetaRequest() throws java.lang.Exception
java.lang.Exception
protected void waitForCpcReply()
protected void waitForMetadataReply()
public java.lang.String getPerformanceReport()
UimaAsynchronousEngine
getPerformanceReport
in interface UimaAsynchronousEngine
public void process() throws org.apache.uima.resource.ResourceProcessException
UimaAsynchronousEngine
CollectionReader
is provided via
UimaAsynchronousEngine.setCollectionReader(CollectionReader)
. This method blocks until the CollectionReader
finishes processing the entire collection. Status of the processing can be obtained by
registering a listener with the
UimaAsynchronousEngine.addStatusCallbackListener(UimaAsBaseCallbackListener)
method.
The method is synchronized to allow processing of only one collection at a time. The
application must wait with processing another collection until it receives notification via a
listener
UimaASStatusCallbackListener.collectionProcessComplete(EntityProcessStatus aStatus)
process
in interface UimaAsynchronousEngine
org.apache.uima.resource.ResourceProcessException
- - if there is a problem processing the Collectionprotected java.util.concurrent.ConcurrentHashMap getCache()
public boolean delayCasIfDelegateInTimedOutState(java.lang.String aCasReferenceId) throws AsynchAEException
AsynchAEException
public java.lang.String sendCAS(org.apache.uima.cas.CAS aCAS) throws org.apache.uima.resource.ResourceProcessException
sendCAS
in interface UimaAsynchronousEngine
aCAS
- - a CAS to analyze.org.apache.uima.resource.ResourceProcessException
protected void handleCollectionProcessCompleteReply(javax.jms.Message message) throws java.lang.Exception
java.lang.Exception
protected void handleMetadataReply(javax.jms.Message message) throws java.lang.Exception
message
- - jms message containing serialized ResourceMetaDatajava.lang.Exception
protected void notifyListeners(org.apache.uima.cas.CAS aCAS, org.apache.uima.collection.EntityProcessStatus aStatus, int aCommand)
protected void cancelTimer(java.lang.String identifier)
protected void wakeUpSendThread(BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest) throws java.lang.Exception
java.lang.Exception
protected void handleServiceInfo(javax.jms.Message message) throws java.lang.Exception
message
- - message received from a servicejava.lang.Exception
protected void decrementOutstandingCasCounter()
protected void handleProcessReply(javax.jms.Message message, boolean doNotify, org.apache.uima.util.ProcessTrace pt) throws java.lang.Exception
message
- - jms message containing serialized CASjava.lang.Exception
protected void handleNonProcessException(java.lang.Exception exception) throws java.lang.Exception
java.lang.Exception
protected void handleException(java.lang.Exception exception, java.lang.String casReferenceId, java.lang.String inputCasReferenceId, BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest, boolean doNotify) throws java.lang.Exception
java.lang.Exception
protected void handleException(java.lang.Exception exception, java.lang.String casReferenceId, java.lang.String inputCasReferenceId, BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest, boolean doNotify, boolean rethrow) throws java.lang.Exception
java.lang.Exception
protected void handleException(javax.jms.Message message, BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest, boolean doNotify) throws java.lang.Exception
java.lang.Exception
protected void removeFromCache(java.lang.String aCasReferenceId)
protected org.apache.uima.cas.CAS deserialize(java.lang.String aSerializedCAS, org.apache.uima.cas.CAS aCAS) throws java.lang.Exception
java.lang.Exception
protected org.apache.uima.cas.CAS deserialize(java.lang.String aSerializedCAS, org.apache.uima.cas.CAS aCAS, org.apache.uima.cas.impl.XmiSerializationSharedData deserSharedData, boolean deltaCas) throws java.lang.Exception
java.lang.Exception
protected org.apache.uima.cas.CAS deserialize(byte[] binaryData, BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest) throws java.lang.Exception
java.lang.Exception
protected org.apache.uima.cas.CAS deserializeCAS(java.lang.String aSerializedCAS, BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest) throws java.lang.Exception
java.lang.Exception
protected org.apache.uima.cas.CAS deserializeCAS(byte[] aSerializedCAS, BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest) throws java.lang.Exception
java.lang.Exception
protected org.apache.uima.cas.CAS deserializeCAS(byte[] aSerializedCAS, org.apache.uima.cas.CAS aCas) throws java.lang.Exception
java.lang.Exception
protected org.apache.uima.cas.CAS deserializeCAS(java.lang.String aSerializedCAS, BaseUIMAAsynchronousEngineCommon_impl.ClientRequest cachedRequest, boolean deltaCas) throws java.lang.Exception
java.lang.Exception
protected org.apache.uima.cas.CAS deserializeCAS(java.lang.String aSerializedCAS, java.lang.String aCasPoolName) throws java.lang.Exception
java.lang.Exception
protected org.apache.uima.cas.CAS deserializeCAS(byte[] aSerializedCAS, java.lang.String aCasPoolName) throws java.lang.Exception
java.lang.Exception
public void onMessage(javax.jms.Message message)
onMessage
in interface javax.jms.MessageListener
public org.apache.uima.resource.metadata.ProcessingResourceMetaData getMetaData() throws org.apache.uima.resource.ResourceInitializationException
getMetaData
in interface UimaAsynchronousEngine
org.apache.uima.resource.ResourceInitializationException
public java.lang.String sendAndReceiveCAS(org.apache.uima.cas.CAS aCAS, org.apache.uima.util.ProcessTrace pt) throws org.apache.uima.resource.ResourceProcessException
org.apache.uima.resource.ResourceProcessException
public java.lang.String sendAndReceiveCAS(org.apache.uima.cas.CAS aCAS) throws org.apache.uima.resource.ResourceProcessException
UimaAsynchronousEngine
sendAndReceiveCAS
in interface UimaAsynchronousEngine
aCAS
- - a CAS to analyze.org.apache.uima.resource.ResourceProcessException
protected void notifyOnTimout(org.apache.uima.cas.CAS aCAS, java.lang.String anEndpoint, int aTimeoutKind, java.lang.String casReferenceId)
protected javax.jms.MessageProducer getMessageProducer(javax.jms.Destination destination) throws java.lang.Exception
java.lang.Exception
protected void onProducerInitialized()
public boolean connectionOpen()
public boolean recoverSharedConnectionIfClosed()
public void onException(java.lang.Exception aFailure, java.lang.String aDestination)
protected void setReleaseCASMessage(javax.jms.TextMessage msg, java.lang.String aCasReferenceId) throws java.lang.Exception
java.lang.Exception
Copyright © 2014. All Rights Reserved.