Modifier and Type | Method and Description |
---|---|
void |
FaultHandler.handleFault(MessageContext synCtx) |
void |
FaultHandler.handleFault(MessageContext synCtx,
Exception e)
Extract and set ERROR_MESSAGE and ERROR_DETAIL to the message context from the Exception
|
boolean |
Mediator.mediate(MessageContext synCtx)
Invokes the mediator passing the current message for mediation.
|
abstract void |
FaultHandler.onFault(MessageContext synCtx)
This will be executed to handle any Exceptions occurred within the Synapse environment.
|
Modifier and Type | Method and Description |
---|---|
static AspectConfiguration |
AspectConfigurationDetectionStrategy.getAspectConfiguration(MessageContext synCtx)
Factory method to create the AspectConfiguration when there is no a defined main sequence and
only there is a set of mediators.
|
Modifier and Type | Method and Description |
---|---|
static ErrorLog |
ErrorLogFactory.createErrorLog(MessageContext synCtx)
Create an ErrorLog from the information in the synapse MessageContext
By default only the error code is logged and if the 'synapse.detailederrorlogging.enable'
has been set, then the error message, details and exception are also logged
|
static void |
StatisticsReporter.endReportForAllOnRequestProcessed(MessageContext synCtx)
Ends statistics reporting for any component after the request processed.
|
static StatisticsRecord |
StatisticsRecordFactory.getStatisticsRecord(MessageContext synCtx)
Factory method to create
StatisticsRecord instances |
static void |
StatisticsReporter.reportFaultForAll(MessageContext synCtx,
ErrorLog errorLog)
Reporting a fault for any component when a response for a request is received.
|
static void |
StatisticsReporter.reportForAllOnOutFlowEnd(MessageContext synCtx)
Reports statistics on the end of the out flow
|
static void |
StatisticsReporter.reportForAllOnResponseReceived(MessageContext synCtx)
Collects statistics for any component when a response for a request is received.
|
static void |
StatisticsReporter.reportForAllOnResponseSent(MessageContext synCtx)
Reports statistics for any component on the response message is sent
Any component means that this statistics log (check point) is valid for sequence, endpoint,
and proxy.
|
static void |
StatisticsReporter.reportForComponent(MessageContext synCtx,
StatisticsConfigurable configurable,
ComponentType componentType)
Collects statistics for the given component.This is the starting point of
collecting stats for a particular component
|
Modifier and Type | Method and Description |
---|---|
boolean |
AnonymousListMediator.mediate(MessageContext synCtx) |
boolean |
SwitchCase.mediate(MessageContext synCtx)
To delegate message mediation to list mediator
|
Modifier and Type | Method and Description |
---|---|
MessageContext |
SynapseEnvironment.createMessageContext()
Creates a new Synapse
MessageContext instance. |
Modifier and Type | Method and Description |
---|---|
void |
SynapseEnvironment.injectAsync(MessageContext smc,
SequenceMediator seq)
This method injects a new message into the Synapse engine for the mediation
by the specified sequence.
|
boolean |
SynapseEnvironment.injectMessage(MessageContext smc)
This method injects a new message into the Synapse engine.
|
void |
SynapseEnvironment.send(EndpointDefinition endpoint,
MessageContext smc)
This method allows a message to be sent through the underlying SOAP engine.
|
Modifier and Type | Class and Description |
---|---|
class |
Axis2MessageContext
This is the MessageContext implementation that synapse uses almost all the time because Synapse
is implemented on top of the Axis2
|
Modifier and Type | Method and Description |
---|---|
MessageContext |
Axis2SynapseEnvironment.createMessageContext()
This method will be used to create a new MessageContext in the Axis2 environment for
Synapse.
|
static MessageContext |
MessageContextCreatorForAxis2.getSynapseMessageContext(org.apache.axis2.context.MessageContext axisMsgCtx) |
MessageContext |
AsyncCallback.getSynapseOutMsgCtx() |
MessageContext |
Axis2BlockingClient.send(Endpoint endpoint,
MessageContext synapseInMsgCtx)
Send the message to a given Leaf endpoint (Address/WSDL/Default) in a blocking manner
|
Modifier and Type | Method and Description |
---|---|
static void |
BlockingClientUtils.fillClientOptions(EndpointDefinition endpoint,
org.apache.axis2.client.Options clientOptions,
MessageContext synapseInMsgCtx)
Fill client options extracting properties from the original message context and
endpoint definition
|
static void |
BlockingClientUtils.fillMessageContext(EndpointDefinition endpoint,
org.apache.axis2.context.MessageContext axisOutMsgCtx,
MessageContext synapseInMsgCtx)
Fill the target message context extracting the required properties of the original
message context and the endpoint
|
void |
Axis2SynapseEnvironment.injectAsync(MessageContext synCtx,
SequenceMediator seq) |
boolean |
Axis2SynapseEnvironment.injectMessage(MessageContext synCtx) |
void |
Axis2SynapseEnvironment.send(EndpointDefinition endpoint,
MessageContext synCtx)
This will be used for sending the message provided, to the endpoint specified by the
EndpointDefinition using the axis2 environment.
|
static void |
Axis2FlexibleMEPClient.send(EndpointDefinition endpoint,
MessageContext synapseOutMessageContext)
Based on the Axis2 client code.
|
MessageContext |
Axis2BlockingClient.send(Endpoint endpoint,
MessageContext synapseInMsgCtx)
Send the message to a given Leaf endpoint (Address/WSDL/Default) in a blocking manner
|
static void |
Axis2Sender.sendBack(MessageContext smc)
Send a response back to a client of Synapse
|
static void |
Axis2Sender.sendOn(EndpointDefinition endpoint,
MessageContext synapseInMessageContext)
Send a message out from the Synapse engine to an external service
|
Constructor and Description |
---|
AsyncCallback(MessageContext synapseOutMsgCtx) |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractEndpoint.evaluateProperties(MessageContext synCtx)
Evaluates the endpoint properties based on the current message context and set
the properties to the message context appropriately
|
protected String |
DynamicLoadbalanceEndpoint.extractSessionID(MessageContext synCtx,
String key) |
String |
EndpointDefinition.getAddress(MessageContext messageContext)
This should return the absolute EPR address referenced by the named endpoint.
|
protected Endpoint |
LoadbalanceEndpoint.getNextChild(MessageContext synCtx) |
Endpoint |
IndirectEndpoint.getRealEndpoint(MessageContext synCtx)
Get the real endpoint
|
protected void |
AbstractEndpoint.informFailure(MessageContext synCtx,
int errorCode,
String errorMsg) |
protected boolean |
AbstractEndpoint.isRetryDisabled(MessageContext synCtx) |
protected boolean |
AbstractEndpoint.isSuspendFault(MessageContext synCtx)
Is this a fault that should put the endpoint on SUSPEND? or is this a fault to ignore?
|
protected boolean |
AbstractEndpoint.isTimeout(MessageContext synCtx)
Is this [fault] message a timeout?
|
protected boolean |
AbstractEndpoint.isTraceOn(MessageContext msgCtx)
Should this mediator perform tracing? True if its explicitly asked to
trace, or its parent has been asked to trace and it does not reject it
|
protected void |
AbstractEndpoint.logOnChildEndpointFail(Endpoint endpoint,
MessageContext synMessageContext) |
void |
LoadbalanceEndpoint.onChildEndpointFail(Endpoint endpoint,
MessageContext synMessageContext) |
void |
Endpoint.onChildEndpointFail(Endpoint endpoint,
MessageContext synMessageContext)
Endpoints that contain other endpoints should implement this method.
|
void |
RecipientListEndpoint.onChildEndpointFail(Endpoint endpoint,
MessageContext synMessageContext) |
void |
SALoadbalanceEndpoint.onChildEndpointFail(Endpoint endpoint,
MessageContext synCtx)
It is logically incorrect to failover a session affinity endpoint after the session has started.
|
void |
AbstractEndpoint.onChildEndpointFail(Endpoint endpoint,
MessageContext synMessageContext) |
void |
FailoverEndpoint.onChildEndpointFail(Endpoint endpoint,
MessageContext synMessageContext) |
void |
DefaultEndpoint.onFault(MessageContext synCtx) |
void |
WSDLEndpoint.onFault(MessageContext synCtx) |
void |
AbstractEndpoint.onFault(MessageContext synCtx)
On a fault, propagate to parent if any, or call into the fault handler
|
void |
AddressEndpoint.onFault(MessageContext synCtx) |
protected void |
AbstractEndpoint.prepareForEndpointStatistics(MessageContext synCtx)
Process statistics for this message
|
void |
LoadbalanceEndpoint.send(MessageContext synCtx) |
void |
ServiceDynamicLoadbalanceEndpoint.send(MessageContext synCtx) |
void |
DefaultEndpoint.send(MessageContext synCtx) |
void |
IndirectEndpoint.send(MessageContext synCtx)
Send by calling to the real endpoint
|
void |
WSDLEndpoint.send(MessageContext synCtx) |
void |
ResolvingEndpoint.send(MessageContext synCtx)
Send by calling to the real endpoint
|
void |
TemplateEndpoint.send(MessageContext synCtx) |
void |
Endpoint.send(MessageContext synMessageContext)
Sends the message context according to an endpoint specific behavior.
|
void |
RecipientListEndpoint.send(MessageContext synCtx) |
void |
SALoadbalanceEndpoint.send(MessageContext synCtx) |
void |
AbstractEndpoint.send(MessageContext synCtx) |
void |
FailoverEndpoint.send(MessageContext synCtx) |
void |
DynamicLoadbalanceEndpoint.send(MessageContext synCtx) |
void |
AddressEndpoint.send(MessageContext synCtx) |
protected void |
DynamicLoadbalanceEndpoint.sendToApplicationMember(MessageContext synCtx,
org.apache.axis2.clustering.Member currentMember,
DynamicLoadbalanceFaultHandler faultHandler,
boolean newSession) |
protected void |
DynamicLoadbalanceEndpoint.setCookieHeader(MessageContext synCtx) |
protected void |
AbstractEndpoint.setErrorOnMessage(MessageContext synCtx,
String errorCode,
String errorMsg) |
Modifier and Type | Method and Description |
---|---|
Endpoint |
WeightedRRLCAlgorithm.getNextEndpoint(MessageContext messageContext,
AlgorithmContext algorithmContext) |
Endpoint |
WeightedRoundRobin.getNextEndpoint(MessageContext synapseMessageContext,
AlgorithmContext algorithmContext) |
Endpoint |
RoundRobin.getNextEndpoint(MessageContext synCtx,
AlgorithmContext algorithmContext)
Choose an active endpoint using the round robin algorithm.
|
Endpoint |
LoadbalanceAlgorithm.getNextEndpoint(MessageContext synapseMessageContext,
AlgorithmContext algorithmContext)
This method returns the next node according to the algorithm implementation.
|
Modifier and Type | Method and Description |
---|---|
protected String |
AbstractDispatcher.extractSessionID(MessageContext synCtx,
String key) |
protected List<String> |
HttpSessionDispatcher.extractSessionIDs(MessageContext synCtx,
String key) |
SessionInformation |
Dispatcher.getSession(MessageContext synCtx)
Dispatcher should check the session id pattern in the synapseMessageContext and return the
matching endpoint for that session id, if available.
|
SessionInformation |
HttpSessionDispatcher.getSession(MessageContext synCtx)
Check if "Cookie" HTTP header is available.
|
SessionInformation |
SimpleClientSessionDispatcher.getSession(MessageContext synCtx) |
SessionInformation |
SoapSessionDispatcher.getSession(MessageContext synCtx)
Gives the endpoint based on the service group context ID of the request message.
|
void |
Dispatcher.removeSessionID(MessageContext syCtx)
Remove the session Id - To clear out session information from current message
|
void |
HttpSessionDispatcher.removeSessionID(MessageContext syCtx) |
void |
SimpleClientSessionDispatcher.removeSessionID(MessageContext syCtx) |
void |
SoapSessionDispatcher.removeSessionID(MessageContext syCtx) |
protected void |
AbstractDispatcher.removeSessionID(MessageContext synCtx,
String key) |
void |
Dispatcher.unbind(MessageContext synCtx)
Removes the session belonging to the given message context.
|
void |
HttpSessionDispatcher.unbind(MessageContext synCtx) |
void |
SimpleClientSessionDispatcher.unbind(MessageContext synCtx) |
void |
SoapSessionDispatcher.unbind(MessageContext synCtx) |
void |
Dispatcher.updateSession(MessageContext synCtx)
Updates the session maps.
|
void |
HttpSessionDispatcher.updateSession(MessageContext synCtx)
Searches for "Set-Cookie" HTTP header in the message context.
|
void |
SimpleClientSessionDispatcher.updateSession(MessageContext synCtx) |
void |
SoapSessionDispatcher.updateSession(MessageContext synCtx)
As this is a server initiated session, this method will only be called for response messages.
|
void |
SALSessions.updateSession(MessageContext synCtx,
String sessionID)
Update or establish a session
|
Modifier and Type | Method and Description |
---|---|
void |
SynapseEventSource.dispatchEvents(MessageContext msgCtx)
Public method for event dispatching, used by the eventPublisher mediator and eventSource
|
boolean |
SynapseEventFilter.isSatisfied(MessageContext mc)
Check the incoming event satisfied with the defined filter
|
Modifier and Type | Method and Description |
---|---|
boolean |
XPathBasedEventFilter.isSatisfied(MessageContext mc) |
Modifier and Type | Method and Description |
---|---|
boolean |
ReplaceMediator.mediate(MessageContext synCtx) |
boolean |
DetachMediator.mediate(MessageContext synCtx) |
Modifier and Type | Method and Description |
---|---|
BlockingQueue<MessageContext> |
SEDAQueue.getQueue() |
Modifier and Type | Method and Description |
---|---|
void |
DefaultConsumer.consume(MessageContext messageContext) |
void |
SEDAQueueConsumer.consume(MessageContext messageContext) |
boolean |
SEDAMediator.mediate(MessageContext synCtx) |
void |
SEDAQueueProducer.produce(MessageContext messageContext) |
Modifier and Type | Method and Description |
---|---|
static boolean |
HandlerUtil.mediateInMessage(org.apache.commons.logging.Log log,
org.apache.axis2.context.MessageContext messageContext,
MessageContext synCtx) |
static boolean |
HandlerUtil.mediateOutMessage(org.apache.commons.logging.Log log,
org.apache.axis2.context.MessageContext messageContext,
MessageContext synCtx) |
Modifier and Type | Method and Description |
---|---|
static Object |
EIPUtils.lookupFunctionParam(MessageContext synCtx,
String paramName)
Fetch parameter values parsed by call template mediators
|
boolean |
DynamicRouterMediator.mediate(MessageContext msgCtx)
Route a message consecutively through a series of condition steps
|
boolean |
CalloutBlockMediator.mediate(MessageContext synCtx)
Blocks external service invocation
|
boolean |
ContentBasedRouterMediator.mediate(MessageContext messageContext)
Route messages to the appropriate sequence according to the message contents
|
Modifier and Type | Method and Description |
---|---|
MessageContext |
GetPropertyFunction.getSynCtx() |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractMediator.auditLog(String msg,
MessageContext msgContext)
Deprecated.
This method will be removed in a future version of Synapse.
Please use the
SynapseLog instance returned by
AbstractMediator.getLog(MessageContext) for all logging inside a
mediator. |
protected void |
AbstractMediator.auditWarn(String msg,
MessageContext msgContext)
Deprecated.
This method will be removed in a future version of Synapse.
Please use the
SynapseLog instance returned by
AbstractMediator.getLog(MessageContext) for all logging inside a
mediator. |
void |
MediatorProperty.evaluate(MessageContext synCtx) |
Object |
Value.evaluateObjectValue(MessageContext synCtx) |
String |
Value.evaluateValue(MessageContext synCtx)
Evaluating key based on message context
used when key is a xpath expression
|
Object |
Value.evalutePropertyExpression(MessageContext synCtx) |
String |
MediatorProperty.getEvaluatedExpression(MessageContext synCtx) |
protected SynapseLog |
AbstractMediator.getLog(MessageContext synCtx)
Get a SynapseLog instance appropriate for the given context.
|
protected void |
AbstractMediator.handleException(String msg,
Exception e,
MessageContext msgContext)
Perform an error log message to all logs @ ERROR.
|
protected void |
AbstractMediator.handleException(String msg,
MessageContext msgContext)
Perform an error log message to all logs @ ERROR.
|
protected boolean |
AbstractMediator.isTraceOn(MessageContext msgCtx)
Deprecated.
This method will be removed in a future version of Synapse.
Please use the
SynapseLog instance returned by
AbstractMediator.getLog(MessageContext) for all logging inside a
mediator. |
boolean |
AbstractListMediator.mediate(MessageContext synCtx) |
void |
MediatorFaultHandler.onFault(MessageContext synCtx)
Implements the fault handling method for the mediators (basically sequences)
|
void |
AbstractMediator.setEffectiveTraceState(MessageContext synCtx)
This method is used to save previous tracing state and set next the tracing
state for a child mediator
|
boolean |
FilterMediator.test(MessageContext synCtx)
Should return true if the sub/child mediators should execute.
|
Constructor and Description |
---|
GetPropertyFunction(MessageContext synCtx) |
MediatorLog(org.apache.commons.logging.Log defaultLog,
boolean traceOn,
MessageContext synCtx) |
MediatorWorker(Mediator seq,
MessageContext synCtx)
Constructor of the MediatorWorker which sets the sequence and the message context
|
MediatorWorker(MessageContext synCtx)
Constructor od the MediatorWorker which sets the provided message context and the
main sequence as the sequence for mediation
|
Modifier and Type | Method and Description |
---|---|
boolean |
SynapseMediator.mediate(MessageContext synCtx)
Perform the mediation specified by the rule set
|
boolean |
SequenceMediator.mediate(MessageContext synCtx)
If this mediator refers to another named Sequence, execute that.
|
Modifier and Type | Method and Description |
---|---|
void |
Target.insert(MessageContext synCtx,
Object object)
Inserts the given object into the target specified by the current Target object.
|
boolean |
BeanMediator.mediate(MessageContext synCtx)
Manipulates a JavaBean attached to the current message context according to the supplied
semantics.
|
Modifier and Type | Method and Description |
---|---|
boolean |
EJBMediator.mediate(MessageContext synCtx)
Calls an external EJB according to the supplied semantics and attaches the result into the
message/message context.
|
Modifier and Type | Class and Description |
---|---|
class |
ScriptMessageContext
ScriptMessageContext decorates the Synapse MessageContext adding methods to use the
message payload XML in a way natural to the scripting languageS
|
Modifier and Type | Method and Description |
---|---|
boolean |
ScriptMediator.mediate(MessageContext synCtx)
Perform Script mediation
|
protected void |
ScriptMediator.prepareExternalScript(MessageContext synCtx)
Prepares the mediator for the invocation of an external script
|
Constructor and Description |
---|
ScriptMessageContext(MessageContext mc,
org.apache.bsf.xml.XMLHelper xmlHelper) |
Modifier and Type | Method and Description |
---|---|
boolean |
SendMediator.mediate(MessageContext synCtx)
This will call the send method on the messages with implicit message parameters
or else if there is an endpoint, with that endpoint parameters
|
boolean |
PropertyMediator.mediate(MessageContext synCtx)
Sets a property into the current (local) Synapse Context or into the Axis Message Context
or into Transports Header and removes above properties from the corresponding locations.
|
boolean |
LogMediator.mediate(MessageContext synCtx)
Logs the current message according to the supplied semantics
|
boolean |
RespondMediator.mediate(MessageContext synCtx)
Halts further processing/mediation of the current message and return the current message back to client.
|
boolean |
CalloutMediator.mediate(MessageContext synCtx) |
boolean |
DropMediator.mediate(MessageContext synCtx)
Halts further mediation of the current message by returning false.
|
boolean |
CacheMediator.mediate(MessageContext synCtx) |
boolean |
EnqueueMediator.mediate(MessageContext synCtx) |
boolean |
ValidateMediator.mediate(MessageContext synCtx) |
boolean |
LoopbackMediator.mediate(MessageContext synCtx) |
Modifier and Type | Method and Description |
---|---|
protected PreparedStatement |
AbstractDBMediator.getPreparedStatement(Statement stmnt,
Connection con,
MessageContext msgCtx)
Return a Prepared statement for the given Statement object, which is ready to be executed
|
boolean |
AbstractDBMediator.mediate(MessageContext synCtx)
Process each SQL statement against the current message
|
protected void |
DBReportMediator.processStatement(Statement stmnt,
MessageContext msgCtx) |
protected abstract void |
AbstractDBMediator.processStatement(Statement query,
MessageContext msgCtx)
Subclasses must specify how each SQL statement is processed
|
protected void |
DBLookupMediator.processStatement(Statement stmnt,
MessageContext msgCtx) |
Modifier and Type | Method and Description |
---|---|
static void |
EIPUtils.createSynapseEIPTemplateProperty(MessageContext synCtxt,
String templateName,
String paramName,
Object value) |
static void |
EIPUtils.enrichEnvelope(org.apache.axiom.soap.SOAPEnvelope envelope,
org.apache.axiom.soap.SOAPEnvelope enricher,
MessageContext synCtxt,
SynapseXPath expression)
Merge two SOAP envelopes using the given XPath expression that specifies the
element that enriches the first envelope from the second
|
static List<org.apache.axiom.om.OMNode> |
EIPUtils.getDetachedMatchingElements(org.apache.axiom.soap.SOAPEnvelope envelope,
MessageContext synCtxt,
SynapseXPath expression)
Return the set of detached elements specified by the XPath over the given envelope
|
static List |
EIPUtils.getMatchingElements(org.apache.axiom.soap.SOAPEnvelope envelope,
MessageContext synCtxt,
SynapseXPath expression)
Return the set of elements specified by the XPath over the given envelope
|
boolean |
Target.mediate(MessageContext synCtx)
process the message through this target (may be to mediate
using the target sequence, send message to the target endpoint or both)
|
Modifier and Type | Method and Description |
---|---|
List<MessageContext> |
Aggregate.getMessages() |
Modifier and Type | Method and Description |
---|---|
boolean |
Aggregate.addMessage(MessageContext synCtx)
Add a message to the interlan message list
|
boolean |
AggregateMediator.mediate(MessageContext synCtx)
Aggregate messages flowing through this mediator according to the correlation criteria
and the aggregation algorithm specified to it
|
Modifier and Type | Method and Description |
---|---|
void |
Aggregate.setMessages(List<MessageContext> messages) |
Modifier and Type | Method and Description |
---|---|
MessageContext |
MessageQueue.get() |
MessageContext |
UnboundedMessageQueue.get() |
Modifier and Type | Method and Description |
---|---|
void |
MessageQueue.add(MessageContext synCtx) |
void |
UnboundedMessageQueue.add(MessageContext synCtx) |
boolean |
SamplingThrottleMediator.mediate(MessageContext messageContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
CloneMediator.mediate(MessageContext synCtx)
This will implement the mediate method of the Mediator interface and will provide the
functionality of cloning message into the specified targets and mediation
|
boolean |
IterateMediator.mediate(MessageContext synCtx)
Splits the message by iterating over the results of the given XPath expression
|
Modifier and Type | Method and Description |
---|---|
ArrayList<org.apache.axiom.om.OMNode> |
Source.evaluate(MessageContext synCtx,
SynapseLog synLog) |
void |
Target.insert(MessageContext synContext,
ArrayList<org.apache.axiom.om.OMNode> sourceNodeList,
SynapseLog synLog) |
boolean |
EnrichMediator.mediate(MessageContext synCtx) |
Modifier and Type | Method and Description |
---|---|
boolean |
EventPublisherMediator.mediate(MessageContext synCtx) |
Modifier and Type | Method and Description |
---|---|
boolean |
AnnotatedCommandMediator.mediate(MessageContext synCtx) |
boolean |
ClassMediator.mediate(MessageContext synCtx)
Don't use a new instance...
|
boolean |
POJOCommandMediator.mediate(MessageContext synCtx)
Implements the mediate method of the Mediator interface.
|
Modifier and Type | Method and Description |
---|---|
boolean |
OutMediator.mediate(MessageContext synCtx)
Executes the list of sub/child mediators, if the filter condition is satisfied
|
boolean |
FilterMediator.mediate(MessageContext synCtx)
Executes the list of sub/child mediators, if the filter condition is satisfied
|
boolean |
InMediator.mediate(MessageContext synCtx)
Executes the list of sub/child mediators, if the filter condition is satisfied
|
boolean |
SwitchMediator.mediate(MessageContext synCtx)
Iterate over switch cases and find match and execute selected sequence
|
boolean |
OutMediator.test(MessageContext synCtx)
Apply mediation only on response messages
|
boolean |
FilterMediator.test(MessageContext synCtx)
Tests the supplied condition after evaluation against the given XPath
or Regex (against a source XPath).
|
boolean |
InMediator.test(MessageContext synCtx)
Apply mediation only on request messages
|
Modifier and Type | Method and Description |
---|---|
boolean |
ConditionalRouterMediator.mediate(MessageContext synCtx) |
Modifier and Type | Method and Description |
---|---|
boolean |
SpringMediator.mediate(MessageContext synCtx) |
Modifier and Type | Method and Description |
---|---|
boolean |
MessageStoreMediator.mediate(MessageContext synCtx) |
Modifier and Type | Method and Description |
---|---|
boolean |
TemplateMediator.mediate(MessageContext synCtx) |
boolean |
InvokeMediator.mediate(MessageContext synCtx) |
void |
TemplateContext.setupParams(MessageContext synCtxt)
evaluate raw parameters passed from an invoke mediator and store them in this context
|
Modifier and Type | Method and Description |
---|---|
boolean |
ThrottleMediator.mediate(MessageContext synCtx) |
Modifier and Type | Method and Description |
---|---|
boolean |
TransactionMediator.mediate(MessageContext synCtx) |
Modifier and Type | Method and Description |
---|---|
boolean |
FaultMediator.mediate(MessageContext synCtx) |
boolean |
HeaderMediator.mediate(MessageContext synCtx)
Sets/Removes a SOAP header on the current message
|
boolean |
PayloadFactoryMediator.mediate(MessageContext synCtx)
Replaces the existing payload with a new payload as defined by the format and the argument list
|
boolean |
XSLTMediator.mediate(MessageContext synCtx)
Transforms this message (or its element specified as the source) using the
given XSLT transformation
|
Modifier and Type | Method and Description |
---|---|
void |
RewriteAction.execute(URIFragments fragments,
MessageContext messageContext) |
boolean |
URLRewriteMediator.mediate(MessageContext messageContext) |
void |
RewriteRule.rewrite(URIFragments fragments,
MessageContext messageContext) |
Modifier and Type | Method and Description |
---|---|
boolean |
MediatorCustomVariable.evaluateValue(MessageContext synCtx)
To assign a value to variable dynamically
|
abstract boolean |
MediatorVariable.evaluateValue(MessageContext synCtx)
Calculates the value of this variable
|
boolean |
MediatorBaseVariable.evaluateValue(MessageContext synCtx) |
boolean |
XQueryMediator.mediate(MessageContext synCtx)
Performs the query and attached the result to the target Node
|
Modifier and Type | Method and Description |
---|---|
MessageContext |
BlockingMessageSender.send(EndpointDefinition endpoint,
MessageContext messageIn)
Send the message to a given AddressEndpoint in a blocking manner
|
Modifier and Type | Method and Description |
---|---|
MessageContext |
BlockingMessageSender.send(EndpointDefinition endpoint,
MessageContext messageIn)
Send the message to a given AddressEndpoint in a blocking manner
|
Modifier and Type | Method and Description |
---|---|
MessageContext |
InMemoryMessageStore.get(int index) |
MessageContext |
MessageStore.get(int index)
Return the Message in given index position
(this may depend on the implementation)
|
MessageContext |
InMemoryMessageStore.get(String messageId) |
MessageContext |
MessageStore.get(String messageId)
Get the Message with the given ID from the Message store without removing it
|
MessageContext |
InMemoryMessageStore.peek() |
MessageContext |
MessageStore.peek()
Retrieves but not removes the first Message in this store.
|
MessageContext |
InMemoryMessageStore.poll() |
MessageContext |
MessageStore.poll()
Retrieves and removes the first Message in this store.
|
MessageContext |
InMemoryMessageStore.remove() |
MessageContext |
MessageStore.remove()
Retrieves and removes the first Message in this store.
|
MessageContext |
InMemoryMessageStore.remove(String messageID) |
MessageContext |
MessageStore.remove(String messageID)
Delete and return the MessageContext with given Message id
|
Modifier and Type | Method and Description |
---|---|
List<MessageContext> |
InMemoryMessageStore.getAll() |
List<MessageContext> |
MessageStore.getAll()
Get the All messages in the Message store without removing them from the queue
|
Modifier and Type | Method and Description |
---|---|
boolean |
InMemoryMessageStore.offer(MessageContext messageContext) |
boolean |
MessageStore.offer(MessageContext messageContext)
Inserts the Message into this store if it is possible to do so immediately
without violating capacity restrictions.
|
Modifier and Type | Method and Description |
---|---|
static String |
RESTUtils.getFullRequestPath(MessageContext synCtx) |
static String |
RESTUtils.getSubRequestPath(MessageContext synCtx) |
boolean |
Handler.handleRequest(MessageContext messageContext) |
boolean |
Handler.handleResponse(MessageContext messageContext) |
boolean |
RESTRequestHandler.process(MessageContext synCtx)
Attempt to process the given message through one of the available APIs.
|
Modifier and Type | Method and Description |
---|---|
Resource |
DefaultDispatcher.findResource(MessageContext synCtx,
Collection<Resource> resources) |
Resource |
URLMappingBasedDispatcher.findResource(MessageContext synCtx,
Collection<Resource> resources) |
Resource |
URITemplateBasedDispatcher.findResource(MessageContext synCtx,
Collection<Resource> resources) |
Resource |
RESTDispatcher.findResource(MessageContext synCtx,
Collection<Resource> resources)
Find a Resource instance suitable for processing the given message
|
Modifier and Type | Method and Description |
---|---|
static MessageContext |
MessageHelper.cloneMessageContext(MessageContext synCtx)
This method will simulate cloning the message context and creating an exact copy of the
passed message.
|
Modifier and Type | Method and Description |
---|---|
static MessageContext |
MessageHelper.cloneMessageContext(MessageContext synCtx)
This method will simulate cloning the message context and creating an exact copy of the
passed message.
|
static DataHandler |
PayloadHelper.getBinaryPayload(MessageContext mc) |
static SimpleMap |
PayloadHelper.getMapPayload(MessageContext mc) |
static int |
PayloadHelper.getPayloadType(MessageContext mc) |
static org.apache.neethi.Policy |
MessageHelper.getPolicy(MessageContext synCtx,
String propertyKey)
Get the Policy object for the given name from the Synapse configuration at runtime
|
static XMLStreamReader |
PayloadHelper.getStAXPayload(MessageContext mc) |
static String |
PayloadHelper.getTextPayload(MessageContext mc) |
static void |
PayloadHelper.setBinaryPayload(MessageContext mc,
DataHandler dh) |
static void |
PayloadHelper.setMapPayload(MessageContext mc,
SimpleMap map) |
static void |
PayloadHelper.setStAXPayload(MessageContext mc,
XMLStreamReader streamReader) |
static void |
PayloadHelper.setTextPayload(MessageContext mc,
String text) |
static void |
PayloadHelper.setXMLPayload(MessageContext mc,
org.apache.axiom.om.OMElement element) |
Modifier and Type | Method and Description |
---|---|
Object |
SynapseXPath.evaluate(Object primaryContext,
MessageContext secondaryContext)
Specialized form of xpath evaluation function.An xpath evaluate() will be performed using two contexts
(ie:-soap-envelope and on Synapse Message Context).
|
org.apache.axiom.om.OMNode |
SourceXPathSupport.selectOMNode(MessageContext synCtx,
SynapseLog synLog)
Get the first node selected by the configured XPath expression.
|
String |
SynapseXPath.stringValueOf(MessageContext synCtx)
Evaluates the XPath expression against the MessageContext of the current message and
returns a String representation of the result
|
Constructor and Description |
---|
SynapseXPathFunctionContext(org.jaxen.FunctionContext parent,
MessageContext synCtx)
Initialises the function context
|
SynapseXPathVariableContext(org.jaxen.VariableContext parent,
MessageContext synCtx)
Initializes the
SynapseVariableContext with the specified context |
SynapseXPathVariableContext(org.jaxen.VariableContext parent,
MessageContext synCtx,
org.apache.axiom.soap.SOAPEnvelope env)
Initializes the
SynapseVariableContext with the specified envelope |
Modifier and Type | Method and Description |
---|---|
static org.jaxen.Function |
XpathExtensionUtil.getFunctionContext(MessageContext ctxt,
String namespaceURI,
String prefix,
String localName)
Returns a Function Context extension registered for given QName/namespaceURI+prefix+localName
combination
|
org.jaxen.Function |
SynapseXpathFunctionContextProvider.getInitializedExtFunction(MessageContext msgCtxt)
This method should implement instatntiation code for custom xpath function for the registered
QNames given by #getResolvingQName().Note that this extension provider is responsible for
initalizing custom xpath function and returning a fresh function instance to Synapse.
|
Object |
SynapseXpathVariableResolver.resolve(MessageContext msgCtxt)
This method should implement the resolving code for custom xpath variable for the registered
QName given by #getResolvingQName().
|
static Object |
XpathExtensionUtil.resolveVariableContext(MessageContext ctxt,
String namespaceURI,
String prefix,
String localName)
Returns an object resolved by Variable Context extension registered for given
QName/namespaceURI+prefix+localName combination
|
Modifier and Type | Method and Description |
---|---|
boolean |
DiscountQuoteMediator.mediate(MessageContext mc) |
boolean |
BinaryExtractMediator.mediate(MessageContext msgCtx) |
Modifier and Type | Method and Description |
---|---|
boolean |
SpringCustomLogger.mediate(MessageContext synCtx) |
Copyright © 2005-2017 Apache Software Foundation. All Rights Reserved.