A B C D E F G H I J K L M N O P Q R S T U V W X Z
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- AbstractInboundEndpointManager - Class in org.wso2.carbon.inbound.endpoint.common
- AbstractInboundEndpointManager() - Constructor for class org.wso2.carbon.inbound.endpoint.common.AbstractInboundEndpointManager
- AbstractKafkaMessageListener - Class in org.wso2.carbon.inbound.endpoint.protocol.kafka
- AbstractKafkaMessageListener() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
- AbstractKafkaMessageListener.CONSUMER_TYPE - Enum in org.wso2.carbon.inbound.endpoint.protocol.kafka
-
the consumer types are high level and simple,high level is used for kafka high level configuration and simple is used for kafka low level configuration
- AbstractSubprotocolHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
- AbstractSubprotocolHandler() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.AbstractSubprotocolHandler
- ACKNOWLEDGE - org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.AcknowledgementMode
- AcknowledgementMode - Enum in org.wso2.carbon.inbound.endpoint.protocol.rabbitmq
-
The acknowledgement mode return by the message consumer
- addChannelContext(String, String, InboundWebsocketChannelContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketSubscriberPathManager
- addCloseListener(ChannelHandlerContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelContext
- addDispatchPattern(String, int, Pattern) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Adds a dispatch pattern to pattern map.
- addWorkerPool(String, int, WorkerPoolConfiguration) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Method for add worker pool configs
- AMQ_PREFIX - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- APIResource - Class in org.wso2.carbon.inbound.endpoint.internal.http.api
-
APIResource
is the abstract implementation of a Resource in an Internal API. - APIResource(String) - Constructor for class org.wso2.carbon.inbound.endpoint.internal.http.api.APIResource
-
Constructor for creating an API Resource.
- Axis2HL7Constants - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.util
-
Copyright (c) 2015, WSO2 Inc.
- Axis2HL7Constants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- Axis2HL7Constants.MessageEncoding - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.util
- Axis2HL7Constants.MessageType - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.util
B
- BACKEND_MESSAGE_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- BINARY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- BINARY_BUILDER_IMPLEMENTATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- bind(int, HL7Processor) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7IOReactor
- bossThreadPoolSize(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- broadcastLevel(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- broadcastOnSubscriberPath(WebSocketFrame, String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketSubscriberPathManager
- broadcastShutDownToSubscriber(String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- BUFFER_SIZE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- BUFFER_SIZE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- build() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration.InboundHttpConfigurationBuilder
- build() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- build() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration.SSLConfigurationBuilder
- buildConfiguration(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
- buildConfiguration(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- buildIdentifier(String, String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- buildMessage(AMQP.BasicProperties, byte[], MessageContext) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQUtils
-
Build SOAP envelop from AMQP properties and byte body
- buildMessage(MessageContext) - Method in class org.wso2.carbon.inbound.endpoint.internal.http.api.APIResource
-
Builds the message by consuming the input stream.
- buildNameIdentifier(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- buildSSLConfiguration(InboundProcessorParams) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management.HttpWebsocketEndpointManager
-
Builds the
SSLConfiguration
to wrap all the security related parameters defined in the inbound endpoint. - buildSSLConfiguration(InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- buildSubprotocolString(ArrayList<String>, ArrayList<String>) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.SubprotocolBuilderUtil
- BytesMessageDataSource - Class in org.wso2.carbon.inbound.endpoint.protocol.jms
-
Data source implementation wrapping a JMS
BytesMessage
. - BytesMessageDataSource(BytesMessage) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageDataSource
- BytesMessageDataSource(BytesMessage, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageDataSource
- BytesMessageInputStream - Class in org.wso2.carbon.inbound.endpoint.protocol.jms
-
Input stream that reads data from a JMS
BytesMessage
. - BytesMessageInputStream(BytesMessage) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageInputStream
- BytesMessageOutputStream - Class in org.wso2.carbon.inbound.endpoint.protocol.jms
- BytesMessageOutputStream(BytesMessage) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageOutputStream
C
- CACHE_AUTO - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
automatic choice of an appropriate caching level (depending on the transaction strategy)
- CACHE_CONNECTION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Cache only the JMS connection between tasks (when receiving), or JMS CF's (when sending)
- CACHE_CONSUMER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Cache the JMS connection, Session and Consumer between tasks when receiving
- CACHE_NONE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Do not cache any JMS resources between tasks (when sending) or JMS CF's (when sending)
- CACHE_PRODUCER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Cache the JMS connection, Session and Producer within a JMSConnectionFactory when sending
- CACHE_SESSION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Cache only the JMS connection and Session between tasks (receiving), or JMS CF's (sending)
- CachedJMSConnectionFactory - Class in org.wso2.carbon.inbound.endpoint.protocol.jms.factory
- CachedJMSConnectionFactory(Properties) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- CachedJMSConnectionFactory(Properties, Connection) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- call() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.CallableTask
- CallableTask - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.core
-
Copyright (c) 2015, WSO2 Inc.
- CallableTask(MessageContext, SequenceMediator) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.CallableTask
- channelActive(ChannelHandlerContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- channelInactive(ChannelHandlerContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.pipelinehandlers.SamplePipelineHandler
- checkReactor() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7IOReactor
-
In certain cases, reactor is not started prior to a bind() (e.g.
- CIPHER_SUITES - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- cleanSession - Variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttListener
- CLIENT_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- CLIENT_REVOCATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- clientId - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- close() - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConsumer
-
Return connection back to the pool when undeploying the listener proxy
- CLOSE_WEBSOCKET_CLIENT_ON_CLIENT_HANDLER_ERROR - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- closeConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- closeConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.CoreListener
-
Close the connection to NATS server and set connection to null.
- closeConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsMessageConsumer
- closeConnection() - Method in interface org.wso2.carbon.inbound.endpoint.protocol.nats.NatsMessageListener
- closeConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.StreamingListener
-
Close the connection to NATS Streaming server and set connection to null.
- closeConnection(Connection) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- closeConnection(Connection) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- closeConnection(Connection, boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- closeConsumer(MessageConsumer) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- closeConsumer(MessageConsumer, boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- closeEndpoint(int) - Method in interface org.wso2.carbon.inbound.endpoint.common.InboundEndpointManager
-
Stop Inbound Endpoint
- closeEndpoint(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.management.HL7EndpointManager
- closeEndpoint(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Stop Inbound Endpoint
- closeEndpoint(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management.HttpWebsocketEndpointManager
- closeEndpoint(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.management.NatsEndpointManager
-
Stop Inbound Endpoint
- closeEndpoint(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- closeSession(Session) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- closeSession(Session, boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- COMMON_ENDPOINT_POSTFIX - Static variable in class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerRequestProcessor
- COMMON_ENDPOINT_POSTFIX - Static variable in class org.wso2.carbon.inbound.endpoint.common.InboundRequestProcessorImpl
- compilePattern(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
- ConfigurationLoader - Class in org.wso2.carbon.inbound.endpoint.internal.http.api
-
ConfigurationLoader
contains utilities to load configuration file content required for Internal APIs implementation. - ConfigurationLoader() - Constructor for class org.wso2.carbon.inbound.endpoint.internal.http.api.ConfigurationLoader
- CONNECT_TIMEOUT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- connected(IOSession) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPSourceHandler
- connected(IOSession) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MultiIOHandler
- CONNECTION_FACTORY_JNDI_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- CONNECTION_FACTORY_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- CONNECTION_STRING - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Default Connection Factory
- CONNECTION_TERMINATE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- CONNECTION_TIMEOUT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- connectionFactory - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- connectionFactoryString - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- connectionLost(Throwable) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
-
Handle losing connection with the server.
- Constants - Class in org.wso2.carbon.inbound.endpoint.internal.http.api
-
Constants
contains constants related to internal http api implementation. - Constants() - Constructor for class org.wso2.carbon.inbound.endpoint.internal.http.api.Constants
- consumeMultipleTopics(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
-
Consume from multiple topics
- consumeMultipleTopics(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAMessageListener
- CONSUMER_QOS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- CONSUMER_TAG - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- CONSUMER_TIMEOUT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- CONSUMER_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- consumerConnector - Variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
- consumerIte - Variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
- CONTENT_ENCODING - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- CONTENT_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- CONTENT_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- CONTENT_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- CONTENT_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- CONTENT_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- CONTENT_TYPE_PROPERTY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- contentTypeToSyanapeSubprotocol(String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.SubprotocolBuilderUtil
- convertJMSMapToXML(MapMessage) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSInjectHandler
- convertXMLtoJMSMap(OMElement, MapMessage) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSUtils
- coordination - Variable in class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerRequestProcessor
- coordination - Variable in class org.wso2.carbon.inbound.endpoint.common.InboundRequestProcessorImpl
- coordination - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
- coordination - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- CoreListener - Class in org.wso2.carbon.inbound.endpoint.protocol.nats
-
Core listener class which uses core NATS connection to receive messages.
- CoreListener(String, NatsInjectHandler, Properties) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.nats.CoreListener
- CORRELATION_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- CR - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- create() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.SSLHandlerFactory
- createConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.CoreListener
-
Create the connection to the Core NATS server.
- createConnection() - Method in interface org.wso2.carbon.inbound.endpoint.protocol.nats.NatsMessageListener
- createConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.StreamingListener
-
Create the connection to the NATS Streaming server.
- createConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConnectionFactory
-
Create a RabbitMQ connection
- createConnection(ConnectionFactory, Address[]) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQUtils
-
Create a connection from given connection factory and address array
- createConnection(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- createConnection(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createContext() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createContext(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createContext(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createContext(String, String, int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createDefaultNack(String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
- createDestination(Session, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createErrorMessageContext(String, Exception, InboundProcessorParams) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
- createInboundProcessor(InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl
-
return underlying Request Processor Implementation according to protocol
- createKafkaConsumerConnector() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
-
Create the connection with the zookeeper
- createKafkaConsumerConnector() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAMessageListener
-
Create the connection with the zookeeper to consume the messages
- createKafkaConsumerConnector() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.SimpleKafkaMessageListener
- createMessageConsumer(Session, Destination) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- createMessageConsumer(Session, Destination) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createMLLPContext(IOSession, HL7Processor) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContextFactory
- createNack(Message, String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
- createProducer(Session, Destination, Boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
-
This is a JMS spec independent method to create a MessageProducer.
- createProducer(Session, Destination, Boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
-
This is a JMS spec independent method to create a MessageProducer.
- createQueueConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createQueueConnection(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createSession(Connection) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- createSession(Connection) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createSynapseMessageContext(Message, InboundProcessorParams) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
- createTopicConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- createTopicConnection(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- ctx - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- CUSTOM_HTTP_SC - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- CUSTOM_SEQUENCE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
D
- dataStore - Variable in class org.wso2.carbon.inbound.endpoint.common.AbstractInboundEndpointManager
- declareExchange(Channel, String, Map<String, String>) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQUtils
-
Helper method to declare exchange when direct channel is given
- declareQueue(Channel, String, Map<String, String>) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQUtils
-
Helper method to declare queue when direct channel is given
- decode(ByteBuffer, MLLPContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- DEFAULT_CONFAC_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- DEFAULT_CONSUMER_QOS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- DEFAULT_CONTENT_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- DEFAULT_HL7_TIMEOUT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- DEFAULT_HYPHEN_SUPPORT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- DEFAULT_JMS_CLIENT_POLLING_SUSPENSION_PERIOD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- DEFAULT_NATS_STREAMING_CLUSTER_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- DEFAULT_NATS_STREAMING_URL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- DEFAULT_RETRY_COUNT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- DEFAULT_RETRY_INTERVAL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- defaultContentType(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- DELIVERY_COUNT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- deliveryComplete(IMqttDeliveryToken) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
- DESTINATION_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- DESTINATION_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- DESTINATION_TYPE_GENERIC - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- DESTINATION_TYPE_QUEUE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- DESTINATION_TYPE_TOPIC - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- destinationName - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- destinationType - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- destoryInbound() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpListener
- destoryInbound() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketListener
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerEventBasedProcessor
-
Stop the inbound polling processor This will be called when inbound is undeployed/redeployed or when server stop
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerRequestProcessor
-
Stop the inbound polling processor This will be called when inbound is undeployed/redeployed or when server stop
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.common.InboundRequestProcessorImpl
-
Stop the inbound polling processor This will be called when inbound is undeployed/redeployed or when server stop
- destroy() - Static method in class org.wso2.carbon.inbound.endpoint.internal.http.api.ConfigurationLoader
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
-
This methods needs to be implemented when terminating the inbound
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericOneTimeTask
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericProcessor
-
Stop the inbound polling processor This will be called when inbound is undeployed/redeployed or when server stop
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericTask
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7Listener
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpListener
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.InboundHttpWebsocketListener
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSPollingConsumer
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSProcessor
-
Stop the inbound polling processor This will be called when inbound is undeployed/redeployed or when server stop
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSTask
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
-
Destroy consuming the messages
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAProcessor
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKATask
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttListener
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttTask
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.InboundNatsListener
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQListener
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQTask
- destroy() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketListener
- destroy(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSProcessor
-
Remove inbound endpoints.
- destroy(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAProcessor
-
Remove inbound endpoints.
- disconnected(IOSession) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPSourceHandler
- disconnected(IOSession) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MultiIOHandler
- disconnectSessions(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MultiIOHandler
- dispatch(MessageContext) - Method in class org.wso2.carbon.inbound.endpoint.internal.http.api.InternalAPIDispatcher
-
Dispatches the message into relevant internal API.
- dispatchPattern(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration.InboundHttpConfigurationBuilder
- dispatchToCustomSequence(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
E
- EchoSubprotocolHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket.subprotocols
- EchoSubprotocolHandler() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.subprotocols.EchoSubprotocolHandler
- ENABLE_PORT_OFFSET_FOR_INBOUND_ENDPOINT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- encode(ByteBuffer, MLLPContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- EndpointListenerLoader - Class in org.wso2.carbon.inbound.endpoint
-
This class is responsible for starting Listeners( like HTTP, HTTPS, HL7) on server startup for Listening Inbound Endpoints.
- EndpointListenerLoader() - Constructor for class org.wso2.carbon.inbound.endpoint.EndpointListenerLoader
- ER7 - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants.MessageEncoding
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- EXCHANGE_AUTO_DELETE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- EXCHANGE_DURABLE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- EXCHANGE_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- EXCHANGE_OPTIONAL_ARG_PREFIX - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- EXCHANGE_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- exclusiveBroadcastOnSubscriberPath(WebSocketFrame, String, String, InboundWebsocketChannelContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketSubscriberPathManager
- execute() - Method in class org.wso2.carbon.inbound.endpoint.common.InboundTask
- execute() - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerInboundTask
- execute() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSPollingConsumer
-
This will be called by the task scheduler.
- execute() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAPollingConsumer
- execute() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionConsumer
- execute() - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConsumer
-
Execute by the
RabbitMQTask
- extractSynapseSubprotocol(String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.SubprotocolBuilderUtil
F
- FAULT_SEQUENCE_INVOKED_ON_WEBSOCKET_CLIENT_HANDLER_ERROR - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- file - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- FILTER_FROM_WHITE_LIST - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
G
- generateHL7MessageElement(String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
- generateHL7RawMessaegElement(String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
- GenericConstants - Class in org.wso2.carbon.inbound.endpoint.protocol.generic
- GenericConstants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericConstants
- GenericEventBasedConsumer - Class in org.wso2.carbon.inbound.endpoint.protocol.generic
- GenericEventBasedConsumer(Properties, String, SynapseEnvironment, String, String, boolean, boolean) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
- GenericEventBasedListener - Class in org.wso2.carbon.inbound.endpoint.protocol.generic
- GenericEventBasedListener(String, String, Properties, String, String, SynapseEnvironment, boolean, boolean) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedListener
- GenericEventBasedListener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedListener
- GenericInboundListener - Class in org.wso2.carbon.inbound.endpoint.protocol.generic
- GenericInboundListener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericInboundListener
- GenericOneTimeTask - Class in org.wso2.carbon.inbound.endpoint.protocol.generic
- GenericOneTimeTask(GenericEventBasedConsumer) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericOneTimeTask
- GenericPollingConsumer - Class in org.wso2.carbon.inbound.endpoint.protocol.generic
- GenericPollingConsumer(Properties, String, SynapseEnvironment, long, String, String, boolean, boolean) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- GenericProcessor - Class in org.wso2.carbon.inbound.endpoint.protocol.generic
- GenericProcessor(String, String, Properties, long, String, String, SynapseEnvironment, boolean, boolean) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericProcessor
- GenericProcessor(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericProcessor
- GenericTask - Class in org.wso2.carbon.inbound.endpoint.protocol.generic
- GenericTask(GenericPollingConsumer, long) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericTask
- getBoolean(String, InboundProcessorParams) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
- getBooleanProperty(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7Configuration
-
Get a Boolean property that tunes HL7 transport.
- getBooleanProperty(String, Boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7Configuration
-
Get a boolean property that tunes HL7 transport.
- getBossGroupThreadPool() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketEventExecutor
- getBossThreadPoolSize() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.configuration.NettyThreadPoolConfiguration
- getBossThreadPoolSize() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getBroadcastLevel() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getBufferFactory() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- getCallback() - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerInboundTask
- getCertPass() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- getChannelHandlerContext() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelContext
- getChannelHandlerContext() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- getChannelIdentifier() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelContext
- getChannelIdLongText() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelContext
- getCharsetDecoder() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- getCipherSuites() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- getClientBroadcastLevel() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- getCodec() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- getConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- getConnection(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- getConnectionFactory() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- getConnectionFactory() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- getConnectionFactoryString() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- getConnectOptions() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionConsumer
- getContent() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- getContent() - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConnectionFactory
- getContentType() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageDataSource
- getContext() - Method in interface org.wso2.carbon.inbound.endpoint.internal.http.api.InternalAPI
-
Gets the API context.
- getContext() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- getCoresize() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration
- getDefaultContentType() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getDefaultContentType() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- getDestination(Session) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- getDestinationType() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- getDestinationType() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- getDispatcherHelper() - Method in class org.wso2.carbon.inbound.endpoint.internal.http.api.APIResource
-
Gets the
DispatcherHelper
related to the the Resource. - getDispatchPattern() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration
- getDispatchToCustomSequence() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getEndpointName(int, String) - Method in class org.wso2.carbon.inbound.endpoint.common.AbstractInboundEndpointManager
- getEndpointName(int, String) - Method in interface org.wso2.carbon.inbound.endpoint.common.InboundEndpointManager
-
Get endpoint name from underlying store for particular port and tenant domain.
- getEventBasedConsumer() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericOneTimeTask
- getExecutorService() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7ExecutorServiceFactory
- getHandlers() - Method in interface org.wso2.carbon.inbound.endpoint.internal.http.api.InternalAPI
-
Gets the handlers associated with the API
- getHl7Message() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- getHttpInternalApis() - Static method in class org.wso2.carbon.inbound.endpoint.internal.http.api.ConfigurationLoader
- getHttpsInternalApis() - Static method in class org.wso2.carbon.inbound.endpoint.internal.http.api.ConfigurationLoader
- getHttpWebSocketInboundEndpointConfiguration(int, String, InboundProcessorParams, boolean) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management.HttpWebsocketEndpointManager
-
Builds the
HttpWebSocketInboundEndpointConfiguration
, which wraps all the necessary information to be used in theHttpWebSocketInboundEndpointHandler
to start the transport listener. - getInboundEndpointIdentifier(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- getInboundName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConsumer
- getInboundParameterMap() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.HL7Processor
- getInboundProperites() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSPollingConsumer
- getInboundProperties() - Method in class org.wso2.carbon.inbound.endpoint.common.InboundTask
- getInboundProperties() - Method in interface org.wso2.carbon.inbound.endpoint.common.PinnedPollingTask
- getInboundProperties() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- getInboundProperties() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericTask
- getInboundProperties() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSTask
- getInboundProperties() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAPollingConsumer
- getInboundProperties() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKATask
- getInflowIdleTime() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getInputStream() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageDataSource
- getInstance() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.management.HL7EndpointManager
- getInstance() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7Configuration
- getInstance() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
- getInstance() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management.HttpWebsocketEndpointManager
- getInstance() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- getInstance() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.nats.management.NatsEndpointManager
- getInstance() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- getInstance() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEventExecutorManager
- getInstance() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketSubscriberPathManager
- getInstance(InboundProcessorParams) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericInboundListener
-
This is to get the GenericInboundListener instance for given params
- getInt(String, InboundProcessorParams) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
- getInternalHttpApiDispatcher() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
- getInternalHttpsApiDispatcher() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
- getInternalInboundHttpPort() - Static method in class org.wso2.carbon.inbound.endpoint.internal.http.api.ConfigurationLoader
- getInternalInboundHttpPort() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
- getInternalInboundHttpsPort() - Static method in class org.wso2.carbon.inbound.endpoint.internal.http.api.ConfigurationLoader
- getInternalInboundHttpsPort() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
- getIntProperty(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7Configuration
-
Get an int property that tunes HL7 transport.
- getIntProperty(String, Integer) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7Configuration
-
Get an int property that tunes HL7 transport.
- getKeepAlive() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration
- getKeyStore() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- getKeyStorePass() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- getLastOffset(SimpleConsumer, String, int, long, String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.SimpleKafkaMessageListener
- getMaxSize() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration
- getMessageConsumer() - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.management.NatsEndpointManager
- getMessageConsumer(Session, Destination) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- getMessageId() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- getMethods() - Method in class org.wso2.carbon.inbound.endpoint.internal.http.api.APIResource
-
Gets the HTTP methods supported by this Resource.
- getMqttAsyncClient() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionConsumer
- getMqttAsyncClient(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- getMqttCallback(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- getMqttClient(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- getMqttClientDataStore(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- getMqttConnectionConsumer() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
- getMqttConnectionFactory() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionConsumer
- getMqttConnectionOptions() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
- getMqttProperties() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionConsumer
- getName() - Method in interface org.wso2.carbon.inbound.endpoint.internal.http.api.InternalAPI
-
Gets the API name.
- getName() - Method in interface org.wso2.carbon.inbound.endpoint.internal.http.api.InternalAPIHandler
-
Gets the Handler name.
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedListener
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericProcessor
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageDataSource
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSProcessor
- getName() - Method in enum org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener.CONSUMER_TYPE
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAProcessor
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
-
get the inbound endpoint name
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionConsumer
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttListener
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConnectionFactory
-
get connection factory name
- getName() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getNatsConnection() - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.CoreListener
-
Create and return the Core NATS connection.
- getOutFlowDispatchSequence() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getOutFlowErrorSequence() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getOutflowIdleTime() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getOutputStream() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageDataSource
- getParameters() - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConnectionFactory
-
Get all rabbit mq parameters
- getPassThroughControlFrames() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- getPattern(String, int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Method to get pattern for tenant and port.
- getPipelineHandler() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getPort() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration
- getPort() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getPort() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- getPreProcessParser() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- getQueueLength() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration
- getReconnectionInterval() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- getRequestBuffer() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- getRequestTime() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- getResources() - Method in interface org.wso2.carbon.inbound.endpoint.internal.http.api.InternalAPI
-
Gets the API Resources.
- getResponseBuffer() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- getServerHost() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- getServerPort() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- getSession(Connection) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
- getSession(Connection) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- getSessionAckMode() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- getSize() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageDataSource
- getSocketFactory(String, String, String, String, String, String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- getSourceHandler() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketResponseSender
- getSourceHandler() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- getSslConfiguration() - Static method in class org.wso2.carbon.inbound.endpoint.internal.http.api.ConfigurationLoader
- getSslProtocols() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- getSSLSocketFactory() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- getState() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- getStringProperty(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7Configuration
-
Get a String property that tunes HL7 transport.
- getSubprotocolHandler() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- getSubprotocolIdentifier() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.AbstractSubprotocolHandler
- getSubscriber() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- getSubscriberPath() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- getSubscriberPathChannelContextList(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketSubscriberPathManager
- getSynapseMessageContext(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- getTenantDomain() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- getThreadGroup() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration
- getThreadGroupID() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.config.WorkerPoolConfiguration
- getThreadID() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.config.WorkerPoolConfiguration
- getThreadID() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration
- getTopic() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- getTransportHeaders(AMQP.BasicProperties) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQUtils
-
Get transport headers from the rabbitmq message
- getTransportHeaders(Message, MessageContext) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSUtils
-
Extract transport level headers from JMS message into a Map
- getTrustStore() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- getTrustStorePass() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- getWorkerGroupThreadPool() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketEventExecutor
- getWorkerPoolConfiguration(String, int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Method for get WorkerPool Config
- getWorkerPoolCoreSize() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.config.WorkerPoolConfiguration
- getWorkerPoolQueuLength() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.config.WorkerPoolConfiguration
- getWorkerPoolSizeMax() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.config.WorkerPoolConfiguration
- getWorkerPoolThreadKeepAliveSec() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.config.WorkerPoolConfiguration
- getWorkerThreadPoolSize() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.configuration.NettyThreadPoolConfiguration
- getWorkerThreadPoolSize() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- GROUP_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
H
- handle(ChannelHandlerContext, WebSocketFrame, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.AbstractSubprotocolHandler
- handle(ChannelHandlerContext, WebSocketFrame, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.subprotocols.EchoSubprotocolHandler
- handleCancel(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConsumer
-
Called when the consumer is cancelled for reasons other than by a call to
Channel.basicCancel(java.lang.String)
. - handleCancelOk(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConsumer
-
Called when the consumer is cancelled by a call to
Channel.basicCancel(java.lang.String)
. - handleClientWebsocketChannelTermination(WebSocketFrame) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- handleConsumeOk(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConsumer
-
Called when the consumer is registered by a call to any of the
Channel.basicConsume(java.lang.String, com.rabbitmq.client.Consumer)
methods. - handleDelivery(String, Envelope, AMQP.BasicProperties, byte[]) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConsumer
-
Called when a basic.deliver is received for this consumer.
- handleException(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpServerWorker
- handleException(String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSUtils
- handleException(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- handleException(String, Exception) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericInboundListener
- handleException(String, Exception) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpListener
- handleException(String, Exception) - Method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.InboundHttpWebsocketListener
- handleException(String, Exception) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketListener
- handlerAdded(ChannelHandlerContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- handleReconnection() - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerAbstractCallback
- handleRecoverOk(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConsumer
-
Called when a basic.recover-ok is received in reply to a basic.recover.
- handleRecovery(Recoverable) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQRecoveryListener
- handleRecoveryStarted(Recoverable) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQRecoveryListener
- handlers - Variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MultiIOHandler
- handleSendBack(WebSocketFrame) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketResponseSender
- handleSendBack(WebSocketFrame, InboundWebsocketChannelContext, int, String, WebsocketSubscriberPathManager) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketResponseSender
- handleShutdownSignal(String, ShutdownSignalException) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConsumer
-
Called when either the channel or the underlying connection has been shut down.
- handleWebsocketBinaryFrame(WebSocketFrame, MessageContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- handleWebsocketPassthroughTextFrame(WebSocketFrame, MessageContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- hasClientDataStore(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- hasInboundEndpoint(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- hasMqttCallback(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- hasMqttClient(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- hasMultipleTopicsToConsume() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
-
Used to check whether there are multiple topics to consume from
- hasMultipleTopicsToConsume() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAMessageListener
- hasNext() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
-
Check ConsumerIterator whether It has next value
- hasNext() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAMessageListener
- hasNext() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.SimpleKafkaMessageListener
- hasNext(ConsumerIterator<byte[], byte[]>) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAMessageListener
- HEARTBEAT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- HIGHLEVEL - org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener.CONSUMER_TYPE
- hl7 - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- HL7_APPLICATION_ACK - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_BUILD_RAW_MESSAGE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_CHARSET_DECODER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- HL7_CONFORMANCE_PROFILE_PATH - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_DEFAULT_ACK_CODE_AR - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_DEFAULT_ENCODING_CHARS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_DEFAULT_FIELD_SEPARATOR - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_DEFAULT_MESSAGE_CONTROL_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_DEFAULT_PROCESSING_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_DEFAULT_RECEIVING_APPLICATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_DEFAULT_RECEIVING_FACILITY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_ELEMENT_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_HEADER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- HL7_ID_GENERATOR - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- HL7_INBOUND_MSG_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- HL7_INBOUND_TENANT_DOMAIN - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- HL7_MESSAGE_CHARSET - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_MESSAGE_ELEMENT_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_MESSAGE_OBJECT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_NACK_MESSAGE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_NAMESPACE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_PASS_THROUGH_INVALID_MESSAGES - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_PRE_PROC_PARSER_CLASS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- HL7_REQ_PROC - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- HL7_RESULT_MODE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_RESULT_MODE_NACK - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_TRAILER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- HL7_VALIDATE_MESSAGE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7_VALIDATION_PASSED - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants
- HL7Codec - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.codec
- HL7Codec() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- HL7Codec(CharsetDecoder) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- HL7Configuration - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.util
-
Copyright (c) 2015, WSO2 Inc.
- HL7EndpointManager - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.management
-
Copyright (c) 2015, WSO2 Inc.
- HL7ExecutorServiceFactory - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.util
-
Copyright (c) 2015, WSO2 Inc.
- HL7ExecutorServiceFactory() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7ExecutorServiceFactory
- HL7MessagePreprocessor - Interface in org.wso2.carbon.inbound.endpoint.protocol.hl7
-
This interface represents an implementation of a preprocessor which is used to modify the incoming HL7 message before parsing.
- HL7MessageUtils - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.util
- HL7MessageUtils() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
- HL7Processor - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.core
-
Copyright (c) 2015, WSO2 Inc.
- HL7Processor(Map<String, Object>) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.HL7Processor
- http - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- HTTP - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- HTTPEndpointManager - Class in org.wso2.carbon.inbound.endpoint.protocol.http.management
-
Manager which handles Http Listeners activities for Inbound Endpoints, coordinating with Pass-through APIs and registry etc.
- https - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- HTTPS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- HTTPS_PROTOCOL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- httpswss - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- HttpWebsocketEndpointManager - Class in org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management
- HttpWebsocketEndpointManager() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management.HttpWebsocketEndpointManager
- httpws - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- HYPHEN_MODE_DELETE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- HYPHEN_MODE_NONE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- HYPHEN_MODE_REPLACE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- HYPHEN_REPLACEMENT_STR - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
I
- INBOUND_BOSS_THREAD_POOL_SIZE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- INBOUND_BUILD_ERROR - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericConstants
- INBOUND_CONCURRENT_CONSUMERS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.PollingConstants
- INBOUND_COORDINATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.PollingConstants
- INBOUND_DEFAULT_CONTENT_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- INBOUND_ENDPOINT_INTERVAL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.PollingConstants
- INBOUND_ENDPOINT_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericConstants
- INBOUND_ENDPOINT_PARAMETER_API_DISPATCHING_ENABLED - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- INBOUND_ENDPOINT_PARAMETER_DISPATCH_FILTER_PATTERN - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- INBOUND_ENDPOINT_PARAMETER_HOSTNAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.InboundHttpWebSocketConstants
-
String representing hostname of the InboundEndpoint.
- INBOUND_ENDPOINT_PARAMETER_HTTP_PORT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
-
String representing port of the InboundEndpoint
- INBOUND_ENDPOINT_PARAMETER_HTTP_PROTOCOL_VERSION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.InboundHttpWebSocketConstants
-
String representing http protocol version of the InboundEndpoint.
- INBOUND_ENDPOINT_PARAMETER_HTTP_WS_PORT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.InboundHttpWebSocketConstants
-
String representing port of the InboundEndpoint.
- INBOUND_ENDPOINT_PARAMETER_WEBSOCKET_PORT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- INBOUND_ENDPOINT_SEQUENTIAL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.PollingConstants
- INBOUND_HL7_BUFFER_FACTORY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- INBOUND_PARAMS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- INBOUND_PINNED_SERVER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.PollingConstants
- INBOUND_PIPELINE_HANDLER_CLASS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- INBOUND_SSL_CERT_PASS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- INBOUND_SSL_KEY_STORE_FILE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- INBOUND_SSL_KEY_STORE_PASS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- INBOUND_SSL_TRUST_STORE_FILE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- INBOUND_SSL_TRUST_STORE_PASS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- INBOUND_SUBPROTOCOL_HANDLER_CLASS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- INBOUND_THREAD_GROUP_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- INBOUND_THREAD_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- INBOUND_WORKER_POOL_QUEUE_LENGTH - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
-
Defines the length of the queue that is used to hold Runnable tasks to be executed by the worker pool.
- INBOUND_WORKER_POOL_SIZE_CORE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
-
Defines the core size (number of threads) of the worker thread pool.
- INBOUND_WORKER_POOL_SIZE_MAX - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
-
Defines the maximum size (number of threads) of the worker thread pool.
- INBOUND_WORKER_THREAD_KEEP_ALIVE_SEC - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
-
Defines the keep-alive time for extra threads in the worker pool.
- INBOUND_WORKER_THREAD_POOL_SIZE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- InboundCorrelationEnabledHttpServerWorker - Class in org.wso2.carbon.inbound.endpoint.protocol.http
-
Extends
InboundHttpServerWorker
with correlation logs enabled. - InboundEndpointManager - Interface in org.wso2.carbon.inbound.endpoint.common
- InboundHL7IOReactor - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.core
- InboundHL7IOReactor() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7IOReactor
- InboundHL7Listener - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.core
- InboundHL7Listener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7Listener
- InboundHttpConfiguration - Class in org.wso2.carbon.inbound.endpoint.protocol.http
- InboundHttpConfiguration.InboundHttpConfigurationBuilder - Class in org.wso2.carbon.inbound.endpoint.protocol.http
- InboundHttpConfigurationBuilder(int, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration.InboundHttpConfigurationBuilder
- InboundHttpConstants - Class in org.wso2.carbon.inbound.endpoint.protocol.http
- InboundHttpConstants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- InboundHttpListener - Class in org.wso2.carbon.inbound.endpoint.protocol.http
-
Listener class for HttpInboundEndpoint which is trigger by inbound core and responsible for start ListeningEndpoint related to given port
- InboundHttpListener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpListener
- InboundHttpResponseSender - Class in org.wso2.carbon.inbound.endpoint.protocol.http
-
Get mediated message context from Source Response Worker and created InboundHttpSourceResponse extract the pipe and set to the reader
- InboundHttpResponseSender() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpResponseSender
- InboundHttpServerWorker - Class in org.wso2.carbon.inbound.endpoint.protocol.http
-
Create SynapseMessageContext from HTTP Request and inject it to the sequence in a synchronous manner This is the worker for HTTP inbound related requests.
- InboundHttpServerWorker(int, String, SourceRequest, SourceConfiguration, OutputStream) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpServerWorker
- InboundHttpsListener - Class in org.wso2.carbon.inbound.endpoint.protocol.https
- InboundHttpsListener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.https.InboundHttpsListener
- InboundHttpSourceHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.http
-
Handler Class for process HTTP Requests
- InboundHttpSourceHandler(int, SourceConfiguration) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpSourceHandler
- InboundHttpsSecureWebsocketListener - Class in org.wso2.carbon.inbound.endpoint.protocol.httpssecurewebsocket
- InboundHttpsSecureWebsocketListener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.httpssecurewebsocket.InboundHttpsSecureWebsocketListener
- InboundHttpWebSocketConstants - Class in org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket
- InboundHttpWebSocketConstants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.InboundHttpWebSocketConstants
- InboundHttpWebsocketListener - Class in org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket
- InboundHttpWebsocketListener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.InboundHttpWebsocketListener
- InboundNatsListener - Class in org.wso2.carbon.inbound.endpoint.protocol.nats
-
Listener class for NATS Inbound Endpoint which is triggered by inbound core
- InboundNatsListener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.nats.InboundNatsListener
- InboundOneTimeTriggerEventBasedProcessor - Class in org.wso2.carbon.inbound.endpoint.common
- InboundOneTimeTriggerEventBasedProcessor() - Constructor for class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerEventBasedProcessor
- InboundOneTimeTriggerRequestProcessor - Class in org.wso2.carbon.inbound.endpoint.common
-
This class provides the common implementation for one time trigger protocol processors Implemented the support if message injection happens in a separate thread.
- InboundOneTimeTriggerRequestProcessor() - Constructor for class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerRequestProcessor
- InboundRequestProcessorFactoryImpl - Class in org.wso2.carbon.inbound.endpoint.inboundfactory
-
Class responsible for providing the implementation of the request processor according to the protocol.
- InboundRequestProcessorFactoryImpl() - Constructor for class org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl
- InboundRequestProcessorFactoryImpl.Protocols - Enum in org.wso2.carbon.inbound.endpoint.inboundfactory
- InboundRequestProcessorImpl - Class in org.wso2.carbon.inbound.endpoint.common
-
This class provides the common implementation for polling protocol processors
- InboundRequestProcessorImpl() - Constructor for class org.wso2.carbon.inbound.endpoint.common.InboundRequestProcessorImpl
- InboundRunner - Class in org.wso2.carbon.inbound.endpoint.common
-
InboundRunner class is used to run the non coordinated processors in background according to the scheduled interval
- InboundRunner(InboundTask, long, String, boolean) - Constructor for class org.wso2.carbon.inbound.endpoint.common.InboundRunner
- InboundSecureWebsocketListener - Class in org.wso2.carbon.inbound.endpoint.protocol.securewebsocket
- InboundSecureWebsocketListener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.securewebsocket.InboundSecureWebsocketListener
- InboundTask - Class in org.wso2.carbon.inbound.endpoint.common
-
This class provides Generic Task implementation for inbound polling
- InboundTask() - Constructor for class org.wso2.carbon.inbound.endpoint.common.InboundTask
- InboundWebsocketChannelContext - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
- InboundWebsocketChannelContext(ChannelHandlerContext) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelContext
- InboundWebsocketChannelInitializer - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
- InboundWebsocketChannelInitializer() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- InboundWebsocketConfiguration - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
- InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
- InboundWebsocketConfigurationBuilder(int, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- InboundWebsocketConstants - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
- InboundWebsocketConstants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- InboundWebsocketEventExecutor - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
- InboundWebsocketEventExecutor(NettyThreadPoolConfiguration) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketEventExecutor
- InboundWebsocketListener - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
- InboundWebsocketListener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketListener
- InboundWebsocketResponseSender - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
- InboundWebsocketResponseSender(InboundWebsocketSourceHandler) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketResponseSender
- InboundWebsocketSourceHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
- InboundWebsocketSourceHandler() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- InboundWebsocketSSLConfiguration - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl
- InboundWebsocketSSLConfiguration(File, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- InboundWebsocketSSLConfiguration.SSLConfigurationBuilder - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl
- inferJMSMessageType(Message) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSUtils
-
Method to infer the JMS message type.
- inflowIdleTime(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedListener
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericProcessor
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7Listener
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpListener
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.https.InboundHttpsListener
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.httpssecurewebsocket.InboundHttpsSecureWebsocketListener
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.InboundHttpWebsocketListener
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSProcessor
-
This will be called at the time of synapse artifact deployment.
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAProcessor
-
This will be called at the time of synapse artifact deployment.
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttListener
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.InboundNatsListener
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQListener
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.securewebsocket.InboundSecureWebsocketListener
- init() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketListener
- init(SynapseEnvironment) - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericOneTimeTask
- init(SynapseEnvironment) - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericTask
- init(SynapseEnvironment) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSTask
- init(SynapseEnvironment) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKATask
- init(SynapseEnvironment) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttTask
- init(SynapseEnvironment) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQTask
- initAsyncClient() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttListener
- initChannel(SocketChannel) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- initializeConsumer() - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsMessageConsumer
-
Create the NATS connection and poll messages.
- initializeConsumer(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.CoreListener
-
Consume the message received and inject into the sequence.
- initializeConsumer(String) - Method in interface org.wso2.carbon.inbound.endpoint.protocol.nats.NatsMessageListener
- initializeConsumer(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.StreamingListener
-
Consume the message received and inject into the sequence.
- initializeMessageListener() - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsMessageConsumer
-
Initialize the message listener to use (Core NATS or NATS Streaming).
- injectHandler - Variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
- InjectHandler - Interface in org.wso2.carbon.inbound.endpoint.protocol.kafka
- injectingSeq - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
- injectingSeq - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- injectingSequence - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericInboundListener
- injectMessage(InputStream, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
- injectMessage(InputStream, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- injectMessage(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
- injectMessage(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- injectMessageToESB(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
-
Poll the messages from the zookeeper and injected to the sequence
- injectMessageToESB(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAMessageListener
- injectMessageToESB(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.SimpleKafkaMessageListener
- injectMessageToESB(String, ConsumerIterator<byte[], byte[]>) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAMessageListener
- inputReady(IOSession) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPSourceHandler
- inputReady(IOSession) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MultiIOHandler
- INTERNAL_APIS_FILE - Static variable in class org.wso2.carbon.inbound.endpoint.internal.http.api.Constants
- INTERNAL_HTTP_INBOUND_ENDPOINT_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- INTERNAL_HTTPS_INBOUND_ENDPOINT_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- InternalAPI - Interface in org.wso2.carbon.inbound.endpoint.internal.http.api
-
InternalAPI
is the interface that need to be implemented in order to register an internal API into EI. - InternalAPIDispatcher - Class in org.wso2.carbon.inbound.endpoint.internal.http.api
-
InternalAPIDispatcher
takes care of dispatching messages received over the internal inbound endpoint into relevantInternalAPI
. - InternalAPIDispatcher(List<InternalAPI>) - Constructor for class org.wso2.carbon.inbound.endpoint.internal.http.api.InternalAPIDispatcher
- InternalAPIHandler - Interface in org.wso2.carbon.inbound.endpoint.internal.http.api
-
InternalAPIHandler
is the interface that need to be implemented in order to set handlers to an internal API. - interval - Variable in class org.wso2.carbon.inbound.endpoint.common.InboundRequestProcessorImpl
- interval - Variable in class org.wso2.carbon.inbound.endpoint.common.InboundTask
- invoke(Object, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSInjectHandler
-
Invoke the mediation logic for the passed message
- invoke(Object, String) - Method in interface org.wso2.carbon.inbound.endpoint.protocol.kafka.InjectHandler
- invoke(Object, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAInjectHandler
-
Determine the message builder to use, set the message payload to the message context and inject the message to the sequence
- invoke(Object, String, String, Connection) - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsInjectHandler
-
Determine the message builder to use, set the message payload to the message context and inject the message to the sequence
- invoke(MessageContext) - Method in class org.wso2.carbon.inbound.endpoint.internal.http.api.APIResource
-
Invokes the API Resource.
- invoke(MessageContext) - Method in interface org.wso2.carbon.inbound.endpoint.internal.http.api.InternalAPIHandler
-
Invoke the handler logic
- invoke(MqttMessage, String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttInjectHandler
-
inject mqtt message into esb sequence
- IO_THREAD_COUNT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- IS_TCP_TRANSPORT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- isAnyInternalHttpApiEnabled() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Checks whether at least one internal http api is enabled.
- isAnyInternalHttpsApiEnabled() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Checks whether at least one internal https api is enabled.
- isApplicationAck() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- isAutoAck() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- isAutoAck() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.HL7Processor
- isAutoDeleteExchange(Map<String, String>) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQUtils
- isAutoDeleteQueue(Map<String, String>) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQUtils
- isCallbackSuspended() - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerAbstractCallback
- isDurable - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- isDurableExchange(Map<String, String>) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQUtils
- isDurableQueue(Map<String, String>) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQUtils
- isEndpointRunning(int) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7IOReactor
- isEventBasedInboundEndpoint(InboundProcessorParams) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
-
States whether generic endpoint is a eventBased Return true; if eventBased
- isExclusiveQueue(Map<String, String>) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQUtils
- isExpired() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- isInboundRunnerMode() - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerAbstractCallback
- isInboundTenantLoadingFlagSet(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- isInternalApiEnabled() - Static method in class org.wso2.carbon.inbound.endpoint.internal.http.api.ConfigurationLoader
-
Reads and check from the synapse properties file whether the Internal api is enabled.
- isListeningInboundEndpoint(InboundProcessorParams) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericInboundListener
-
States whether generic endpoint is a listening Return true; if listening
- isMarkForClose() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- isNackMode() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- isPinnedServer(Properties) - Method in class org.wso2.carbon.inbound.endpoint.common.InboundRequestProcessorImpl
- isPinnedServerEnabled(Properties) - Static method in class org.wso2.carbon.inbound.endpoint.common.InboundRequestProcessorImpl
- isPortOccupied(int) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management.HttpWebsocketEndpointManager
-
Checks if the given port is available to use.
- isPortUsedByAnotherApplication(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpListener
- isPreProcess() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- isReadComplete() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- isRegisteredExecutor(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEventExecutorManager
- isSharedSubscription - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- isSslConfiguredSuccessfully() - Static method in class org.wso2.carbon.inbound.endpoint.internal.http.api.ConfigurationLoader
- isStarted() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7IOReactor
- isTransactedSession() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- isUsePortOffset() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- isValidateMessage() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- isWriteComplete() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- isWriteTrailer() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
J
- JAVA_INITIAL_NAMING_FACTORY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- JAVA_NAMING_PROVIDER_URL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- jms - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- JMS_BYTE_MESSAGE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
The message type indicating a BytesMessage.
- JMS_CLIENT_CONNECTION_RESET_AFTER_POLLING_SUSPENSION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- JMS_CLIENT_POLLING_RETRIES_BEFORE_SUSPENSION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- JMS_CLIENT_POLLING_SUSPENSION_PERIOD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- JMS_COORELATION_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A MessageContext property or client Option indicating the JMS correlation id
- JMS_DELIVERY_MODE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A MessageContext property or client Option indicating the JMS delivery mode as an Integer or String Value 1 - javax.jms.DeliveryMode.NON_PERSISTENT Value 2 - javax.jms.DeliveryMode.PERSISTENT
- JMS_DESTINATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A MessageContext property or client Option indicating the JMS destination to use on a Send
- JMS_EXPIRATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A MessageContext property or client Option indicating the JMS message expiration - a Long value specified as a String
- JMS_MAP_ELEMENT_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Root element name of JMS Map message payload representation
- JMS_MAP_MESSAGE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
The message type indicating a MapMessage.
- JMS_MAP_NS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Namespace for JMS map payload representation
- JMS_MAP_QNAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- JMS_MESSAGE_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A MessageContext property or client Option indicating the JMS message id
- JMS_MESSAGE_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A MessageContext property or client Option indicating the JMS message type
- JMS_PRIORITY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A MessageContext property or client Option indicating the JMS priority
- JMS_REDELIVERED - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A MessageContext property or client Option indicating the JMS message redelivered (boolean specified as String)
- JMS_REPLY_TO - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A MessageContext property or client Option indicating the JMS replyTo Destination
- JMS_RETRY_DURATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- JMS_SPEC_VERSION_1_0 - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- JMS_SPEC_VERSION_1_1 - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- JMS_SPEC_VERSION_2_0 - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- JMS_TEXT_MESSAGE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
The message type indicating a TextMessage.
- JMS_TIMESTAMP - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A MessageContext property or client Option indicating the JMS timestamp (Long specified as String)
- JMS_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A MessageContext property indicating the JMS type String returned by {@link javax.jms.Message.getJMSType()}
- JMSConnectionFactory - Class in org.wso2.carbon.inbound.endpoint.protocol.jms.factory
-
use of factory server down and up jms spec transport.jms.MessageSelector isDurable
- JMSConnectionFactory(Properties) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- JMSConstants - Class in org.wso2.carbon.inbound.endpoint.protocol.jms
-
Common constants used by inbound JMS protocol
- JMSConstants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- JMSConstants.JMSDestinationType - Enum in org.wso2.carbon.inbound.endpoint.protocol.jms
- JMSExceptionWrapper - Exception in org.wso2.carbon.inbound.endpoint.protocol.jms
- JMSExceptionWrapper(JMSException) - Constructor for exception org.wso2.carbon.inbound.endpoint.protocol.jms.JMSExceptionWrapper
- JMSInjectHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.jms
-
JMSInjectHandler use to mediate the received JMS message
- JMSInjectHandler(String, String, boolean, SynapseEnvironment, Properties) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSInjectHandler
- JMSPollingConsumer - Class in org.wso2.carbon.inbound.endpoint.protocol.jms
- JMSPollingConsumer(Properties, long, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSPollingConsumer
- JMSProcessor - Class in org.wso2.carbon.inbound.endpoint.protocol.jms
- JMSProcessor(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSProcessor
- JMSReplySender - Class in org.wso2.carbon.inbound.endpoint.protocol.jms
- JMSReplySender(Destination, CachedJMSConnectionFactory, String, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSReplySender
- jmsSpec - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- JMSTask - Class in org.wso2.carbon.inbound.endpoint.protocol.jms
-
JMSTask class is used to schedule the inbound execution when the coordination is required
- JMSTask(JMSPollingConsumer, long) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSTask
- JMSUtils - Class in org.wso2.carbon.inbound.endpoint.protocol.jms
-
Maintain the common methods used by inbound JMS protocol
- JMSUtils() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSUtils
- JMSX_GROUP_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
The JMSXGroupID property
- JMSX_GROUP_SEQ - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
The JMSXGroupSeq property
- JMSX_PREFIX - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
The prefix that denotes JMSX properties
K
- kafka - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- KAFKAConstants - Class in org.wso2.carbon.inbound.endpoint.protocol.kafka
-
The constant parameters for kafka protocol
- KAFKAConstants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- KAFKAInjectHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.kafka
-
KafkaInjectHandler uses to mediate the received Kafka message
- KAFKAInjectHandler(String, String, boolean, SynapseEnvironment, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAInjectHandler
- KAFKAMessageListener - Class in org.wso2.carbon.inbound.endpoint.protocol.kafka
- KAFKAMessageListener(int, List<String>, Properties, InjectHandler) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAMessageListener
- KAFKAPollingConsumer - Class in org.wso2.carbon.inbound.endpoint.protocol.kafka
- KAFKAPollingConsumer(Properties, long, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAPollingConsumer
-
Initialize the kafka properties and the polling interval
- KAFKAProcessor - Class in org.wso2.carbon.inbound.endpoint.protocol.kafka
- KAFKAProcessor(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAProcessor
- kafkaProperties - Variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
- KAFKATask - Class in org.wso2.carbon.inbound.endpoint.protocol.kafka
- KAFKATask(KAFKAPollingConsumer, long) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKATask
- KEY_STORE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
L
- listen() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
-
This methods needs to be implemented when implementing the custom inbound
- loadEndpointListeners() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Start Http listeners for all the Inbound Endpoints.
- loadEndpointListeners() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- loadInternalApis(String) - Static method in class org.wso2.carbon.inbound.endpoint.internal.http.api.ConfigurationLoader
- loadListeners() - Static method in class org.wso2.carbon.inbound.endpoint.EndpointListenerLoader
-
Start listeners for all the Listening Inbound Endpoints.
- log - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
- lookupDestination(Context, String, String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSUtils
-
Return the JMS destination with the given destination name looked up from the context
M
- MAX_JMS_CONNECTIONS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Maximum number of shared JMS Connections when sending messages out
- MAX_JMS_SESSIONS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- MESSAGE_ERROR_EXCHANGE_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- MESSAGE_ERROR_QUEUE_ROUTING_KEY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- MESSAGE_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- MESSAGE_MAX_DEAD_LETTERED_COUNT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- MESSAGE_REQUEUE_DELAY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- MESSAGE_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- messageArrived(String, MqttMessage) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
- messageContextToText(MessageContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketResponseSender
- MessageEncoding() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants.MessageEncoding
- messageListener - Variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAPollingConsumer
- messageSelector - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- MessageType() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants.MessageType
- MLLP_CONTEXT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- MLLPConstants - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.core
- MLLPConstants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- MLLPConstants.TCPConstants - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.core
- MLLPContext - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.context
- MLLPContext(IOSession, CharsetDecoder, boolean, boolean, Parser, BufferFactory) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- MLLPContextFactory - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.context
-
Copyright (c) 2015, WSO2 Inc.
- MLLPContextFactory() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContextFactory
- MLLProtocolException - Exception in org.wso2.carbon.inbound.endpoint.protocol.hl7.core
-
Copyright (c) 2015, WSO2 Inc.
- MLLProtocolException() - Constructor for exception org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLProtocolException
- MLLProtocolException(String) - Constructor for exception org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLProtocolException
- MLLProtocolException(String, Throwable) - Constructor for exception org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLProtocolException
- MLLProtocolException(Throwable) - Constructor for exception org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLProtocolException
- MLLPSourceHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.core
- MLLPSourceHandler() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPSourceHandler
- MLLPSourceHandler(HL7Processor) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPSourceHandler
- mqtt - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- MQTT_CLIENT_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_PASSWORD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_QOS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_RECONNECTION_INTERVAL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SERVER_HOST_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SERVER_PORT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SESSION_CLEAN - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SSL_ENABLE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SSL_KEYSTORE_LOCATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SSL_KEYSTORE_PASSWORD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SSL_KEYSTORE_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SSL_SOCKET_FACTORY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SSL_TRUSTSTORE_LOCATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SSL_TRUSTSTORE_PASSWORD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SSL_TRUSTSTORE_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_SSL_VERSION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_TEMP_STORE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_TOPIC_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MQTT_USERNAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MqttAsyncCallback - Class in org.wso2.carbon.inbound.endpoint.protocol.mqtt
-
MQTT Asynchronous call back handler
- MqttAsyncCallback(MqttAsyncClient, MqttInjectHandler, MqttConnectionFactory, MqttConnectOptions, Properties) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
- MqttClientManager - Class in org.wso2.carbon.inbound.endpoint.protocol.mqtt
-
Reference Holder for MQTT clients in existence per ESB Server instance
- MqttConnectionConsumer - Class in org.wso2.carbon.inbound.endpoint.protocol.mqtt
-
Connection consumer for MQTT listener which delegates connection attempts and subscription from the MQTT inbound listener
- MqttConnectionConsumer(MqttConnectOptions, MqttAsyncClient, MqttConnectionFactory, Properties, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionConsumer
- MqttConnectionFactory - Class in org.wso2.carbon.inbound.endpoint.protocol.mqtt
-
MQTT factory, return instances of asynchronous clients
- MqttConnectionFactory(Properties) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- MqttConnectionListener - Class in org.wso2.carbon.inbound.endpoint.protocol.mqtt
-
MQTT connection Listener bounded per MQTT client, this the listener registered per client when mqtt connection is being made.
- MqttConnectionListener(MqttConnectionConsumer) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionListener
- MqttConstants - Class in org.wso2.carbon.inbound.endpoint.protocol.mqtt
-
MQTT Constants
- MqttConstants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- MqttInjectHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.mqtt
-
Inject mqtt message into the sequence
- MqttInjectHandler(String, String, boolean, SynapseEnvironment, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttInjectHandler
-
constructor initialize parameters and synapseEnvironment
- MqttListener - Class in org.wso2.carbon.inbound.endpoint.protocol.mqtt
-
This is the listener which directly interacts with the external MQTT server.
- MqttListener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttListener
-
constructor for the MQTT inbound endpoint listener *
- MqttTask - Class in org.wso2.carbon.inbound.endpoint.protocol.mqtt
-
MQTT task for support coordination.
- MqttTask(MqttConnectionConsumer) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttTask
- MultiIOHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.hl7.core
- MultiIOHandler(ConcurrentHashMap<Integer, HL7Processor>) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MultiIOHandler
N
- name - Variable in class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerRequestProcessor
- name - Variable in class org.wso2.carbon.inbound.endpoint.common.InboundRequestProcessorImpl
- name - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
- name - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericInboundListener
- name - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- name - Variable in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.InboundHttpWebsocketListener
- NAMING_FACTORY_INITIAL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Naming factory initial
- nats - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- NATS_STREAMING - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_ACK_WAIT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_CLIENT_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_CLUSTER_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_CONNECT_WAIT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_DISCOVER_PREFIX - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_DISPATCHER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_DURABLE_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_MANUAL_ACK - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_MAX_IN_FLIGHT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_MAX_PINGS_OUT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_PING_INTERVAL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_QUEUE_GROUP - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_SUBSCRIPTION_TIMEOUT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_TRACE_CONNECTION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NATS_STREAMING_URL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- NatsConstants - Class in org.wso2.carbon.inbound.endpoint.protocol.nats
-
Constant parameters and default values for NATS and NATS Streaming protocol.
- NatsEndpointManager - Class in org.wso2.carbon.inbound.endpoint.protocol.nats.management
-
Manager which handles NATS Listeners activities for Inbound Endpoints.
- NatsEndpointManager() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.nats.management.NatsEndpointManager
- NatsInjectHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.nats
-
Inject handler to inject NATS message into the sequence.
- NatsInjectHandler(String, String, boolean, SynapseEnvironment, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsInjectHandler
- NatsMessageConsumer - Class in org.wso2.carbon.inbound.endpoint.protocol.nats
-
Message consumer for NATS to initialize connection and listen for messages.
- NatsMessageConsumer(Properties, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsMessageConsumer
- NatsMessageListener - Interface in org.wso2.carbon.inbound.endpoint.protocol.nats
-
The interface which defines behaviour of a core NATS or NATS streaming connection.
- NatsReplySender - Class in org.wso2.carbon.inbound.endpoint.protocol.nats
-
Send the Reply from the Respond Mediator using this class (only for core NATS).
- NatsReplySender(String, Connection) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsReplySender
- NettyThreadPoolConfiguration - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket.configuration
- NettyThreadPoolConfiguration(String, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.configuration.NettyThreadPoolConfiguration
- NETWORK_RECOVERY_INTERVAL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- noPubSubLocal - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- notifyLocalTaskDeletion(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSTask
O
- onErrorSeq - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
- onErrorSeq - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- onErrorSequence - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericInboundListener
- OneTimeTriggerAbstractCallback - Class in org.wso2.carbon.inbound.endpoint.common
-
Generic callback implementation for one time trigger inbound endpoints.
- OneTimeTriggerAbstractCallback() - Constructor for class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerAbstractCallback
- OneTimeTriggerInboundRunner - Class in org.wso2.carbon.inbound.endpoint.common
-
OnetimeTriggerInboundRunner class is used to run the non coordinated processors in background.
- OneTimeTriggerInboundRunner(OneTimeTriggerInboundTask, String) - Constructor for class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerInboundRunner
- OneTimeTriggerInboundTask - Class in org.wso2.carbon.inbound.endpoint.common
-
This class provides Generic Task implementation for one time trigger Inbound Endpoint Tasks
- OneTimeTriggerInboundTask() - Constructor for class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerInboundTask
- onFailure() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionListener
- onMessage(AMQP.BasicProperties, byte[], String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQInjectHandler
-
Determine the message builder to use, set the message payload to the message context and inject the message.
- org.wso2.carbon.inbound.endpoint - package org.wso2.carbon.inbound.endpoint
- org.wso2.carbon.inbound.endpoint.common - package org.wso2.carbon.inbound.endpoint.common
- org.wso2.carbon.inbound.endpoint.inboundfactory - package org.wso2.carbon.inbound.endpoint.inboundfactory
- org.wso2.carbon.inbound.endpoint.internal.http.api - package org.wso2.carbon.inbound.endpoint.internal.http.api
- org.wso2.carbon.inbound.endpoint.protocol - package org.wso2.carbon.inbound.endpoint.protocol
- org.wso2.carbon.inbound.endpoint.protocol.generic - package org.wso2.carbon.inbound.endpoint.protocol.generic
- org.wso2.carbon.inbound.endpoint.protocol.hl7 - package org.wso2.carbon.inbound.endpoint.protocol.hl7
- org.wso2.carbon.inbound.endpoint.protocol.hl7.codec - package org.wso2.carbon.inbound.endpoint.protocol.hl7.codec
- org.wso2.carbon.inbound.endpoint.protocol.hl7.context - package org.wso2.carbon.inbound.endpoint.protocol.hl7.context
- org.wso2.carbon.inbound.endpoint.protocol.hl7.core - package org.wso2.carbon.inbound.endpoint.protocol.hl7.core
- org.wso2.carbon.inbound.endpoint.protocol.hl7.management - package org.wso2.carbon.inbound.endpoint.protocol.hl7.management
- org.wso2.carbon.inbound.endpoint.protocol.hl7.util - package org.wso2.carbon.inbound.endpoint.protocol.hl7.util
- org.wso2.carbon.inbound.endpoint.protocol.http - package org.wso2.carbon.inbound.endpoint.protocol.http
- org.wso2.carbon.inbound.endpoint.protocol.http.config - package org.wso2.carbon.inbound.endpoint.protocol.http.config
- org.wso2.carbon.inbound.endpoint.protocol.http.management - package org.wso2.carbon.inbound.endpoint.protocol.http.management
- org.wso2.carbon.inbound.endpoint.protocol.https - package org.wso2.carbon.inbound.endpoint.protocol.https
- org.wso2.carbon.inbound.endpoint.protocol.httpssecurewebsocket - package org.wso2.carbon.inbound.endpoint.protocol.httpssecurewebsocket
- org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket - package org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket
- org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management - package org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management
- org.wso2.carbon.inbound.endpoint.protocol.jms - package org.wso2.carbon.inbound.endpoint.protocol.jms
- org.wso2.carbon.inbound.endpoint.protocol.jms.factory - package org.wso2.carbon.inbound.endpoint.protocol.jms.factory
- org.wso2.carbon.inbound.endpoint.protocol.kafka - package org.wso2.carbon.inbound.endpoint.protocol.kafka
- org.wso2.carbon.inbound.endpoint.protocol.mqtt - package org.wso2.carbon.inbound.endpoint.protocol.mqtt
- org.wso2.carbon.inbound.endpoint.protocol.nats - package org.wso2.carbon.inbound.endpoint.protocol.nats
- org.wso2.carbon.inbound.endpoint.protocol.nats.management - package org.wso2.carbon.inbound.endpoint.protocol.nats.management
- org.wso2.carbon.inbound.endpoint.protocol.rabbitmq - package org.wso2.carbon.inbound.endpoint.protocol.rabbitmq
- org.wso2.carbon.inbound.endpoint.protocol.securewebsocket - package org.wso2.carbon.inbound.endpoint.protocol.securewebsocket
- org.wso2.carbon.inbound.endpoint.protocol.websocket - package org.wso2.carbon.inbound.endpoint.protocol.websocket
- org.wso2.carbon.inbound.endpoint.protocol.websocket.configuration - package org.wso2.carbon.inbound.endpoint.protocol.websocket.configuration
- org.wso2.carbon.inbound.endpoint.protocol.websocket.management - package org.wso2.carbon.inbound.endpoint.protocol.websocket.management
- org.wso2.carbon.inbound.endpoint.protocol.websocket.pipelinehandlers - package org.wso2.carbon.inbound.endpoint.protocol.websocket.pipelinehandlers
- org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl - package org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl
- org.wso2.carbon.inbound.endpoint.protocol.websocket.subprotocols - package org.wso2.carbon.inbound.endpoint.protocol.websocket.subprotocols
- outFlowDispatchSequence(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- outFlowErrorSequence(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- outflowIdleTime(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- outputReady(IOSession) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPSourceHandler
- outputReady(IOSession) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MultiIOHandler
P
- PARAM_CACHE_LEVEL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- PARAM_DURABLE_SUB_CLIENT_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- PARAM_DURABLE_SUB_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
The name for the durable subscription See
JMSConstants.PARAM_SUB_DURABLE
- PARAM_HL7_AUTO_ACK - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- PARAM_HL7_BUILD_RAW_MESSAGE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- PARAM_HL7_CHARSET - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- PARAM_HL7_PASS_THROUGH_INVALID_MESSAGES - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- PARAM_HL7_PORT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- PARAM_HL7_PRE_PROC - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- PARAM_HL7_TIMEOUT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- PARAM_HL7_VALIDATE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
- PARAM_INBOUND_ENDPOINT_BEHAVIOR - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericInboundListener
- PARAM_INBOUND_ENDPOINT_BEHAVIOR_EVENT_BASED - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
- PARAM_INBOUND_ENDPOINT_BEHAVIOR_LISTENING - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericInboundListener
- PARAM_IS_SHARED_SUBSCRIPTION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
JMS 2.0 Parameters
- PARAM_JMS_HYPHEN_MODE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Does the JMS broker support hyphen in JMS message property names.
- PARAM_JMS_PASSWORD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
The password to use when obtaining a JMS Connection
- PARAM_JMS_SPEC_VER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
The parameter indicating the JMS API specification to be used - if this is "1.1" the JMS 1.1 API would be used, else the JMS 1.0.2B
- PARAM_JMS_USERNAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- PARAM_MQTT_CONFAC - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConstants
- PARAM_MSG_SELECTOR - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
A message selector to be used when messages are sought for this service
- PARAM_PUBSUB_NO_LOCAL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Should a pub-sub connection receive messages published by itself?
- PARAM_REPLY_DESTINATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
The Service level Parameter name indicating the [default] response destination of a service
- PARAM_SUB_DURABLE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- params - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericInboundListener
- parse(String, boolean) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
- parse(String, Parser) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
- PASS_THROUGH_CONTROL_FRAMES - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- passThroughControlFrames() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration
- passThroughControlFrames(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- password - Variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttListener
- pause() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7IOReactor
- payloadToHL7Message(MessageContext, InboundProcessorParams) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.HL7MessageUtils
-
Get the hl7message from the MessageContext
- PinnedPollingTask - Interface in org.wso2.carbon.inbound.endpoint.common
- pipelineHandler(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- PipelineHandlerBuilderUtil - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
-
This class builds a ChannelHandler instance from the pipeline handler String given in the configuration file
- PipelineHandlerBuilderUtil() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.PipelineHandlerBuilderUtil
- poll() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- poll() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSPollingConsumer
-
Create connection with broker and retrieve the messages.
- poll() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAPollingConsumer
-
Create the connection with the zookeeper and inject the messages to the sequence
- PollingConstants - Class in org.wso2.carbon.inbound.endpoint.protocol
-
Define the common properties shared by all polling inbound endpoints
- PollingConstants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.PollingConstants
- port - Variable in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.InboundHttpWebsocketListener
- PREFERRED_CIPHERS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
-
Parameter name for preferred ciphers in inbound endpoint configs
- PREFIX_TO_ENABLE_INTERNAL_APIS - Static variable in class org.wso2.carbon.inbound.endpoint.internal.http.api.Constants
- printHeaders(Log, FullHttpRequest, ChannelHandlerContext) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.WebsocketLogUtil
-
Print the headers associated with the initial Http Request.
- printSpecificLog(Log, ChannelHandlerContext, String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.WebsocketLogUtil
-
Print specific debug logs with the
ChannelHandlerContext
context. - printWebSocketFrame(Log, WebSocketFrame, ChannelHandlerContext, boolean) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.WebsocketLogUtil
-
Print
WebSocketFrame
information. - printWebSocketFrame(Log, WebSocketFrame, ChannelHandlerContext, String, boolean) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.WebsocketLogUtil
-
Print
WebSocketFrame
information. - process(String, String, String) - Method in interface org.wso2.carbon.inbound.endpoint.protocol.hl7.HL7MessagePreprocessor
-
Processes the incoming message and returns a possibly modified message.
- processError(MLLPContext, Exception) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.HL7Processor
- processorParams - Variable in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.InboundHttpWebsocketListener
- processRequest(MLLPContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.HL7Processor
-
HL7 Request Processing logic
- properties - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
- properties - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- PROVIDER_URL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
-
Constant that holds the name of the environment property for specifying configuration information for the service provider to use.
Q
- QUEUE - org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants.JMSDestinationType
- QUEUE_AUTO_ACK - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- QUEUE_AUTO_DELETE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- QUEUE_DURABLE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- QUEUE_EXCLUSIVE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- QUEUE_GROUP - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- QUEUE_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- QUEUE_OPTIONAL_ARG_PREFIX - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- QUEUE_PREFIX - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- QUEUE_ROUTING_KEY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
R
- rabbitmq - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- RABBITMQ_CON_FAC - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- RABBITMQ_REPLY_TO - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- RabbitMQConnectionFactory - Class in org.wso2.carbon.inbound.endpoint.protocol.rabbitmq
-
Encapsulate a RabbitMQ AMQP Connection factory definition within an inbound configuration
- RabbitMQConnectionFactory(Properties) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConnectionFactory
-
Digest a AMQP CF definition from the configuration and construct
- RabbitMQConstants - Class in org.wso2.carbon.inbound.endpoint.protocol.rabbitmq
-
Holds constants for RabbitMQ Inbound Endpoint Implementation
- RabbitMQConstants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- RabbitMQConsumer - Class in org.wso2.carbon.inbound.endpoint.protocol.rabbitmq
-
The actual tasks that perform message consuming
- RabbitMQConsumer(RabbitMQConnectionFactory, Properties, RabbitMQInjectHandler) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConsumer
- RabbitMQException - Exception in org.wso2.carbon.inbound.endpoint.protocol.rabbitmq
-
This class represents RabbitMQ specific exceptions
- RabbitMQException(String) - Constructor for exception org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQException
-
Create an exception with given exception message
- RabbitMQException(String, Exception) - Constructor for exception org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQException
-
Create an exception with given message and wrapping the given exception object
- RabbitMQInjectHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.rabbitmq
-
The received messages will be injected into the sequence for the mediation.
- RabbitMQInjectHandler(String, String, boolean, SynapseEnvironment) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQInjectHandler
- RabbitMQListener - Class in org.wso2.carbon.inbound.endpoint.protocol.rabbitmq
-
The listener implementation to initialize the RabbitMQ consumer once with inbound parameters.
- RabbitMQListener(InboundProcessorParams) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQListener
- RabbitMQRecoveryListener - Class in org.wso2.carbon.inbound.endpoint.protocol.rabbitmq
-
Logging notifications about completed automatic connection recovery
- RabbitMQRecoveryListener() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQRecoveryListener
- RabbitMQTask - Class in org.wso2.carbon.inbound.endpoint.protocol.rabbitmq
-
The task implementation to trigger the RabbitMQ consumer.
- RabbitMQTask(RabbitMQConsumer) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQTask
- RabbitMQUtils - Class in org.wso2.carbon.inbound.endpoint.protocol.rabbitmq
-
Helper class to support AMQP inbound endpoint related functions
- RabbitMQUtils() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQUtils
- read() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageInputStream
- read(byte[]) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageInputStream
- read(byte[], int, int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageInputStream
- READ_COMPLETE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- READ_CONTENT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- READ_HEADER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- READ_TRAILER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- RECEIVER_TIMEOUT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- reConnect() - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerAbstractCallback
- reConnect() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
- recoverSession(Session, boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.CachedJMSConnectionFactory
-
Recover JMS session
- registerClientDataStore(String, MqttDefaultFilePersistence) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- registerEventExecutor(int, InboundWebsocketEventExecutor) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEventExecutorManager
- registerHandler(JMSInjectHandler) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSPollingConsumer
-
Register a handler to implement injection of the retrieved message
- registerHandler(InjectHandler) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAPollingConsumer
-
Register a handler to implement injection of the retrieved message
- registerHandler(NatsInjectHandler) - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsMessageConsumer
-
Register a handler to implement injection of the retrieved message.
- registerInboundEndpoint(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- registerInboundTenantLoadingFlag(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- registerMqttCallback(String, MqttAsyncCallback) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- registerMqttClient(String, MqttAsyncClient) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- releaseCallbackSuspension() - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerAbstractCallback
- removeChannelContext(String, String, InboundWebsocketChannelContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketSubscriberPathManager
- removeDispatchPattern(String, int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Removes a dispatch pattern from pattern map.
- removeWorkerPoolConfiguration(String, int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Remove Worker Pool
- requestInput() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- requestOutput() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- requestReceived(NHttpServerConnection) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpSourceHandler
- REQUEUE_FALSE - org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.AcknowledgementMode
- REQUEUE_TRUE - org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.AcknowledgementMode
- reset() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- RETRY_COUNT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- RETRY_INTERVAL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- run() - Method in class org.wso2.carbon.inbound.endpoint.common.InboundRunner
- run() - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerInboundRunner
- run() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundCorrelationEnabledHttpServerWorker
- run() - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpServerWorker
- run() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.SimpleKafkaMessageListener
S
- SamplePipelineHandler - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket.pipelinehandlers
-
This class is an example of a Pipeline Handler
- SamplePipelineHandler() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.pipelinehandlers.SamplePipelineHandler
- scanInterval - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- SELECT_INTERVAL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- sendBack(MessageContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.HL7Processor
- sendBack(MessageContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpResponseSender
- sendBack(MessageContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSReplySender
-
Send the reply back to the response queue/topic
- sendBack(MessageContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsReplySender
- sendBack(MessageContext) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketResponseSender
- sequential - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
- sequential - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
- SERVER_HOST_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SERVER_PASSWORD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SERVER_PORT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SERVER_USER_NAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SERVER_VIRTUAL_HOST - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SESSION_ACK - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- SESSION_TRANSACTED - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- sessionAckMode - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- SET_REQUEUE_ON_ROLLBACK - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SET_ROLLBACK_ONLY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- SET_ROLLBACK_ONLY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- setApplicationAck(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- setAutoAck(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- setCallback(OneTimeTriggerAbstractCallback) - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerInboundTask
- setCertPass(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- setCipherSuites(String[]) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- setClientBroadcastLevel(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- setClientBroadcastLevel(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- setConnection(Connection) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSInjectHandler
- setDispatchToCustomSequence(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- setDispatchToCustomSequence(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- setExpiry(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- setHandlers(List<InternalAPIHandler>) - Method in interface org.wso2.carbon.inbound.endpoint.internal.http.api.InternalAPI
-
Sets the handlers associated with the API
- setHl7Message(Message) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- setInboundName(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConsumer
- setInboundRunnerMode(boolean) - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerAbstractCallback
- setInflowIdleTime(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- setMarkForClose(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- setMessageId(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- setMqttConnectionConsumer(MqttConnectionConsumer) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
- setNackMode(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- setName(String) - Method in interface org.wso2.carbon.inbound.endpoint.internal.http.api.InternalAPI
-
Sets the name of the API
- setName(String) - Method in interface org.wso2.carbon.inbound.endpoint.internal.http.api.InternalAPIHandler
-
Sets the name of the Handler
- setName(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedListener
- setName(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericProcessor
- setName(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSProcessor
- setName(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAProcessor
- setName(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
-
Set the inbound endpoint name
- setName(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttListener
- setName(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConnectionFactory
-
Set connection factory name
- setOutflowDispatchSequence(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- setOutflowDispatchSequence(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- setOutflowErrorSequence(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- setOutflowErrorSequence(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- setOutflowIdleTime(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- setPassThroughControlFrames(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- setPassThroughControlFrames(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- setPipelineHandler(ChannelHandler) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- setPortOffset(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- setPortOffset(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- setReplyDestination(Destination) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSInjectHandler
- setRequestTime(long) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- setSourceHandler(InboundWebsocketSourceHandler) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- setSslConfiguration(InboundWebsocketSSLConfiguration) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- setSslProtocols(String[]) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- setState(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- setSubprotocolHandlers(ArrayList<AbstractSubprotocolHandler>) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelInitializer
- setSubprotocolHandlers(ArrayList<AbstractSubprotocolHandler>) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketSourceHandler
- setSubprotocolIdentifier(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.AbstractSubprotocolHandler
- setTenantDomain(String) - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerAbstractCallback
- setTransportHeaders(MessageContext, Message) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSUtils
-
Set transport headers from the axis message context, into the JMS message
- setTrustStore(File) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- setTrustStorePass(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration
- setValidateMessage(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.context.MLLPContext
- shutdown() - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerAbstractCallback
- shutdown() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
- shutdown() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionConsumer
- shutdown() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionListener
- shutdown(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- SHUTDOWN_GRACE_PERIOD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- shutdownEventExecutor() - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketEventExecutor
- shutdownExecutor(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEventExecutorManager
- SIMPLE - org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener.CONSUMER_TYPE
- SIMPLE_BROKERS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- SIMPLE_MAX_MSG_TO_READ - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- SIMPLE_PARTITION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- SIMPLE_PORT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- SIMPLE_TOPIC - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- SimpleKafkaMessageListener - Class in org.wso2.carbon.inbound.endpoint.protocol.kafka
- SimpleKafkaMessageListener(Properties, InjectHandler) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.kafka.SimpleKafkaMessageListener
- SO_KEEP_ALIVE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- SO_RCVBUF - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- SO_SNDBUF - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- SO_TIMEOUT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- SO_TIMEOUT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- SOAP_ACTION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
-
String representing SOAPAction which is used to set WSAction in synapse message properties.
- SOURCE_HANDSHAKE_PRESENT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- SSL_ENABLED - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SSL_KEYSTORE_LOCATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SSL_KEYSTORE_PASSWORD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SSL_KEYSTORE_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SSL_PROTOCOL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- SSL_PROTOCOLS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- SSL_TRUSTSTORE_LOCATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SSL_TRUSTSTORE_PASSWORD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SSL_TRUSTSTORE_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SSL_VERIFY_CLIENT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- SSL_VERSION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQConstants
- SSLConfigurationBuilder(String, String, String, String, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration.SSLConfigurationBuilder
- SSLConfigurationBuilder(String, String, String, String, String, String, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.InboundWebsocketSSLConfiguration.SSLConfigurationBuilder
- SSLHandlerFactory - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl
- SSLHandlerFactory(InboundWebsocketSSLConfiguration) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.ssl.SSLHandlerFactory
- start() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedListener
- start() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericProcessor
- start() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7IOReactor
- start() - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7Listener
- start() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
-
Start to consume the messages from topics
- start() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAMessageListener
-
Starts topics consuming the messages,the message can be consumed by topic or topic filter which are white list and black list.
- start() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAProcessor
-
Register/start the schedule service
- start() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.SimpleKafkaMessageListener
- start() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttListener
- start(Connection) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- start(InboundTask, String) - Method in class org.wso2.carbon.inbound.endpoint.common.InboundRequestProcessorImpl
-
Based on the coordination option schedule the task with NTASK or run as a background thread
- start(OneTimeTriggerInboundTask, String) - Method in class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerRequestProcessor
-
Based on the coordination option schedule the task with NTASK or run as a background thread
- start(GenericOneTimeTask, String) - Method in class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerEventBasedProcessor
-
Based on the coordination option schedule the task with NTASK or run as a background thread
- start(JMSPollingConsumer, int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSProcessor
-
Register/start the schedule service
- startConsumers(List<KafkaStream<byte[], byte[]>>) - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAMessageListener
-
Use one stream from kafka stream iterator
- startEndpoint(int, String, InboundProcessorParams) - Method in interface org.wso2.carbon.inbound.endpoint.common.InboundEndpointManager
-
Start Inbound endpoint on a particular port
- startEndpoint(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.management.HL7EndpointManager
- startEndpoint(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Start Http Inbound endpoint in a particular port
- startEndpoint(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management.HttpWebsocketEndpointManager
- startEndpoint(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.management.NatsEndpointManager
-
Start NATS Inbound endpoint
- startEndpoint(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- startInboundTenantLoading(String) - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerAbstractCallback
- startListener(int, String, InboundProcessorParams) - Method in interface org.wso2.carbon.inbound.endpoint.common.InboundEndpointManager
-
Start Listener on a particular port
- startListener(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.management.HL7EndpointManager
- startListener(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Start Http Listener in a particular port
- startListener(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management.HttpWebsocketEndpointManager
- startListener(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.nats.management.NatsEndpointManager
-
Start NATS Listener
- startListener(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- startsMessageListener() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAPollingConsumer
-
Start the listener to listen when new messages come to the esb,the listener can be high level or low level.
- startSSLEndpoint(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management.HttpWebsocketEndpointManager
- startSSLEndpoint(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- startSSLEndpoint(int, String, SSLConfiguration, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Start Https Inbound endpoint in a particular port
- startSSLListener(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.httpwebsocket.management.HttpWebsocketEndpointManager
- startSSLListener(int, String, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- startSSLListener(int, String, SSLConfiguration, InboundProcessorParams) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.management.HTTPEndpointManager
-
Start Http Listener in a particular port
- startUpController - Variable in class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerRequestProcessor
- stop() - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7IOReactor
- stop(Connection) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- StreamingListener - Class in org.wso2.carbon.inbound.endpoint.protocol.nats
-
Streaming listener class which uses NATS streaming connection to receive messages.
- StreamingListener(String, NatsInjectHandler, Properties) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.nats.StreamingListener
- stringToPipelineHandlers(String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.PipelineHandlerBuilderUtil
-
build a ChannelHandler instance from a String
- stringToSubprotocolHandlers(String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.SubprotocolBuilderUtil
- SUBJECT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- SubprotocolBuilderUtil - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
- SubprotocolBuilderUtil() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.SubprotocolBuilderUtil
- subprotocolHandler(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- subscriptionName - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- syanapeSubprotocolToContentType(String) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.SubprotocolBuilderUtil
- SYNAPSE_SUBPROTOCOL_PREFIX - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- synapseEnvironment - Variable in class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerRequestProcessor
- synapseEnvironment - Variable in class org.wso2.carbon.inbound.endpoint.common.InboundRequestProcessorImpl
- synapseEnvironment - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedConsumer
- synapseEnvironment - Variable in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericPollingConsumer
T
- TASK_THRESHOLD_INTERVAL - Static variable in class org.wso2.carbon.inbound.endpoint.common.InboundOneTimeTriggerRequestProcessor
- TASK_THRESHOLD_INTERVAL - Static variable in class org.wso2.carbon.inbound.endpoint.common.InboundTask
- taskExecute() - Method in class org.wso2.carbon.inbound.endpoint.common.InboundTask
- taskExecute() - Method in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerInboundTask
- taskExecute() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericOneTimeTask
- taskExecute() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericTask
- taskExecute() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSTask
- taskExecute() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKATask
- taskExecute() - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttTask
- taskExecute() - Method in class org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.RabbitMQTask
- TCP_NO_DELAY - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- TCPConstants() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- tenantDomain - Variable in class org.wso2.carbon.inbound.endpoint.common.OneTimeTriggerAbstractCallback
- terminate() - Method in class org.wso2.carbon.inbound.endpoint.common.InboundRunner
-
Exit the running while loop and terminate the thread
- TEXT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- TEXT_BUILDER_IMPLEMENTATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- THREAD_COUNT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- threadCount - Variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
- timeout(IOSession) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPSourceHandler
- timeout(IOSession) - Method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MultiIOHandler
- TLS_KEY_MANAGER_ALGORITHM - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- TLS_KEYSTORE_LOCATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- TLS_KEYSTORE_PASSWORD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- TLS_KEYSTORE_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- TLS_PROTOCOL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- TLS_TRUST_MANAGER_ALGORITHM - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- TLS_TRUSTSTORE_LOCATION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- TLS_TRUSTSTORE_PASSWORD - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- TLS_TRUSTSTORE_TYPE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- TOPIC - org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants.JMSDestinationType
- TOPIC_FILTER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- TOPIC_PREFIX - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants
- topics - Variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener
- TOPICS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- TRACE_CONNECTION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- transactedSession - Variable in class org.wso2.carbon.inbound.endpoint.protocol.jms.factory.JMSConnectionFactory
- TRUST_STORE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConstants
- TURN_ON_ADVANCED_STATS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
U
- unbind(int) - Static method in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.InboundHL7IOReactor
- unRegisterInboundTenantLoadingFlag(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- unregisterMqttClient(String, String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttClientManager
- update() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericEventBasedListener
- update() - Method in class org.wso2.carbon.inbound.endpoint.protocol.generic.GenericProcessor
- update() - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.JMSProcessor
- update() - Method in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAProcessor
- updateInjectHandler(MqttInjectHandler) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttAsyncCallback
- USE_CORE_NATS_CONNECTION - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.nats.NatsConstants
- usePortOffset(boolean) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- userName - Variable in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttListener
- UTF8_CHARSET - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants
V
- V2X - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants.MessageType
- V3X - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants.MessageType
- validateBroadcastLevelParam(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- validatePortField(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.mqtt.MqttConnectionFactory
- valueOf(String) - Static method in enum org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants.JMSDestinationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener.CONSUMER_TYPE
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.AcknowledgementMode
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.wso2.carbon.inbound.endpoint.protocol.jms.JMSConstants.JMSDestinationType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.wso2.carbon.inbound.endpoint.protocol.kafka.AbstractKafkaMessageListener.CONSUMER_TYPE
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.wso2.carbon.inbound.endpoint.protocol.rabbitmq.AcknowledgementMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
W
- WEB_SOCKET_CLOSE_CODE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEB_SOCKET_REASON_TEXT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_BINARY_FRAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_BINARY_FRAME_PRESENT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_CLIENT_SIDE_BROADCAST_LEVEL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_CLOSE_CLIENT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_CLOSE_CODE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_CORRELATION_ID - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_DISPATCH_IDLETIME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_OUTFLOW_DISPATCH_FAULT_SEQUENCE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_OUTFLOW_DISPATCH_IDLETIME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_OUTFLOW_DISPATCH_SEQUENCE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_PING_FRAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_PING_FRAME_PRESENT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_PONG_FRAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_PONG_FRAME_PRESENT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_REASON_TEXT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_SOURCE_CHANNEL_IDENTIFIER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_SOURCE_HANDLER_CONTEXT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_SOURCE_HANDSHAKE_PRESENT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
-
Deprecated.
- WEBSOCKET_SUBPROTOCOL - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_SUBSCRIBER_PATH - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_TARGET_HANDLER_CONTEXT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_TARGET_HANDSHAKE_PRESENT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_TEXT_FRAME - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_TEXT_FRAME_PRESENT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WEBSOCKET_TRANSPORT_MAX_FRAME_PAYLOAD_LENGTH - Static variable in class org.wso2.carbon.inbound.endpoint.internal.http.api.Constants
- WEBSOCKET_USE_PORT_OFFSET - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WebsocketEndpointManager - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket.management
- WebsocketEndpointManager() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEndpointManager
- WebsocketEventExecutorManager - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket.management
- WebsocketEventExecutorManager() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketEventExecutorManager
- WebsocketLogUtil - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket
-
This class will be used log the websocket communication related requests/frames between client and the gateway.
- WebsocketLogUtil() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.WebsocketLogUtil
- WebsocketSubscriberPathManager - Class in org.wso2.carbon.inbound.endpoint.protocol.websocket.management
- WebsocketSubscriberPathManager() - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.websocket.management.WebsocketSubscriberPathManager
- WORKER_THREADS_CORE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- WORKER_THREADS_CORE_DEFAULT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.core.MLLPConstants.TCPConstants
- WorkerPoolConfiguration - Class in org.wso2.carbon.inbound.endpoint.protocol.http.config
-
Wrapping class for Inbound Worker Pool Configs
- WorkerPoolConfiguration(String, String, String, String, String, String) - Constructor for class org.wso2.carbon.inbound.endpoint.protocol.http.config.WorkerPoolConfiguration
- workerPoolCoreSize(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration.InboundHttpConfigurationBuilder
- workerPoolKeepAlive(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration.InboundHttpConfigurationBuilder
- workerPoolMaxSize(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration.InboundHttpConfigurationBuilder
- workerPoolQueueLength(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration.InboundHttpConfigurationBuilder
- workerPoolThreadGroup(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration.InboundHttpConfigurationBuilder
- workerPoolThreadId(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.http.InboundHttpConfiguration.InboundHttpConfigurationBuilder
- workerThreadPoolSize(String) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConfiguration.InboundWebsocketConfigurationBuilder
- write(byte[]) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageOutputStream
- write(byte[], int, int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageOutputStream
- write(int) - Method in class org.wso2.carbon.inbound.endpoint.protocol.jms.BytesMessageOutputStream
- WRITE_COMPLETE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- WRITE_CONTENT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- WRITE_HEADER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- WRITE_TRAILER - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.codec.HL7Codec
- writeToChannel(WebSocketFrame) - Method in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketChannelContext
- ws - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- WS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WS_CLOSE_DEFAULT_CODE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WS_CLOSE_DEFAULT_TEXT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WS_CLOSE_FRAME_REASON_TEXT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WS_CLOSE_FRAME_STATUS_CODE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WS_UNAUTHORIZED_CODE - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- WS_UNEXPECTED_CONNECTION_CLOSURE_TEXT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
- wss - org.wso2.carbon.inbound.endpoint.inboundfactory.InboundRequestProcessorFactoryImpl.Protocols
- WSS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.websocket.InboundWebsocketConstants
X
- XML - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.hl7.util.Axis2HL7Constants.MessageEncoding
Z
- ZOOKEEPER_COMMIT_INTERVAL_MS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- ZOOKEEPER_CONNECT - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- ZOOKEEPER_SESSION_TIMEOUT_MS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
- ZOOKEEPER_SYNC_TIME_MS - Static variable in class org.wso2.carbon.inbound.endpoint.protocol.kafka.KAFKAConstants
All Classes All Packages