|
Spring Integration | |||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
MessageChannel instances.MessageDispatcher implementations.ExpressionSource implementations.FileListFilter whose criteria can be
evaluated against each File in isolation.JmsTemplate.MailReceiver implementations.MessageChannel implementations providing common
properties such as the channel name.MessageProcessor.MessageChannels for sending, receiving, or request-reply operations.Transformer implementations that modify the payload
of a Message.MessageProcessor for scripting implementations to extend.ScriptSource.
AbstractChannelNameResolvingMessageRouter to support router
implementations that always return a single channel name (or null).AbstractMessageRouter to support router implementations that
always return a single MessageChannel instance (or null).MessageChannel that invokes the subscribed
handler(s) by delegating to a MessageDispatcher.Transformer implementations.MessageSelector implementations.XPathExpression evaluation to determine channel names.XPathExpression evaluates to true
XPathExpression is equal to the valueToTestFor.
FileListFilter that passes files only one time.TcpListener, this
method is called each time a new connection is made.
@Aggregator annotation.ApplicationEvents within messages.MessageHandler that publishes each Message it receives as
a MessagingEvent.MessageFormats.FORMAT_CRLF.
MessageFormats.FORMAT_CUSTOM.
UnsupportedOperationException; custom implementations can
subclass this class and provide an implementation for this method.
UnsupportedOperationException; custom implementations can
subclass this class and provide an implementation.
MessageFormats.FORMAT_LENGTH_HEADER.
MessageFormats.FORMAT_JAVA_SERIALIZED
UnsupportedOperationException; Java serialization is currently only
supported using the NetSocketReader.
MessageFormats.FORMAT_STX_ETX.
MessageSource implementation that retrieves the current
value of a JMX attribute each time AttributePollingMessageSource.receive() is invoked.ChannelResolver implementation based on a Spring BeanFactory.BeanFactoryChannelResolver class.
BeanFactoryChannelResolver class.
MessageSelector.MessageSelector supporting
mutliple namespaces.
MessageSelector supporting a
single namespace.
MessageSelector with no namespace
support.
MessageSelector using the
provided XPathExpression.
InputStream.MessageHandler that writes a byte array to an OutputStream.ConfigAttributes for secured channel
send and receive operations based on simple String values.Messages being sent-to and/or received-from a
MessageChannel.ChannelInterceptor with no-op method implementations so that
subclasses do not have to implement all of the interface's methods.ChannelSecurityInterceptor.SecurityMetadataSource implementation for secured MessageChannels.Messages from one or more
QueueChannels.MessageChannel.BeanPostProcessor that proxies MessageChannels to apply a ChannelSecurityInterceptor.Readers.MessageHandler that writes characters to a Writer.Messages from this channel.
FileFilters.ControlBus that will register channels and endpoints as MBeans with the given MBeanServer using
the default domain name.
ControlBus that will register channels and endpoints as MBeans with the given MBeanServer using
the specified domain name.
UUIDConverter.getUUID(Object).
MessageStore.CorrelationStrategy implementation that works as an adapter to another bean.javax.jms.QueueConnection.
SqlParameterSource.
javax.jms.QueueSession.
Source instance for payload
MessageFormats.FORMAT_CRLF.
HeaderMapper implementation for HTTP.InboundRequestMapper for inbound HttpServletRequests.JmsHeaderMapper.MessageConverter implementation that is capable of delegating to
an existing converter instance.SimpleMessageConverter.
MessageConverter instance.
MethodInvoker to be used when the actual Method reference is known.MultipartFileReader implementation that reads the MultipartFile
content directly into a new MultipartFile instance that is not restricted
to the HTTP request scope.OutboundRequestMapper.SqlParameterSourceFactory which creates an SqlParameterSource according
to the type of the data passed in.TransformerConfigurer instance which looks for headers and uses them
to configure the provided Transformer instance.XmlPayloadConverter.MessageHandler that is capable of delaying the continuation of a
Message flow based on the presence of a delay header on an inbound Message
or a default delay value configured on this handler.DeserializationException with the specified detail message.
DeserializationFailureException with the specified detail message
and nested exception.
JavaStreamingConverter to deserialize data
in a byte[] to an object.RoundRobinLoadBalancingStrategy
LoadBalancingStrategy.
SourceFactory implementation which supports creation of a
DOMSource from a Document or String payload.TaskExecutor implementation that wraps an existing Executor
instance in order to catch any exceptions.Throwable payload.MessageChannel for
messages whose payload is an Exception..$[]^*+{}()\?
- ETX -
Static variable in class org.springframework.integration.ip.tcp.converter.ByteArrayStxEtxConverter
-
- ETX -
Static variable in interface org.springframework.integration.ip.tcp.MessageFormats
-
- etxPart -
Variable in class org.springframework.integration.ip.tcp.NioSocketWriter
- A buffer containing the ETX for when the messageFormat is
MessageFormats.FORMAT_STX_ETX.
- evaluateExpression(Expression, Message<?>, Class<?>) -
Method in class org.springframework.integration.handler.AbstractMessageProcessor
-
- evaluateXPath(XPathExpression, Node) -
Method in enum org.springframework.integration.xml.xpath.XPathEvaluationType
-
- EventDrivenConsumer - Class in org.springframework.integration.endpoint
- Message Endpoint that connects any
MessageHandler implementation
to a SubscribableChannel. - EventDrivenConsumer(SubscribableChannel, MessageHandler) -
Constructor for class org.springframework.integration.endpoint.EventDrivenConsumer
-
- EventInboundChannelAdapterParser - Class in org.springframework.integration.event.config
-
- EventInboundChannelAdapterParser() -
Constructor for class org.springframework.integration.event.config.EventInboundChannelAdapterParser
-
- EventNamespaceHandler - Class in org.springframework.integration.event.config
- Namespace handler for Spring Integration's 'event' namespace.
- EventNamespaceHandler() -
Constructor for class org.springframework.integration.event.config.EventNamespaceHandler
-
- EventOutboundChannelAdapterParser - Class in org.springframework.integration.event.config
-
- EventOutboundChannelAdapterParser() -
Constructor for class org.springframework.integration.event.config.EventOutboundChannelAdapterParser
-
- exchange(Message<?>) -
Method in class org.springframework.integration.gateway.RemotingInboundGatewaySupport
-
- exchange(Message<?>) -
Method in interface org.springframework.integration.gateway.RequestReplyExchanger
-
- execute(MessageGroupStore, MessageGroup) -
Method in interface org.springframework.integration.store.MessageGroupCallback
-
- execute(Runnable) -
Method in class org.springframework.integration.util.ErrorHandlingTaskExecutor
-
- executeMethod(Collection<? extends Message<?>>) -
Method in class org.springframework.integration.aggregator.MessageListMethodAdapter
-
- executeScript(ScriptSource, Message<?>) -
Method in class org.springframework.integration.groovy.GroovyScriptExecutingMessageProcessor
-
- executeScript(ScriptSource, Message<?>) -
Method in class org.springframework.integration.handler.AbstractScriptExecutingMessageProcessor
- Subclasses must implement this method.
- ExecutorChannel - Class in org.springframework.integration.channel
- An implementation of
MessageChannel that delegates to an instance of
UnicastingDispatcher which in turn delegates all dispatching
invocations to an Executor. - ExecutorChannel(Executor) -
Constructor for class org.springframework.integration.channel.ExecutorChannel
- Create an ExecutorChannel that delegates to the provided
Executor when dispatching Messages.
- ExecutorChannel(Executor, LoadBalancingStrategy) -
Constructor for class org.springframework.integration.channel.ExecutorChannel
- Create an ExecutorChannel with a
LoadBalancingStrategy that
delegates to the provided Executor when dispatching Messages.
- EXPIRATION_DATE -
Static variable in class org.springframework.integration.MessageHeaders
-
- expireMessageGroups(long) -
Method in class org.springframework.integration.store.AbstractMessageGroupStore
-
- expireMessageGroups(long) -
Method in interface org.springframework.integration.store.MessageGroupStore
- Extract all expired groups (whose timestamp is older than the current time less the threshold provided) and call
each of the registered callbacks on them in turn.
- EXPRESSION_ATTRIBUTE -
Static variable in class org.springframework.integration.config.xml.AbstractConsumerEndpointParser
-
- ExpressionBinding - Annotation Type in org.springframework.integration.aop
- Annotation that provides the variable names to use when constructing the
evaluation context for a MessagePublishingInterceptor.
- ExpressionEvaluatingMessageProcessor - Class in org.springframework.integration.handler
- A
MessageProcessor implementation that evaluates a SpEL expression
with the Message itself as the root object within the evaluation context. - ExpressionEvaluatingMessageProcessor(String) -
Constructor for class org.springframework.integration.handler.ExpressionEvaluatingMessageProcessor
- Create an
ExpressionEvaluatingMessageProcessor for the given expression String.
- ExpressionEvaluatingRouter - Class in org.springframework.integration.router
- A Message Router implementation that evaluates the specified SpEL
expression.
- ExpressionEvaluatingRouter(String) -
Constructor for class org.springframework.integration.router.ExpressionEvaluatingRouter
-
- ExpressionEvaluatingSelector - Class in org.springframework.integration.filter
- A
MessageSelector implementation that evaluates a SpEL expression. - ExpressionEvaluatingSelector(String) -
Constructor for class org.springframework.integration.filter.ExpressionEvaluatingSelector
-
- ExpressionEvaluatingSplitter - Class in org.springframework.integration.splitter
- A Message Splitter implementation that evaluates the specified SpEL
expression.
- ExpressionEvaluatingSplitter(String) -
Constructor for class org.springframework.integration.splitter.ExpressionEvaluatingSplitter
-
- ExpressionEvaluatingTransformer - Class in org.springframework.integration.transformer
- A Message Transformer implementation that evaluates the specified SpEL
expression.
- ExpressionEvaluatingTransformer(String) -
Constructor for class org.springframework.integration.transformer.ExpressionEvaluatingTransformer
-
- extractOutputPropertyHeaders(MessageHeaders) -
Method in class org.springframework.integration.xml.transformer.DefaultTransformerConfigurer
-
- extractParameterHeaders(MessageHeaders) -
Method in class org.springframework.integration.xml.transformer.DefaultTransformerConfigurer
-
MultipartFileReader implementation that copies the MulitpartFile's
content to a new temporary File in the specified directory.FileCopyingMultipartFileReader that creates temporary
Files in the default temporary directory.
FileCopyingMultipartFileReader that creates temporary
Files in the given directory.
MessageSource that creates messages from a file system directory.PriorityBlockingQueue ordered with the passed in Comparator
The size of the queue used should be large enough to hold all the files in the input directory in order to sort
all of them, so restricting the size of the queue is mutually exclusive with ordering.
MessageHandler implementation that writes the Message payload to a
file.@Filter.Roster
Message instance pre-populated with
all of the headers copied from the provided message.
Message to an integration Message payload.
Presence object from the inbound Message headers, if possible.
XPathExpression.evaluateAsString(Node)
IntegrationObjectSupport.componentName field.
AbstractConnectionFactory.setSingleUse(boolean) was called with
true, a new connection is returned; otherwise a single connection is
reused for all requests while the connection remains open.
AbstractConnectionFactory.setSingleUse(boolean) was called with
true, a new connection is returned; otherwise a single connection is
reused for all requests while the connection remains open.
next() invocations.
MessageGroupStore.addMessageToGroup(Object, Message) with this group id.
SqlParameterSourceFactory.
Message.NetSocketReader and calls its AbstractSocketReader.assembledData
method repeatedly; for each assembled message, calls MessageProducerSupport.sendMessage(Message) with
the mapped message.
maxNumberOfFiles elements from a directory listing.CorrelationStrategy.MessageHeaders to and from other
types of objects.MessageHeaders of a Message containing any entry
or multiple that match?MessageHandler implementation that executes HTTP requests by delegating
to a RestTemplate instance.Controller
interface to be used with a DispatcherServlet front controller.MailReceiver implementation for receiving mail messages from a
mail server that supports the IMAP protocol.InboundMessageMapper implementation that maps incoming JSON messages to a Message with the specified payload type.Message.HttpServletRequest
to a Message.ChannelResolver and TaskScheduler instances.ConcurrentLinkedQueue.iterator().
DataSource from which the DB Connection can be obtained and the select query to
execute to retrieve new rows.
JdbcOperations instance to use for query execution and the select query to execute to
retrieve new rows.
MessageStore using a relational database via JDBC.MessageStore with all mandatory properties.
JdbcMessageStore.DataSource from which the DB Connection can be
obtained and the select query to execute to retrieve new rows.
JdbcOperations instance to use for query
execution and the select query to execute to retrieve new rows.
JdbcPollingChannelAdapter.MessageChannel implementation that is actually backed by a JMS
Destination.MessageFormats.FORMAT_LENGTH_HEADER.
true if it was
successful, false otherwise.
true if it was
successful, false otherwise.
Messages.MessageSource implementation that delegates to a
MailReceiver to poll a mailbox.MessageHandler implementation for sending mail.Message to a String.ChannelResolver implementation that resolves MessageChannel
instances by matching the channel name against keys within a Map.MapBasedChannelResolver.setChannelMap(Map).
ChannelResolver that uses the provided Map.
Map.AbstractTransformer that delegates to an OXM Marshaller.MarshallingWebServiceInboundGateway.
MarshallingWebServiceInboundGateway with the given marshaller.
MarshallingWebServiceInboundGateway with the given marshaller and unmarshaller.
ReleaseStrategy that releases only the first n messages, where n is a threshold.MessageSelector.MessageSelector.
BlockingQueue that is backed by a MessageGroupStore.MessageGroup instances in a
MessageGroupStore.MessageHandler implementation that invokes a chain of
MessageHandler instances in order.Message.MessageHistoryEvent instances.MessageChannels and
MessageHandlers.Message instances or payloads.MessageChannel.ErrorHandler implementation that sends an ErrorMessage to a
MessageChannel.MethodInterceptor that publishes Messages to a channel.ChannelInterceptor that
delegates to a list of MessageSelectors to decide
whether a Message should be accepted on the MessageChannel.Comparator implementation based on the 'sequence number'
property of a Message's header.Messages that can be polled.ChannelInterceptor which invokes a Transformer
when either sending-to or receiving-from a channel.MessageHandler that delegates to a
Transformer instance to modify the received Message
and sends the result to its output channel.MessageTransformingHandler instance that delegates to
the provided Transformer.
BeanPostProcessor implementation that processes method-level
messaging annotations such as @Transformer, @Splitter, @Router, and @Filter.ApplicationEvent that wraps a Message.MessageChannels.ExpressionSource implementation that retrieves the expression
string and evaluation context variable names from an annotation.MessageHandler that invokes the specified method on the provided object.MessageSource implementation that invokes a no-argument method so
that its return value may be sent to a channel.MessageSelector.Message matcher creation.MessageHandler implementation that maps a Message into
a UDP datagram packet and sends that to the specified multicast address
(224.0.0.0 to 239.255.255.255) and port.HttpMessageConverter implementation that delegates to an instance of
XmlAwareFormHttpMessageConverter while adding the capability to read
multipart/form-data content in an HTTP request.MultipartFile content.MethodInvoker to be used when only the method name is known.Socket.SocketWriter that writes to a Socket.SocketChannel.SocketWriter that writes to a SocketChannel.NotificationListener implementation that will send Messages
containing the JMX Notification instances as their payloads.toString() method.MessageHandler implementation for invoking JMX operations based on
the Message sent to its AbstractMessageHandler.handleMessage(Message) method.OutboundMessageMapper implementation the converts a Message to a JSON string representation.Message to an Object.HttpEntity from a message.FileListFilter implementation that matches against a Pattern.Message equal to a given value or is matching
a given matcher?HandlerMethodResolver that matches the payload
type of the Message against the expected type of its candidate methods.MessageChannel based on the
Message's payload type.MessageSelector implementation that checks the type of the
Message payload.MessageHandler implementation
to a PollableChannel.MailReceiver implementation that polls a mail server using the
POP3 protocol.MessageSelector,
send it to the secondary target.
Comparator.MessagePublishingInterceptor to any
methods containing the provided annotations.Publisher annotation.Executor
to invoke the handlers.
Messages that are not accepted by the provided selector.
MultipartFile content.
Message converting and returning it as
a Spring Integration Message.
MessageGroupStore.expireMessageGroups(long).
@ReleaseStrategy
and for 'release-strategy' elements that include a 'method'
attribute (e.g.TcpListener, this
method is called each time a connection is closed.
QueueChannel that delegates to a
SynchronousQueue internally.Result possibly taking into account the
provided message payload instance.Document from a Result payload.Result to an instance of String
Supports StringResult and DOMResultLoadBalancingStrategy.@Router.AbstractTcpReceivingChannelAdapter.server().
timeout provided.
ChannelSecurityInterceptor
to control send and receive access, and creates a bean post-processor to apply the
interceptor to MessageChannels
whose names match the specified patterns.Message to this channel.
ReleaseStrategy that simply compares the
current size of the message list to the expected 'sequenceSize'.SerializationException with the specified detail message.
SerializationException with the specified detail message
and nested exception.
SerializationFailureException with the specified detail message.
SerializationFailureException with the specified detail message
and nested exception.
JavaStreamingConverter to serialize an object
to a byte[].HttpMessageConverter implementation for Serializable instances.SerializingHttpMessageConverter.
TcpNetReceivingChannelAdapter.handleSocket(Socket) method for each new
connection.
ServerSocketChannel, registers it with a
Selector and calls TcpNioReceivingChannelAdapter.doSelect(ServerSocketChannel, Selector).
@ServiceActivator.ServiceActivatingHandler instances.SourceFactory.
ResultFactory and SourceFactory should always
be used, even for directly supported payloads such as String and Document.
@beanName in the expression.
BeanFactory necessary to look up a
'targetBeanName' if specified.
XPathExpression
to test value should be case sensitive.
ChannelResolver strategy to use.
ConversionService to use when trying to convert to
one of this channel's supported datatypes for a Message whose payload
does not already match.
XmlPayloadConverter to use when converting a Message payload prior to XPath evaluation.
DataSource to use when interacting with the database.
DestinationResolver to use when resolving either a
'requestDestinationName' or 'replyDestinationName' value.
ErrorHandler strategy for handling Exceptions that
occur downstream from this channel.
ResponseErrorHandler for the underlying RestTemplate.
XPathEvaluationType.
InboundMessageMapper for creating a reply Message from
an Exception that occurs downstream from this gateway.
ApplicationContext is closed).
MessageConverter
has been provided to the JmsOutboundGateway.setMessageConverter(MessageConverter)
method.
MessageConverter
has been provided to the JmsOutboundGateway.setMessageConverter(MessageConverter)
method.
MessageHandler throws an Exception.
FileNameGenerator strategy to use when generating
the destination file's name.
FileListFilter.
NotificationFilter to be passed to the server
when registering this listener.
HeaderMapper to use when mapping between HTTP headers and MessageHeaders.
JmsHeaderMapper implementation to use when
converting between JMS Messages and Spring Integration Messages.
JmsHeaderMapper implementation for mapping the
Spring Integration Message Headers to/from JMS Message properties.
HttpMethod that will be used when executing requests.
HttpMethod for requests.
Session will be created with these properties (and the JavaMailAuthenticator if provided).
JdbcOperations to use when interacting with the database.
LoadBalancingStrategy for this dispatcher.
LobHandler that is used to create and unpack large objects in SQL queries.
AbstractMailReceiver.receive().
MessageConverter strategy to use for converting
between Spring Integration Messages and JMS Messages.
MessageConverter implementation to use when
converting between JMS Messages and Spring Integration Messages.
MessageConverter strategy to use for converting the
Spring Integration request Message into a JMS Message and for converting
the JMS reply Messages back into Spring Integration Messages.
HttpMessageConverters to be used by the underlying RestTemplate.
Presence
MessageStore that should be used to store Messages
while awaiting the delay.
MultipartFileReader to use when reading MultipartFile content.
MultipartResolver to use when checking requests.
NodeMapper to use for generating the result object.
ObjectName.
MessageChannel where Messages should be sent.
ParameterExtractor for creating URI parameters from the outbound message.
HttpRequestHandlingEndpointSupport.setExtractReplyPayload(boolean) is false).
ClientHttpRequestFactory for the underlying RestTemplate.
RecursiveLeafOnlyDirectoryScanner
Session.
FolderClosedException while waiting for messages.
null values, such as might be returned from an expression evaluation,
should be skipped.
ErrorMessage
should be extracted and thrown from a send-and-receive operation.
MessageRejectedException when its selector does not accept a
Message.
MulticastSocket time to live property.
WebBindingInitializer to be invoked prior
to the request binding process.
ExpressionSource that allows for
configuration of a single channel name, payload expression, and
array of header key=value expressions.MessageStore and group id.InboundMessageMapper and
OutboundMessageMapper strategy interfaces that maps directly to and
from the Message payload instance.MessageStore and MessageGroupStore.AbstractMessagingGateway that delegates to
an InboundMessageMapper and OutboundMessageMapper.MultipartFileReader implementation that does not maintain metadata from
the original MultipartFile instance.Socket
and socket reader thread hangs on receive for response; therefore no multiplexing
of incoming messages is supported.TcpNetSendingMessageHandler
then blocks on read of same socket.SocketReader to a Message and from
a Message to outgoing data forwarded to a SocketWriter.Source using a SourceFactory.Source possibly taking into account
the provided message payload instance.MessageSource to a MessageChannel.@Splitter.SqlParameterSource for use in update operations.HandlerMethodResolver that always returns the
same Method instance.SourceFactory implementation which supports creation of a
StringSource from either a Document or String payloadMessageSelector that tests if a provided value supports
payloads of type Document or String.XPathExpression.
MessageFormats.FORMAT_STX_ETX.
MessageHandler as a subscriber to this channel.
Socket and SocketChannel that
sends Message objects by converting the payload
and streaming it to the destination.TcpConnectionTcpConnection to a Message.TcpNetConnections.Socket.Socket.Socket.TcpNetConnections using
a ServerSocket.TcpNioConnections.SocketChannel.SocketChannel.SocketChannel.TcpNioConnections using
a ServerSocketChannel.ReleaseStrategy that releases all messages if any of the following is true:
The sequence is complete (if there is one).Message.
Message with payload Presence
URLName, where the
password has been protected.
Message.@Transformer.MessageSelector that accepts Messages that are
not yet expired.MessageDispatcher that will attempt to send a
Message to at most one of its handlers.MessageHandler implementation that maps a Message into
a UDP datagram packet and sends that to the specified host and port.Transformer that delegates to an OXM
Unmarshaller.MessageHandler from the subscribers of this channel.
MultipartFile implementation that represents an uploaded File.ChannelInterceptor that publishes a copy of the intercepted message
to a secondary target while still sending the original message to the main channel.MessageSelector.
MessageSelector.
Message instance with the provided payload.
Document instancesXMPPConnection object.Message objects
that handle XMPP events.OutboundMessageMapper.XmppConnectionFactory and then emit Messages when a particular event happens to the logged in users Roster.XPathExpression to split a
Document or String payload into a NodeList.XPathExpression.evaluateAsNodeList(Node) which returns zero or more
nodes in conjunction with an instance of NodeMapper to produce zero
or more channel names.XPathExpression.evaluateAsString(Node)
to extract a channel name.XPathTransformer that will create an XPath expression from the given String
to be evaluated against converted inbound Message payloads.
XPathTransformer that will evaluate the given XPathExpression
against converted inbound Message payloads.
Transformer
instance used for XSL transformation.Source, Document, or String.
|
Spring Integration | |||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||