Uses of Class
org.apache.axis2.context.MessageContext

Packages that use MessageContext
org.apache.axis2   
org.apache.axis2.addressing   
org.apache.axis2.builder   
org.apache.axis2.builder.unknowncontent   
org.apache.axis2.client   
org.apache.axis2.client.async   
org.apache.axis2.clustering   
org.apache.axis2.clustering.state   
org.apache.axis2.context   
org.apache.axis2.context.externalize   
org.apache.axis2.dataretrieval   
org.apache.axis2.description   
org.apache.axis2.dispatchers   
org.apache.axis2.engine   
org.apache.axis2.handlers   
org.apache.axis2.receivers   
org.apache.axis2.transport   
org.apache.axis2.transport.http   
org.apache.axis2.transport.http.util   
org.apache.axis2.util   
 

Uses of MessageContext in org.apache.axis2
 

Methods in org.apache.axis2 that return MessageContext
 MessageContext AxisFault.getFaultMessageContext()
          Returns the MessageContext representation of the fault if the fault was created by providing that.
 

Constructors in org.apache.axis2 with parameters of type MessageContext
AxisFault(org.apache.axiom.soap.SOAPFault fault, MessageContext faultCtx)
           
AxisFault(String message, MessageContext faultMessageContext)
          Create an AxisFault by providing a textual message and a MessageContext that contains the actual fault representation.
AxisFault(String message, MessageContext faultMessageContext, Throwable cause)
           
 

Uses of MessageContext in org.apache.axis2.addressing
 

Methods in org.apache.axis2.addressing with parameters of type MessageContext
static org.apache.axiom.om.OMElement AddressingFaultsHelper.getDetailElementForAddressingFault(MessageContext messageContext, org.apache.axiom.om.OMNamespace addressingNamespaceObject)
           
static String AddressingHelper.getRequestAddressingRequirementParameterValue(MessageContext response)
           
static boolean AddressingHelper.isFaultRedirected(MessageContext messageContext)
          Returns true if the FaultTo address does not match one of the supported anonymous urls.
static boolean AddressingHelper.isReplyRedirected(MessageContext messageContext)
          Returns true if the ReplyTo address does not match one of the supported anonymous urls.
static boolean AddressingHelper.isSyncFaultAllowed(MessageContext messageContext)
          Returns true if the FaultTo address matches one of the supported anonymous urls.
static boolean AddressingHelper.isSyncReplyAllowed(MessageContext messageContext)
          Returns true if the ReplyTo address matches one of the supported anonymous urls.
static boolean AddressingHelper.shouldSendFaultToFaultTo(MessageContext messageContext)
          If the inbound FaultTo header was invalid and caused a fault, the fault should not be sent to it.
static void AddressingFaultsHelper.triggerActionMismatchFault(MessageContext messageContext, String soapAction, String wsaAction)
           
static void AddressingFaultsHelper.triggerActionNotSupportedFault(MessageContext messageContext, String problemAction)
           
static void AddressingFaultsHelper.triggerDestinationUnreachableFault(MessageContext messageContext, String address)
           
static void AddressingFaultsHelper.triggerInvalidCardinalityFault(MessageContext messageContext, String incorrectHeaderName)
           
static void AddressingFaultsHelper.triggerInvalidEPRFault(MessageContext messageContext, String incorrectHeaderName)
           
static void AddressingFaultsHelper.triggerMessageAddressingRequiredFault(MessageContext messageContext, String missingHeaderName)
           
static void AddressingFaultsHelper.triggerMissingAddressInEPRFault(MessageContext messageContext, String incorrectHeaderName)
           
static void AddressingFaultsHelper.triggerOnlyAnonymousAddressSupportedFault(MessageContext messageContext, String incorrectHeaderName)
           
static void AddressingFaultsHelper.triggerOnlyNonAnonymousAddressSupportedFault(MessageContext messageContext, String incorrectHeaderName)
           
 

Uses of MessageContext in org.apache.axis2.builder
 

Methods in org.apache.axis2.builder with parameters of type MessageContext
static org.apache.axiom.soap.SOAPEnvelope BuilderUtil.buildsoapMessage(MessageContext messageContext, MultipleEntryHashMap requestParameterMap, org.apache.axiom.soap.SOAPFactory soapFactory)
           
static org.apache.axiom.attachments.Attachments BuilderUtil.createAttachments(MessageContext msgContext, InputStream inStream, String contentTypeString, boolean fileCacheForAttachments, String attachmentRepoDir, String attachmentSizeThreshold, int contentLength)
           
protected static org.apache.axiom.attachments.Attachments BuilderUtil.createAttachmentsMap(MessageContext msgContext, InputStream inStream, String contentTypeString)
           
static org.apache.axiom.om.impl.builder.StAXBuilder BuilderUtil.getAttachmentsBuilder(MessageContext msgContext, InputStream inStream, String contentTypeString, boolean isSOAP)
           
static Builder BuilderUtil.getBuilderFromSelector(String type, MessageContext msgContext)
          Initial work for a builder selector which selects the builder for a given message format based on the the content type of the recieved message.
static boolean BuilderUtil.isAttachmentsCacheEnabled(MessageContext msgContext)
           
 org.apache.axiom.om.OMElement XFormURLEncodedBuilder.processDocument(InputStream inputStream, String contentType, MessageContext messageContext)
           
 org.apache.axiom.om.OMElement SOAPBuilder.processDocument(InputStream inputStream, String contentType, MessageContext messageContext)
           
 org.apache.axiom.om.OMElement MTOMBuilder.processDocument(InputStream inputStream, String contentType, MessageContext messageContext)
           
 org.apache.axiom.om.OMElement DataSourceBuilder.processDocument(InputStream inputStream, String contentType, MessageContext msgContext)
           
 org.apache.axiom.om.OMElement Builder.processDocument(InputStream inputStream, String contentType, MessageContext messageContext)
          Process a message.
 org.apache.axiom.om.OMElement ApplicationXMLBuilder.processDocument(InputStream inputStream, String contentType, MessageContext messageContext)
           
 org.apache.axiom.om.OMElement MultipartFormDataBuilder.processDocument(InputStream inputStream, String contentType, MessageContext messageContext)
           
 org.apache.axiom.om.OMElement MIMEBuilder.processDocument(InputStream inputStream, String contentType, MessageContext msgContext)
           
 

Uses of MessageContext in org.apache.axis2.builder.unknowncontent
 

Methods in org.apache.axis2.builder.unknowncontent with parameters of type MessageContext
 org.apache.axiom.om.OMElement UnknownContentBuilder.processDocument(InputStream inputStream, String contentType, MessageContext messageContext)
           
 

Uses of MessageContext in org.apache.axis2.client
 

Methods in org.apache.axis2.client that return MessageContext
abstract  MessageContext OperationClient.getMessageContext(String messageLabel)
          Return a message from the client - will return null if the requested message is not available.
 

Methods in org.apache.axis2.client with parameters of type MessageContext
protected  void Stub.addHttpHeader(MessageContext messageContext, String name, String value)
          add an http header with name and value to message context
abstract  void OperationClient.addMessageContext(MessageContext messageContext)
          Add a message context to the client for processing.
protected  void OperationClient.addReferenceParameters(MessageContext msgctx)
           
 void OperationClient.complete(MessageContext msgCtxt)
          To close the transport if necessary , can call this method.
protected  void OperationClient.prepareMessageContext(ConfigurationContext configurationContext, MessageContext mc)
          prepareMessageContext gets a fresh new MessageContext ready to be sent.
protected  void OperationClient.setMessageID(MessageContext mc)
          Create a message ID for the given message context if needed.
 

Uses of MessageContext in org.apache.axis2.client.async
 

Methods in org.apache.axis2.client.async that return MessageContext
 MessageContext AsyncResult.getResponseMessageContext()
          Deprecated. Get the complete message context for the response.
 

Methods in org.apache.axis2.client.async with parameters of type MessageContext
 void AxisCallback.onFault(MessageContext msgContext)
          This gets called when a fault message is received.
 void AxisCallback.onMessage(MessageContext msgContext)
          This is called when we receive a message.
 

Constructors in org.apache.axis2.client.async with parameters of type MessageContext
AsyncResult(MessageContext result)
          Deprecated. Constructor.
 

Uses of MessageContext in org.apache.axis2.clustering
 

Methods in org.apache.axis2.clustering with parameters of type MessageContext
 Handler.InvocationResponse RequestBlockingHandler.invoke(MessageContext msgContext)
           
 

Uses of MessageContext in org.apache.axis2.clustering.state
 

Methods in org.apache.axis2.clustering.state with parameters of type MessageContext
static void Replicator.replicate(MessageContext msgContext)
          Replicates all serializable properties in the ConfigurationContext, ServiceGroupContext & ServiceContext
 

Uses of MessageContext in org.apache.axis2.context
 

Fields in org.apache.axis2.context with type parameters of type MessageContext
static ThreadLocal<MessageContext> MessageContext.currentMessageContext
          A place to store the current MessageContext
 

Methods in org.apache.axis2.context that return MessageContext
 MessageContext ConfigurationContext.createMessageContext()
          Create a MessageContext, and notify any registered ContextListener.
 MessageContext MessageContext.extractCopyMessageContext()
          Return a Read-Only copy of this message context that has been extracted from the object hierachy.
static MessageContext MessageContext.getCurrentMessageContext()
           
 MessageContext OperationContext.getMessageContext(String messageLabel)
          Get the message context identified by a given label.
 

Methods in org.apache.axis2.context that return types with arguments of type MessageContext
 HashMap<String,MessageContext> OperationContext.getMessageContexts()
           
 

Methods in org.apache.axis2.context with parameters of type MessageContext
 void OperationContext.addMessageContext(MessageContext msgContext)
          When a new message is added to the MEPContext the logic should be included remove the MEPContext from the table in the EngineContext.
 void SelfManagedDataManager.deserializeSelfManagedData(ByteArrayInputStream data, MessageContext mc)
          This method is invoked when the MessageContext object is being restored.
 void ConfigurationContext.fillServiceContextAndServiceGroupContext(MessageContext messageContext)
          Searches for a ServiceGroupContext in the map with given id as the key.
 ServiceGroupContext ConfigurationContext.getServiceGroupContextFromSoapSessionTable(String serviceGroupContextId, MessageContext msgContext)
          Retrieve the ServiceGroupContext from the SOAP session table
 void OperationContext.isolateMessageContext(MessageContext mc)
          Isolate the specified message context object to prepare for serialization.
 void OperationContext.restoreMessageContext(MessageContext msg)
          Restore the specified MessageContext object in the table used to hold the message contexts associated with this operation.
 void SelfManagedDataManager.restoreTransientData(MessageContext mc)
          This method is invoked when the MessageContext object is being restored and after the deserializeSelfManagedData() method.
 ByteArrayOutputStream SelfManagedDataManager.serializeSelfManagedData(MessageContext mc)
          This method is invoked when the MessageContext object is being saved.
static void MessageContext.setCurrentMessageContext(MessageContext ctx)
           
 

Uses of MessageContext in org.apache.axis2.context.externalize
 

Methods in org.apache.axis2.context.externalize with parameters of type MessageContext
static org.apache.axiom.soap.SOAPEnvelope MessageExternalizeUtils.readExternal(ObjectInput in, MessageContext mc, String correlationIDString)
          Read the Message
static void MessageExternalizeUtils.writeExternal(ObjectOutput out, MessageContext mc, String correlationIDString, org.apache.axiom.om.OMOutputFormat outputFormat)
          Write out the Message
 

Uses of MessageContext in org.apache.axis2.dataretrieval
 

Methods in org.apache.axis2.dataretrieval with parameters of type MessageContext
 Data[] WSDLDataLocator.getData(DataRetrievalRequest request, MessageContext msgContext)
          getData API Implement data retrieval logic for WSDL dialect
 Data[] AxisDataLocatorImpl.getData(DataRetrievalRequest request, MessageContext msgContext)
          Retrieves and returns data based on the specified request.
 Data[] AxisDataLocator.getData(DataRetrievalRequest request, MessageContext msgContext)
          Retrieves and returns data based on the specified request.
 Data[] BaseAxisDataLocator.getData(DataRetrievalRequest request, MessageContext msgContext)
          The default Axis2 Data locator getData API Checks data information configured in ServiceData.xml for the supported output forms: inline, url, EndpointReference.
 Data[] SchemaDataLocator.getData(DataRetrievalRequest request, MessageContext msgContext)
           
protected  Data[] WSDLDataLocator.outputInlineForm(MessageContext msgContext, ServiceData[] dataList)
           
protected  Data[] BaseAxisDataLocator.outputInlineForm(MessageContext msgContext, ServiceData[] serviceData)
           
protected  Data[] SchemaDataLocator.outputInlineForm(MessageContext msgContext, ServiceData[] serviceData)
           
protected  Data[] BaseAxisDataLocator.outputReferenceForm(MessageContext msgContext, ServiceData[] serviceData)
           
 

Uses of MessageContext in org.apache.axis2.description
 

Methods in org.apache.axis2.description with parameters of type MessageContext
 void TwoChannelAxisOperation.addFaultMessageContext(MessageContext msgContext, OperationContext opContext)
           
 void OutOnlyAxisOperation.addFaultMessageContext(MessageContext msgContext, OperationContext opContext)
           
 void InOnlyAxisOperation.addFaultMessageContext(MessageContext msgContext, OperationContext opContext)
           
abstract  void AxisOperation.addFaultMessageContext(MessageContext msgContext, OperationContext opContext)
           
 void InOutAxisOperation.addMessageContext(MessageContext msgContext, OperationContext opContext)
           
 void OutOnlyAxisOperation.addMessageContext(MessageContext msgContext, OperationContext opContext)
           
 void InOnlyAxisOperation.addMessageContext(MessageContext msgContext, OperationContext opContext)
           
 void OutInAxisOperation.addMessageContext(MessageContext msgContext, OperationContext opContext)
           
abstract  void AxisOperation.addMessageContext(MessageContext msgContext, OperationContext opContext)
          Adds a message context into an operation context.
 void AxisService.attachEnvelopeEvent(MessageContext mc)
          Signal an Attach Envelope Event
 void MessageContextListener.attachEnvelopeEvent(MessageContext mc)
           
 void AxisService.attachServiceContextEvent(ServiceContext sc, MessageContext mc)
          Signal an Attach ServiceContext Event
 void MessageContextListener.attachServiceContextEvent(ServiceContext sc, MessageContext mc)
           
 OperationContext AxisOperation.findForExistingOperationContext(MessageContext msgContext)
          Returns as existing OperationContext related to this message if one exists.
 OperationContext AxisOperation.findOperationContext(MessageContext msgContext, ServiceContext serviceContext)
          Finds an OperationContext for an incoming message.
 Data[] AxisService.getData(DataRetrievalRequest request, MessageContext msgContext)
          Find a data locator from the available data locators (both configured and default ones) to retrieve Metadata or data specified in the request.
static TransportInDescription ClientUtils.inferInTransport(AxisConfiguration ac, Options options, MessageContext msgCtxt)
           
static TransportOutDescription ClientUtils.inferOutTransport(AxisConfiguration ac, EndpointReference epr, MessageContext msgctx)
           
 void AxisOperation.registerMessageContext(MessageContext msgContext, OperationContext operationContext)
           
 void AxisOperation.registerOperationContext(MessageContext msgContext, OperationContext operationContext)
           
 

Uses of MessageContext in org.apache.axis2.dispatchers
 

Methods in org.apache.axis2.dispatchers with parameters of type MessageContext
 AxisOperation HTTPLocationBasedDispatcher.findOperation(AxisService service, MessageContext messageContext)
           
 AxisOperation RelatesToBasedOperationDispatcher.findOperation(AxisService service, MessageContext messageContext)
           
 AxisOperation RequestURIOperationDispatcher.findOperation(AxisService service, MessageContext messageContext)
           
 AxisOperation AddressingBasedDispatcher.findOperation(AxisService service, MessageContext messageContext)
           
 AxisOperation RequestURIBasedOperationDispatcher.findOperation(AxisService service, MessageContext messageContext)
           
 AxisOperation ActionBasedOperationDispatcher.findOperation(AxisService service, MessageContext messageContext)
           
 AxisOperation SOAPActionBasedDispatcher.findOperation(AxisService service, MessageContext messageContext)
           
abstract  AxisOperation AbstractOperationDispatcher.findOperation(AxisService service, MessageContext messageContext)
          Called by Axis Engine to find the operation.
 AxisOperation SOAPMessageBodyBasedOperationDispatcher.findOperation(AxisService service, MessageContext messageContext)
           
 AxisOperation RequestURIBasedDispatcher.findOperation(AxisService service, MessageContext messageContext)
           
 AxisOperation SOAPMessageBodyBasedDispatcher.findOperation(AxisService service, MessageContext messageContext)
           
 AxisService RequestURIBasedServiceDispatcher.findService(MessageContext messageContext)
           
 AxisService HTTPLocationBasedDispatcher.findService(MessageContext messageContext)
           
 AxisService SOAPMessageBodyBasedServiceDispatcher.findService(MessageContext messageContext)
           
abstract  AxisService AbstractServiceDispatcher.findService(MessageContext messageContext)
          Called by Axis Engine to find the service.
 AxisService RequestURIOperationDispatcher.findService(MessageContext messageContext)
           
 AxisService AddressingBasedDispatcher.findService(MessageContext messageContext)
           
 AxisService RelatesToBasedServiceDispatcher.findService(MessageContext messageContext)
           
 AxisService SOAPActionBasedDispatcher.findService(MessageContext messageContext)
           
 AxisService RequestURIBasedDispatcher.findService(MessageContext messageContext)
           
 AxisService SOAPMessageBodyBasedDispatcher.findService(MessageContext messageContext)
           
 Handler.InvocationResponse AbstractServiceDispatcher.invoke(MessageContext msgctx)
           
 Handler.InvocationResponse AddressingBasedDispatcher.invoke(MessageContext msgctx)
           
 Handler.InvocationResponse AbstractOperationDispatcher.invoke(MessageContext msgctx)
           
 

Uses of MessageContext in org.apache.axis2.engine
 

Methods in org.apache.axis2.engine that return MessageContext
static MessageContext AxisEngine.createFaultMessageContext(MessageContext processingContext, Throwable e)
          Deprecated. (post 1.1 branch)
 

Methods in org.apache.axis2.engine with parameters of type MessageContext
 void DispatchPhase.checkPostConditions(MessageContext msgContext)
           
 void Phase.checkPostConditions(MessageContext msgContext)
          Confirm that all post-conditions of this Phase are met.
 void Phase.checkPreconditions(MessageContext msgContext)
          Check the preconditions for a Phase.
static MessageContext AxisEngine.createFaultMessageContext(MessageContext processingContext, Throwable e)
          Deprecated. (post 1.1 branch)
abstract  AxisOperation AbstractDispatcher.findOperation(AxisService service, MessageContext messageContext)
          Called by Axis Engine to find the operation.
abstract  AxisService AbstractDispatcher.findService(MessageContext messageContext)
          Called by Axis Engine to find the service.
 void Handler.flowComplete(MessageContext msgContext)
          This method will be called on each registered handler that had its invoke(...) method called during the processing of the message, once the message processing has completed.
 void Phase.flowComplete(MessageContext msgContext)
           
 Handler.InvocationResponse Handler.invoke(MessageContext msgContext)
          This method will be called on each registered handler when a message needs to be processed.
 Handler.InvocationResponse AbstractDispatcher.invoke(MessageContext msgctx)
           
 Handler.InvocationResponse InstanceDispatcher.invoke(MessageContext msgContext)
          Deprecated. This doesn't do anything, as the functionality is now in DispatchPhase.checkPostConditions() The class remains for backwards compatibility of axis2.xml files, but it should go away after 1.3.
 Handler.InvocationResponse Phase.invoke(MessageContext msgctx)
          Invoke all the handlers in this Phase
static Handler.InvocationResponse AxisEngine.receive(MessageContext msgContext)
          This methods represents the inflow of the Axis, this could be either at the server side or the client side.
 void MessageReceiver.receive(MessageContext messageCtx)
           
static Handler.InvocationResponse AxisEngine.resume(MessageContext msgctx)
          Resume processing of a message.
static Handler.InvocationResponse AxisEngine.resumeReceive(MessageContext msgContext)
          If the msgConetext is puased and try to invoke then first invoke the phase list and after the message receiver
static Handler.InvocationResponse AxisEngine.resumeSend(MessageContext msgContext)
          To resume the invocation at the send path , this is neened since it is require to call TransportSender at the end
static void AxisEngine.resumeSendFault(MessageContext msgContext)
          here we assume that it is resume from an operation level handler
static void AxisEngine.send(MessageContext msgContext)
          This methods represents the outflow of the Axis, this could be either at the server side or the client side.
static void AxisEngine.sendFault(MessageContext msgContext)
          Sends the SOAP Fault to another SOAP node.
 

Uses of MessageContext in org.apache.axis2.handlers
 

Methods in org.apache.axis2.handlers with parameters of type MessageContext
abstract  Handler.InvocationResponse AbstractTemplatedHandler.doInvoke(MessageContext msgCtx)
          This should implement the actual handler invocation logic.
 void AbstractHandler.flowComplete(MessageContext msgContext)
           
 Handler.InvocationResponse AbstractTemplatedHandler.invoke(MessageContext msgContext)
          Implements the separation of the conditional check and the actual logic
abstract  boolean AbstractTemplatedHandler.shouldInvoke(MessageContext msgCtx)
          This method should implement the conditional check of the handler to decide whether this particular message needs to be handled by me
 

Uses of MessageContext in org.apache.axis2.receivers
 

Fields in org.apache.axis2.receivers declared as MessageContext
 MessageContext AbstractMessageReceiver.ThreadContextDescriptor.oldMessageContext
           
 

Methods in org.apache.axis2.receivers with parameters of type MessageContext
 org.apache.axiom.soap.SOAPFactory AbstractMessageReceiver.getSOAPFactory(MessageContext msgContext)
           
protected  Object AbstractMessageReceiver.getTheImplementationObject(MessageContext msgContext)
          Retrieve the implementation object.
 void ServerCallback.handleResult(MessageContext result)
           
 void RawXMLINOnlyMessageReceiver.invokeBusinessLogic(MessageContext msgContext)
          Invokes the business logic invocation on the service implementation class
protected abstract  void AbstractMessageReceiver.invokeBusinessLogic(MessageContext messageCtx)
          Do the actual work of the MessageReceiver.
 void AbstractInOutSyncMessageReceiver.invokeBusinessLogic(MessageContext msgContext)
          Deprecated.  
 void AbstractInOutMessageReceiver.invokeBusinessLogic(MessageContext msgContext)
           
 void RawXMLINOutMessageReceiver.invokeBusinessLogic(MessageContext msgContext, MessageContext newmsgContext)
          Invokes the bussiness logic invocation on the service implementation class
abstract  void AbstractInOutSyncMessageReceiver.invokeBusinessLogic(MessageContext inMessage, MessageContext outMessage)
          Deprecated.  
abstract  void AbstractInOutMessageReceiver.invokeBusinessLogic(MessageContext inMessage, MessageContext outMessage)
           
protected  Object AbstractMessageReceiver.makeNewServiceObject(MessageContext msgContext)
          Create a new service object.
 void RawXMLINOutAsyncMessageReceiver.receive(MessageContext messageCtx)
          Deprecated.  
 void AbstractInOutAsyncMessageReceiver.receive(MessageContext messageCtx)
          Deprecated.  
 void AbstractMessageReceiver.receive(MessageContext messageCtx)
           
protected  void AbstractMessageReceiver.replicateState(MessageContext messageContext)
           
protected  AbstractMessageReceiver.ThreadContextDescriptor AbstractMessageReceiver.setThreadContext(MessageContext msgContext)
          Several pieces of information need to be available to the service implementation class.
 

Constructors in org.apache.axis2.receivers with parameters of type MessageContext
AbstractMessageReceiver.AsyncMessageReceiverWorker(MessageContext messageCtx)
           
 

Uses of MessageContext in org.apache.axis2.transport
 

Methods in org.apache.axis2.transport with parameters of type MessageContext
 void RequestResponseTransport.acknowledgeMessage(MessageContext msgContext)
          Notify the transport that a message should be acknowledged at this time.
 void TransportSender.cleanup(MessageContext msgContext)
          Release resources associated with a given message context.
static org.apache.axiom.om.OMElement TransportUtils.createDocumentElement(String contentType, MessageContext msgContext, InputStream inStream)
           
static org.apache.axiom.soap.SOAPEnvelope TransportUtils.createSOAPMessage(MessageContext msgContext)
           
static org.apache.axiom.soap.SOAPEnvelope TransportUtils.createSOAPMessage(MessageContext msgContext, boolean detach)
          This method will create a SOAPEnvelope based on the InputStream stored on the MessageContext.
static org.apache.axiom.soap.SOAPEnvelope TransportUtils.createSOAPMessage(MessageContext msgContext, InputStream inStream, String contentType)
          Objective of this method is to capture the SOAPEnvelope creation logic and make it a common for all the transports and to in/out flows.
static void TransportUtils.deleteAttachments(MessageContext msgContext)
          Clean up cached attachment file
static void TransportUtils.detachInputStream(MessageContext msgContext)
          This method can be called by components wishing to detach the DetachableInputStream object that is present on the MessageContext.
static boolean TransportUtils.doWriteMTOM(MessageContext msgContext)
           Checks whether MTOM needs to be enabled for the message represented by the msgContext.
static boolean TransportUtils.doWriteSwA(MessageContext msgContext)
           Checks whether SOAP With Attachments (SwA) needs to be enabled for the message represented by the msgContext.
 String MessageFormatter.formatSOAPAction(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, String soapAction)
           
 byte[] MessageFormatter.getBytes(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format)
           
static String TransportUtils.getCharSetEncoding(MessageContext msgContext)
          Utility method to query CharSetEncoding.
 String MessageFormatter.getContentType(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, String soapAction)
          Different message formats can set their own content types Eg: JSONFormatter can set the content type as application/json
static String TransportUtils.getContentType(String contentType, MessageContext msgContext)
           
static MessageFormatter TransportUtils.getMessageFormatter(MessageContext msgContext)
          Initial work for a builder selector which selects the builder for a given message format based on the the content type of the recieved message.
 SessionContext TransportListener.getSessionContext(MessageContext messageContext)
          To get the sessionContext transport dependent manner.
 URL MessageFormatter.getTargetAddress(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, URL targetURL)
          Some message formats may want to alter the target url.
static boolean TransportUtils.isDoingREST(MessageContext msgContext)
           
static boolean TransportUtils.isResponseWritten(MessageContext messageContext)
          This is a helper method to get the response written flag from the RequestResponseTransport instance.
static void TransportUtils.processContentTypeForAction(String contentType, MessageContext msgContext)
           
static void TransportUtils.setResponseWritten(MessageContext messageContext, boolean responseWritten)
          This is a helper method to set the response written flag on the RequestResponseTransport instance.
static void TransportUtils.writeMessage(MessageContext msgContext, OutputStream out)
           
 void MessageFormatter.writeTo(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, OutputStream outputStream, boolean preserve)
          To support deffered writing transports as in http chunking..
 

Uses of MessageContext in org.apache.axis2.transport.http
 

Methods in org.apache.axis2.transport.http with parameters of type MessageContext
 String SOAPMessageFormatter.formatSOAPAction(MessageContext msgCtxt, org.apache.axiom.om.OMOutputFormat format, String soapActionString)
           
 String MultipartFormDataFormatter.formatSOAPAction(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, String soapAction)
           
 String ApplicationXMLFormatter.formatSOAPAction(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, String soapAction)
           
 String XFormURLEncodedFormatter.formatSOAPAction(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, String soapAction)
           
 byte[] SOAPMessageFormatter.getBytes(MessageContext msgCtxt, org.apache.axiom.om.OMOutputFormat format)
           
 byte[] MultipartFormDataFormatter.getBytes(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format)
           
 byte[] ApplicationXMLFormatter.getBytes(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format)
           
 byte[] XFormURLEncodedFormatter.getBytes(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format)
           
 byte[] ApplicationXMLFormatter.getBytes(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, boolean preserve)
          Get the bytes for this message
 String SOAPMessageFormatter.getContentType(MessageContext msgCtxt, org.apache.axiom.om.OMOutputFormat format, String soapActionString)
           
 String MultipartFormDataFormatter.getContentType(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, String soapAction)
          Different message formats can set their own content types Eg: JSONFormatter can set the content type as application/json
 String ApplicationXMLFormatter.getContentType(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, String soapAction)
           
 String XFormURLEncodedFormatter.getContentType(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, String soapAction)
           
 URL SOAPMessageFormatter.getTargetAddress(MessageContext msgCtxt, org.apache.axiom.om.OMOutputFormat format, URL targetURL)
           
 URL MultipartFormDataFormatter.getTargetAddress(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, URL targetURL)
          Some message formats may want to alter the target url.
 URL ApplicationXMLFormatter.getTargetAddress(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, URL targetURL)
           
 URL XFormURLEncodedFormatter.getTargetAddress(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, URL targetURL)
           
 void SOAPMessageFormatter.writeTo(MessageContext msgCtxt, org.apache.axiom.om.OMOutputFormat format, OutputStream out, boolean preserve)
           
 void MultipartFormDataFormatter.writeTo(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, OutputStream outputStream, boolean preserve)
          To support deffered writing transports as in http chunking..
 void ApplicationXMLFormatter.writeTo(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, OutputStream outputStream, boolean preserve)
           
 void XFormURLEncodedFormatter.writeTo(MessageContext messageContext, org.apache.axiom.om.OMOutputFormat format, OutputStream outputStream, boolean preserve)
           
 

Uses of MessageContext in org.apache.axis2.transport.http.util
 

Methods in org.apache.axis2.transport.http.util with parameters of type MessageContext
static URL URLTemplatingUtil.appendQueryParameters(MessageContext messageContext, URL url)
          Appends Query parameters to the URL
static URL URLTemplatingUtil.getTemplatedURL(URL targetURL, MessageContext messageContext, boolean detach)
          Returns the templated URL given the original URL
 

Uses of MessageContext in org.apache.axis2.util
 

Methods in org.apache.axis2.util that return MessageContext
static MessageContext MessageContextBuilder.createFaultMessageContext(MessageContext processingContext, Throwable e)
          This method is called to handle any error that occurs at inflow or outflow.
static MessageContext Utils.createOutMessageContext(MessageContext inMessageContext)
          Deprecated. (post1.1branch)
static MessageContext MessageContextBuilder.createOutMessageContext(MessageContext inMessageContext)
          Creates a MessageContext for use with a non-fault response based on an request MessageContext
 

Methods in org.apache.axis2.util with parameters of type MessageContext
static String WSDL20Util.applyURITemplating(MessageContext messageContext, String rawURLString, boolean detach)
          This method is used to resolve httplocation property.
 void ThreadContextMigrator.cleanupContext(MessageContext messageContext)
          This method will be invoked when the processing of the message is guaranteed to be on the thread of execution that will be used in user space, after all processing has completed (i.e.
 void ThreadContextMigrator.cleanupThread(MessageContext messageContext)
          This method will be invoked when the processing of the message is guaranteed to still be on the thread of execution that was used in user space, after all processing has completed (i.e.
static MessageContext MessageContextBuilder.createFaultMessageContext(MessageContext processingContext, Throwable e)
          This method is called to handle any error that occurs at inflow or outflow.
static MessageContext Utils.createOutMessageContext(MessageContext inMessageContext)
          Deprecated. (post1.1branch)
static MessageContext MessageContextBuilder.createOutMessageContext(MessageContext inMessageContext)
          Creates a MessageContext for use with a non-fault response based on an request MessageContext
static AxisFault Utils.getInboundFaultFromMessageContext(MessageContext messageContext)
          Get an AxisFault object to represent the SOAPFault in the SOAPEnvelope attached to the provided MessageContext.
static int Utils.getMtomThreshold(MessageContext msgCtxt)
           
static boolean Utils.isClientThreadNonBlockingPropertySet(MessageContext messageContext)
          this is to make is backward compatible.
static boolean Utils.isExplicitlyTrue(MessageContext messageContext, String propertyName)
          Deprecated. please use MessageContext.isTrue(propertyName) instead
 void ThreadContextMigrator.migrateContextToThread(MessageContext messageContext)
          This method will be invoked when the processing of the message is guaranteed to be on the thread of execution that will be used in user space.
 void ThreadContextMigrator.migrateThreadToContext(MessageContext messageContext)
          This method will be invoked when the processing of the message is guaranteed to still be on the thread of execution that was used in user space.
static void ThreadContextMigratorUtil.performContextCleanup(String threadContextMigratorListID, MessageContext msgContext)
          Activate any registered ThreadContextMigrators to remove information from the context if necessary.
static void ThreadContextMigratorUtil.performMigrationToContext(String threadContextMigratorListID, MessageContext msgContext)
          Activate any registered ThreadContextMigrators to move info from the thread of execution into the context.
static void ThreadContextMigratorUtil.performMigrationToThread(String threadContextMigratorListID, MessageContext msgContext)
          Activate any registered ThreadContextMigrators to move context info to the thread of execution.
static void ThreadContextMigratorUtil.performThreadCleanup(String threadContextMigratorListID, MessageContext msgContext)
          Activate any registered ThreadContextMigrators to remove information from the thread of execution if necessary.
 void CallbackReceiver.receive(MessageContext msgContext)
           
 void TargetResolver.resolveTarget(MessageContext messageContext)
          resolveTarget examines the MessageContext and updates the MessageContext in order to resolve the target.
 



Copyright © 2004-2011 The Apache Software Foundation. All Rights Reserved.