public abstract class AbstractConnector extends Object implements Connector, ExceptionListener, Connectable, javax.resource.spi.work.WorkListener
AbstractConnector
provides base functionality for all connectors
provided with Mule. Connectors are the mechanism used to connect to external
systems and protocols in order to send and receive data. The
AbstractConnector
provides getter and setter methods for endpoint
name, transport name and protocol. It also provides methods to stop and start
connecotors and sets up a dispatcher threadpool which allows deriving connectors
the possibility to dispatch work to separate threads. This functionality is
controlled with the doThreading property on the threadingProfiles for
dispachers and receivers. The lifecycle for a connector is -
Modifier and Type | Field and Description |
---|---|
protected WaitableBoolean |
connected |
protected Semaphore |
connectedSemaphore
If doThreading is used in ReconnectingStrategy receivers must wait for
connector to connect before they connect.
|
protected WaitableBoolean |
connecting |
protected ConnectionStrategy |
connectionStrategy |
protected boolean |
createMultipleTransactedReceivers |
static int |
DEFAULT_NUM_CONCURRENT_TX_RECEIVERS
Default number of concurrent transactional receivers.
|
protected MessageDispatcherFactory |
dispatcherFactory
Factory used to create dispatchers for this connector
|
protected org.apache.commons.pool.impl.GenericKeyedObjectPool |
dispatchers
A pool of dispatchers for this connector, keyed by endpoint
|
protected AtomicBoolean |
disposed
Determines in the connector is alive and well
|
protected AtomicBoolean |
disposing
Determines in connector has been told to dispose
|
protected ExceptionListener |
exceptionListener
The exception strategy used by this connector
|
protected AtomicBoolean |
initialised
True once the endpoint has been initialsed
|
protected org.apache.commons.logging.Log |
logger
logger used by this class
|
protected MuleContext |
muleContext |
protected String |
name
The name that identifies the endpoint
|
protected int |
numberOfConcurrentTransactedReceivers |
protected ConcurrentMap |
receivers
The collection of listeners on this connector.
|
protected MessageRequesterFactory |
requesterFactory
Factory used to create requesters for this connector
|
protected org.apache.commons.pool.impl.GenericKeyedObjectPool |
requesters
A pool of requesters for this connector, keyed by endpoint
|
protected TransportServiceDescriptor |
serviceDescriptor
Holds the service configuration for this connector
|
protected Properties |
serviceOverrides
The map of service overrides that can be used to extend the capabilities of the
connector
|
protected SessionHandler |
sessionHandler
The strategy used for reading and writing session information to and fromt he
transport
|
protected AtomicBoolean |
started
Specifies if the endpoint started
|
protected WaitableBoolean |
startOnConnect
If the connect method was called via the start method, this will be set so
that when the connector comes on line it will be started
|
INT_VALUE_NOT_SET
PHASE_NAME
PHASE_NAME
PHASE_NAME
PHASE_NAME
Constructor and Description |
---|
AbstractConnector() |
Modifier and Type | Method and Description |
---|---|
protected void |
checkDisposed() |
void |
connect()
Make the connection to the underlying transport.
|
protected MessageReceiver |
createReceiver(Service service,
InboundEndpoint endpoint)
Create a Message receiver for this connector
|
void |
destroyReceiver(MessageReceiver receiver,
InboundEndpoint endpoint) |
void |
disconnect()
Disconnect the from the underlying transport
|
void |
dispatch(OutboundEndpoint endpoint,
MuleEvent event)
Dispatches an event from the endpoint to the external system
|
void |
dispose()
A lifecycle method where implementor should free up any resources.
|
protected void |
disposeDispatchers() |
protected void |
disposeReceivers() |
protected void |
disposeRequesters() |
protected void |
disposeWorkManagers() |
protected abstract void |
doConnect()
Template method where any connections should be made for the connector
|
protected abstract void |
doDisconnect()
Template method where any connected resources used by the connector should be
disconnected
|
protected abstract void |
doDispose()
Template method to perform any work when destroying the connectoe
|
protected abstract void |
doInitialise() |
protected abstract void |
doStart()
Template method to perform any work when starting the connectoe
|
protected abstract void |
doStop()
Template method to perform any work when stopping the connectoe
|
void |
exceptionThrown(Exception e) |
void |
fireNotification(ServerNotification notification)
Fires a server notification to all registered listeners
|
Semaphore |
getConnectedSemaphore() |
protected String |
getConnectEventId()
The resource id used when firing ConnectEvents from this connector
|
String |
getConnectionDescription()
Returns a string identifying the underlying resource
|
ConnectionStrategy |
getConnectionStrategy()
Getter for property 'connectionStrategy'.
|
List |
getDefaultInboundTransformers() |
List |
getDefaultOutboundTransformers() |
List |
getDefaultResponseTransformers() |
MessageDispatcherFactory |
getDispatcherFactory()
The dispatcher factory is used to create a message dispatcher of the current
request
|
ThreadingProfile |
getDispatcherThreadingProfile()
Getter for property 'dispatcherThreadingProfile'.
|
protected WorkManager |
getDispatcherWorkManager()
Returns a work manager for message dispatchers.
|
ExceptionListener |
getExceptionListener() |
int |
getMaxDispatchersActive()
Returns the maximum number of dispatchers that can be concurrently active per
endpoint.
|
int |
getMaxRequestersActive()
Returns the maximum number of requesters that can be concurrently active per
endpoint.
|
MessageAdapter |
getMessageAdapter(Object message)
Gets a
MessageAdapter for the endpoint for the given message
(data) |
MuleContext |
getMuleContext() |
String |
getName()
Gts the name of the object
|
int |
getNumberOfConcurrentTransactedReceivers()
Returns the number of concurrent receivers that will be launched when
isCreateMultipleTransactedReceivers() returns true . |
OutputStream |
getOutputStream(OutboundEndpoint endpoint,
MuleMessage message)
Will get the output stream for this type of transport.
|
MessageReceiver |
getReceiver(Service service,
InboundEndpoint endpoint) |
protected Object |
getReceiverKey(Service service,
InboundEndpoint endpoint)
The method determines the key used to store the receiver against.
|
Map |
getReceivers()
Getter for property 'receivers'.
|
MessageReceiver[] |
getReceivers(String wildcardExpression) |
ThreadingProfile |
getReceiverThreadingProfile()
Getter for property 'receiverThreadingProfile'.
|
protected WorkManager |
getReceiverWorkManager(String receiverName)
Returns a work manager for message receivers.
|
ReplyToHandler |
getReplyToHandler()
Getter for property 'replyToHandler'.
|
MessageRequesterFactory |
getRequesterFactory()
The requester factory is used to create a message requester of the current
request
|
ThreadingProfile |
getRequesterThreadingProfile()
Getter for property 'requesterThreadingProfile'.
|
protected WorkManager |
getRequesterWorkManager()
Returns a work manager for message requesters.
|
ScheduledExecutorService |
getScheduler()
Returns a Scheduler service for periodic tasks, currently limited to internal
use.
|
protected TransportServiceDescriptor |
getServiceDescriptor()
Get the
TransportServiceDescriptor for this connector. |
Map |
getServiceOverrides()
A map of fully qualified class names that should override those in the
connectors' service descriptor This map will be null if there are no overrides
|
SessionHandler |
getSessionHandler()
Getter for property 'sessionHandler'.
|
List |
getSupportedProtocols()
Returns an unmodifiable list of the protocols supported by this connector
|
void |
handleException(Exception exception) |
protected void |
handleWorkException(javax.resource.spi.work.WorkEvent event,
String type) |
protected void |
initFromServiceDescriptor()
Initialises this connector from its
TransportServiceDescriptor This
will be called before the doInitialise() method is called. |
void |
initialise()
Method used to perform any initialisation work.
|
void |
initialiseFromUrl(EndpointURI endpointUri)
When this connector is created via the
TransportFactory the endpoint used to
determine the connector type is passed to this method so that any properties
set on the endpoint that can be used to initialise the connector are made
available. |
protected void |
initWorkManagers() |
boolean |
isConnected()
Determines if this object is connected or not
|
boolean |
isCreateMultipleTransactedReceivers()
For better throughput when using TransactedMessageReceivers this will enable a
number of concurrent receivers, based on the value returned by
getNumberOfConcurrentTransactedReceivers() . |
boolean |
isDisposed() |
boolean |
isDisposing() |
protected boolean |
isEnableMessageEvents() |
boolean |
isRemoteSyncEnabled() |
boolean |
isStarted() |
boolean |
isSyncEnabled(String protocol)
Used to define is this connectors endpoints' should be synchronous by default rather than
using Mule's instance wide default.
|
MessageReceiver |
lookupReceiver(String key) |
MessageReceiver |
registerListener(Service service,
InboundEndpoint endpoint)
This creates a
MessageReceiver associated with this endpoint
and registers it with the connector |
void |
registerSupportedProtocol(String protocol)
Registers other protocols 'understood' by this connector.
|
protected void |
registerSupportedProtocolWithoutPrefix(String protocol)
Registers other protocols 'understood' by this connector.
|
MuleMessage |
request(InboundEndpoint endpoint,
long timeout)
Make a specific request to the underlying transport
|
MuleMessage |
request(String uri,
long timeout)
Make a specific request to the underlying transport
|
MuleMessage |
send(OutboundEndpoint endpoint,
MuleEvent event)
Sends an event from the endpoint to the external system
|
void |
setConnectionStrategy(ConnectionStrategy connectionStrategy)
Setter for property 'connectionStrategy'.
|
void |
setCreateMultipleTransactedReceivers(boolean createMultipleTransactedReceivers) |
void |
setDispatcherFactory(MessageDispatcherFactory dispatcherFactory)
The dispatcher factory is used to create a message dispatcher of the current
request
|
void |
setDispatcherThreadingProfile(ThreadingProfile dispatcherThreadingProfile)
Setter for property 'dispatcherThreadingProfile'.
|
void |
setDynamicNotification(boolean dynamic) |
void |
setExceptionListener(ExceptionListener listener) |
void |
setMaxDispatchersActive(int maxActive)
Configures the maximum number of dispatchers that can be concurrently active
per endpoint
|
void |
setMaxRequestersActive(int maxActive)
Configures the maximum number of requesters that can be concurrently active
per endpoint
|
void |
setMuleContext(MuleContext context) |
void |
setName(String newName)
Sets the name of the object
|
void |
setNumberOfConcurrentTransactedReceivers(int count) |
void |
setReceiverThreadingProfile(ThreadingProfile receiverThreadingProfile)
Setter for property 'receiverThreadingProfile'.
|
void |
setRequesterFactory(MessageRequesterFactory requesterFactory)
The requester factory is used to create a message requester of the current
request
|
void |
setRequesterThreadingProfile(ThreadingProfile requesterThreadingProfile)
Setter for property 'requesterThreadingProfile'.
|
void |
setServiceOverrides(Map serviceOverrides)
Set the Service overrides on this connector.
|
void |
setSessionHandler(SessionHandler sessionHandler)
Setter for property 'sessionHandler'.
|
void |
setSupportedProtocols(List supportedProtocols)
Sets A list of protocols that the connector can accept
|
protected void |
setupDispatchReturn(OutboundEndpoint endpoint,
MessageDispatcher dispatcher,
MuleMessage result)
This method will return the dispatcher to the pool or, if the payload is an inputstream,
replace the payload with a new DelegatingInputStream which returns the dispatcher to
the pool when the stream is closed.
|
protected void |
setupRequestReturn(InboundEndpoint endpoint,
MessageRequester requester,
MuleMessage result)
This method will return the requester to the pool or, if the payload is an inputstream,
replace the payload with a new DelegatingInputStream which returns the requester to
the pool when the stream is closed.
|
void |
start() |
void |
stop() |
boolean |
supportsProtocol(String protocol) |
String |
toString() |
void |
unregisterListener(Service service,
InboundEndpoint endpoint) |
void |
unregisterSupportedProtocol(String protocol) |
protected void |
updateCachedNotificationHandler() |
void |
workAccepted(javax.resource.spi.work.WorkEvent event) |
void |
workCompleted(javax.resource.spi.work.WorkEvent event) |
void |
workRejected(javax.resource.spi.work.WorkEvent event) |
void |
workStarted(javax.resource.spi.work.WorkEvent event) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
getProtocol
public static final int DEFAULT_NUM_CONCURRENT_TX_RECEIVERS
protected final org.apache.commons.logging.Log logger
protected final AtomicBoolean started
protected final AtomicBoolean initialised
protected volatile String name
protected volatile ExceptionListener exceptionListener
protected final AtomicBoolean disposed
protected final AtomicBoolean disposing
protected volatile MessageDispatcherFactory dispatcherFactory
protected volatile MessageRequesterFactory requesterFactory
protected final org.apache.commons.pool.impl.GenericKeyedObjectPool dispatchers
protected final org.apache.commons.pool.impl.GenericKeyedObjectPool requesters
protected final ConcurrentMap receivers
protected volatile boolean createMultipleTransactedReceivers
#isCreateMultipleTransactedReceivers()}
protected volatile int numberOfConcurrentTransactedReceivers
#getNumberOfConcurrentTransactedReceivers()}
protected volatile ConnectionStrategy connectionStrategy
protected final Semaphore connectedSemaphore
protected final WaitableBoolean connected
protected final WaitableBoolean connecting
protected final WaitableBoolean startOnConnect
protected volatile TransportServiceDescriptor serviceDescriptor
protected volatile Properties serviceOverrides
protected volatile SessionHandler sessionHandler
protected MuleContext muleContext
public String getName()
NamedObject
getName
in interface NamedObject
public void setName(String newName)
NamedObject
setName
in interface NamedObject
newName
- the name of the objectpublic final void initialise() throws InitialisationException
Initialisable
InitialisationException
should be thrown,
causing the Mule instance to shutdown. If the error is recoverable, say by
retrying to connect, a RecoverableException
should be thrown.
There is no guarantee that by throwing a Recoverable exception that the Mule
instance will not shut down.initialise
in interface Initialisable
InitialisationException
- if a fatal error occurs causing the Mule instance to shutdownRecoverableException
- if an error occurs that can be recovered frompublic final void start() throws MuleException
start
in interface Startable
MuleException
public boolean isStarted()
public final void stop() throws MuleException
stop
in interface Stoppable
MuleException
public final void dispose()
Disposable
dispose
in interface Disposable
protected void initWorkManagers() throws MuleException
MuleException
protected void disposeWorkManagers()
protected void disposeReceivers()
protected void disposeDispatchers()
protected void disposeRequesters()
public boolean isDisposed()
isDisposed
in interface Connector
public void handleException(Exception exception)
handleException
in interface Connector
exception
- the exception that was caughtpublic void exceptionThrown(Exception e)
exceptionThrown
in interface ExceptionListener
public ExceptionListener getExceptionListener()
getExceptionListener
in interface Connector
ExceptionListener
public void setExceptionListener(ExceptionListener listener)
setExceptionListener
in interface Connector
listener
- the ExceptionStrategy to use with this endpointExceptionListener
public MessageDispatcherFactory getDispatcherFactory()
Connector
getDispatcherFactory
in interface Connector
public void setDispatcherFactory(MessageDispatcherFactory dispatcherFactory)
Connector
setDispatcherFactory
in interface Connector
dispatcherFactory
- The dispatcherFactory to set.public MessageRequesterFactory getRequesterFactory()
Connector
getRequesterFactory
in interface Connector
public void setRequesterFactory(MessageRequesterFactory requesterFactory)
Connector
setRequesterFactory
in interface Connector
requesterFactory
- The requesterFactory to set.public int getMaxDispatchersActive()
public void setMaxDispatchersActive(int maxActive)
maxActive
- max. number of active dispatcherspublic int getMaxRequestersActive()
public void setMaxRequestersActive(int maxActive)
maxActive
- max. number of active requestersprotected void checkDisposed() throws DisposeException
DisposeException
public MessageReceiver registerListener(Service service, InboundEndpoint endpoint) throws Exception
Connector
MessageReceiver
associated with this endpoint
and registers it with the connectorregisterListener
in interface Connector
service
- the listening serviceendpoint
- the endpoint contains the listener endpointUri on which to
listen on.Exception
- if the MessageReceiver cannot be created or the Receiver
cannot be registeredprotected Object getReceiverKey(Service service, InboundEndpoint endpoint)
service
- the service for which the endpoint is being registeredendpoint
- the endpoint being registered for the servicepublic final void unregisterListener(Service service, InboundEndpoint endpoint) throws Exception
unregisterListener
in interface Connector
service
- the listening serviceendpoint
- the associated endpointDescriptor with the listenerException
- if the listener cannot be unregistered. If a listener is not
associated with the given endpoint this will not throw an
exceptionpublic ThreadingProfile getDispatcherThreadingProfile()
public void setDispatcherThreadingProfile(ThreadingProfile dispatcherThreadingProfile)
dispatcherThreadingProfile
- Value to set for property
'dispatcherThreadingProfile'.public ThreadingProfile getRequesterThreadingProfile()
public void setRequesterThreadingProfile(ThreadingProfile requesterThreadingProfile)
requesterThreadingProfile
- Value to set for property
'requesterThreadingProfile'.public ThreadingProfile getReceiverThreadingProfile()
public void setReceiverThreadingProfile(ThreadingProfile receiverThreadingProfile)
receiverThreadingProfile
- Value to set for property
'receiverThreadingProfile'.public void destroyReceiver(MessageReceiver receiver, InboundEndpoint endpoint) throws Exception
Exception
protected abstract void doInitialise() throws InitialisationException
InitialisationException
protected abstract void doDispose()
protected abstract void doStart() throws MuleException
MuleException
- if the method failsprotected abstract void doStop() throws MuleException
MuleException
- if the method failspublic List getDefaultInboundTransformers()
public List getDefaultResponseTransformers()
public List getDefaultOutboundTransformers()
public ReplyToHandler getReplyToHandler()
public void fireNotification(ServerNotification notification)
notification
- the notification to fire.public ConnectionStrategy getConnectionStrategy()
public void setConnectionStrategy(ConnectionStrategy connectionStrategy)
connectionStrategy
- Value to set for property 'connectionStrategy'.public boolean isDisposing()
isDisposing
in interface Connector
public boolean isRemoteSyncEnabled()
isRemoteSyncEnabled
in interface Connector
public boolean isSyncEnabled(String protocol)
Connector
isSyncEnabled
in interface Connector
ImmutableEndpoint#isSynchronous()
public MessageReceiver getReceiver(Service service, InboundEndpoint endpoint)
public Map getReceivers()
public MessageReceiver lookupReceiver(String key)
public MessageReceiver[] getReceivers(String wildcardExpression)
public void connect() throws Exception
Connectable
connect
in interface Connectable
Exception
public void disconnect() throws Exception
Connectable
disconnect
in interface Connectable
Exception
public String getConnectionDescription()
Connectable
getConnectionDescription
in interface Connectable
public final boolean isConnected()
Connectable
isConnected
in interface Connectable
protected abstract void doConnect() throws Exception
Exception
protected abstract void doDisconnect() throws Exception
Exception
protected String getConnectEventId()
public boolean isCreateMultipleTransactedReceivers()
getNumberOfConcurrentTransactedReceivers()
. This property is used by
transports that support transactions, specifically receivers that extend the
TransactedPollingMessageReceiver.public void setCreateMultipleTransactedReceivers(boolean createMultipleTransactedReceivers)
createMultipleTransactedReceivers
- if true, multiple receivers will be
created for this connection#isCreateMultipleTransactedReceivers()}
public int getNumberOfConcurrentTransactedReceivers()
isCreateMultipleTransactedReceivers()
returns true
.DEFAULT_NUM_CONCURRENT_TX_RECEIVERS
public void setNumberOfConcurrentTransactedReceivers(int count)
count
- the number of concurrent transacted receivers to start#getNumberOfConcurrentTransactedReceivers()}
public void setDynamicNotification(boolean dynamic)
protected void updateCachedNotificationHandler()
protected boolean isEnableMessageEvents()
public void registerSupportedProtocol(String protocol)
protocol
- the supported protocol to registerprotected void registerSupportedProtocolWithoutPrefix(String protocol)
registerSupportedProtocol(String)
method,
this allows you to register protocols that are not prefixed with the connector
protocol. This is useful where you use a Service Finder to discover which
Transport implementation to use. For example the 'wsdl' transport is a generic
'finder' transport that will use Axis, Xfire or Glue to create the WSDL
client. These transport protocols would be wsdl-axis, wsdl-xfire and
wsdl-glue, but they can all support 'wsdl' protocol too.protocol
- the supported protocol to registerpublic void unregisterSupportedProtocol(String protocol)
public boolean supportsProtocol(String protocol)
supportsProtocol
in interface Connector
public List getSupportedProtocols()
public void setSupportedProtocols(List supportedProtocols)
supportedProtocols
- protected WorkManager getReceiverWorkManager(String receiverName) throws MuleException
MuleException
protected WorkManager getDispatcherWorkManager() throws MuleException
MuleException
- in case of errorprotected WorkManager getRequesterWorkManager() throws MuleException
MuleException
- in case of errorpublic ScheduledExecutorService getScheduler()
public SessionHandler getSessionHandler()
public void setSessionHandler(SessionHandler sessionHandler)
sessionHandler
- Value to set for property 'sessionHandler'.public void workAccepted(javax.resource.spi.work.WorkEvent event)
workAccepted
in interface javax.resource.spi.work.WorkListener
public void workRejected(javax.resource.spi.work.WorkEvent event)
workRejected
in interface javax.resource.spi.work.WorkListener
public void workStarted(javax.resource.spi.work.WorkEvent event)
workStarted
in interface javax.resource.spi.work.WorkListener
public void workCompleted(javax.resource.spi.work.WorkEvent event)
workCompleted
in interface javax.resource.spi.work.WorkListener
protected void handleWorkException(javax.resource.spi.work.WorkEvent event, String type)
public void dispatch(OutboundEndpoint endpoint, MuleEvent event) throws DispatchException
Connector
dispatch
in interface Connector
event
- The event to dispatchDispatchException
- if the event fails to be dispatchedprotected void setupDispatchReturn(OutboundEndpoint endpoint, MessageDispatcher dispatcher, MuleMessage result)
endpoint
- dispatcher
- result
- public MuleMessage request(String uri, long timeout) throws Exception
Connector
request
in interface Connector
uri
- the endpoint uri to use when connecting to the resourcetimeout
- the maximum time the operation should block before returning.
The call should return immediately if there is data available. If
no data becomes available before the timeout elapses, null will be
returnedException
- if the call to the underlying protocal cuases an exceptionpublic MuleMessage request(InboundEndpoint endpoint, long timeout) throws Exception
Connector
request
in interface Connector
endpoint
- the endpoint to use when connecting to the resourcetimeout
- the maximum time the operation should block before returning.
The call should return immediately if there is data available. If
no data becomes available before the timeout elapses, null will be
returnedException
- if the call to the underlying protocal cuases an exceptionprotected void setupRequestReturn(InboundEndpoint endpoint, MessageRequester requester, MuleMessage result)
endpoint
- requester
- result
- public MuleMessage send(OutboundEndpoint endpoint, MuleEvent event) throws DispatchException
Connector
send
in interface Connector
event
- The event to sendDispatchException
- if the event fails to be dispatchedpublic void initialiseFromUrl(EndpointURI endpointUri) throws InitialisationException
TransportFactory
the endpoint used to
determine the connector type is passed to this method so that any properties
set on the endpoint that can be used to initialise the connector are made
available.endpointUri
- the EndpointURI
use to create this connectorInitialisationException
- If there are any problems with the
configuration set on the Endpoint or if another exception is
thrown it is wrapped in an InitialisationException.protected void initFromServiceDescriptor() throws InitialisationException
TransportServiceDescriptor
This
will be called before the doInitialise()
method is called.InitialisationException
- InitialisationException If there are any
problems with the configuration or if another exception is thrown
it is wrapped in an InitialisationException.protected TransportServiceDescriptor getServiceDescriptor()
TransportServiceDescriptor
for this connector. This will be
null if the connector was created by the developer. To create a connector the
proper way the developer should use the TransportFactory
and pass in
an endpoint.TransportServiceDescriptor
for this connectorprotected MessageReceiver createReceiver(Service service, InboundEndpoint endpoint) throws Exception
service
- the service that will receive events from this receiver,
the listenerendpoint
- the endpoint that defies this inbound communicationTransportServiceDescriptor
initialised using the service and endpoint.Exception
- if there is a problem creating the receiver. This exception
really depends on the underlying transport, thus any exception
could be thrownpublic MessageAdapter getMessageAdapter(Object message) throws MessagingException
MessageAdapter
for the endpoint for the given message
(data)getMessageAdapter
in interface Connector
message
- the data with which to initialise the
MessageAdapter
MessageAdapter
for the endpointMessagingException
- if the message parameter is not
supportedMessageAdapter
public Map getServiceOverrides()
public void setServiceOverrides(Map serviceOverrides)
serviceOverrides
- the override values to usepublic OutputStream getOutputStream(OutboundEndpoint endpoint, MuleMessage message) throws MuleException
UnsupportedOperationException
is thrown. Note that the stream MUST release resources on close. For help doing so, see
CallbackOutputStream
.getOutputStream
in interface Connector
endpoint
- the endpoint that releates to this Dispatchermessage
- the current message being processedMuleException
- in case of any errorpublic MuleContext getMuleContext()
getMuleContext
in interface Connector
public void setMuleContext(MuleContext context)
setMuleContext
in interface MuleContextAware
public Semaphore getConnectedSemaphore()
Copyright © 2003–2013 MuleSource, Inc.. All rights reserved.