Index

[SYMBOL][A][B][C][D][E][F][G][H][I][J][L][M][N][O][P][Q][R][S][T][U][V][W][X]

SYMBOL

--> operator
==> operator

A

ACID2nd3rd
ActiveMQ2nd
  dead letter queue
  TCP connectors
  VM protocol
ActiveMQ component2nd3rd
ActiveMQConnectionFactory
addInterceptStrategy method
addRoutes
aggregate
<aggregate> tag2nd
AggregationStrategy2nd
  example
  thread safe
  using
Aggregator EIP
  aggregated size
  aggregation strategy
  AggregationStrategy
  combining message2nd
  completion condition2nd
    Aggregated
    batch consumer completion
    conditions provided
    examples
    interval completion
    predicate completion, 2nd
    size completion
    timeout completion
    using multiple conditions
  completion size
  configuration
    additional option
    closeCorrelationKeyOn-Completion
    eagerCheckCompletion
    groupExchanges
    mandatory
  correlation expression
  correlation group
  correlation identifier2nd3rd
    invalid
  Exchange properties
  in Splitter EIP
  ordering
  persistence
    AggregationRepository, 2nd
    example
    file based repository
    HawtDB
    memory repository
    pluggable repository
    RecoverableAggregation-Repository
    setup HawtDB
  recovery2nd
    background task, 2nd
    commit
    dead letter channel
    HawtDBAggregation-Repository
    interval
    maximum redeliveries
    recover
    RecoverableAggregation-Repository
    redelivered
    rollback
    setup
    similar to JMS Broker
    transaction
    using error handler
  reject incoming message
  uses cases
akka
  actor
    actor API
    bang operator
    pattern match
    reply
  actor model
  ActorComponent
  akka-camel component
  asynchronous
  bangbang operator
  CamelContextManager
    sending message
  CamelService2nd
    customize
  CamelServiceManager2nd
  consume from Camel
  disable JMX
  endpointUri2nd
  forwarding message2nd
  immutable message
  message exchange
    pattern
  one-way messaging
  produce message
  ProducerTemplate
  receive2nd
  receiveAfterProduce2nd
  receiveBeforeProduce
  reply
  request-reply messaging
  route
    routing example
    sending message to actor
  software transactional
    memory
  some failure
  some message
  timeout
  with Spring
  XML response
alternative languages
annotation
  @Attachments
  @Autowired
  @Bean
  @BeanShell
  @Body2nd
  @Consume
  @DynamicRouter
  @EL
  @EndpointInject
  @Groovy
  @Handler
  @Header2nd
  @Headers
  @InOnly
  @InOut
  @JavaScript
  @MVEL
  @ONGL
  @OutHeaders
  @PHP
  @Produce
  @Properties
  @Property
  @Python
  @RoutingSlip
  @Ruby
  @Simple
  @XPath2nd
  @XQuery
Apache ActiveMQ2nd3rd
Apache Camel website
Apache CXF
  HTTP transport
  link to website
Apache Felix
Apache Karaf2nd
  adding Camel feature
  features
  install bundle
  installing
  listing installed bundles
  log file
  shutdown OSGi
    container
  starting
Apache Maven2nd
  archetype plugin
    archetypeArtifactId
    archetypeVersion
    create vs. generate goal
  archetypes
  artifactId
  central repository2nd
  configuring local Maven
    repository in Eclipse
  convention over
    configuration
  data directory
  dependency tree
  directories installed
  generating an OSGi
    bundle
  groupId
  local download cache
  managing projects
  Maven Eclipse plugin
  obtaining
  POM2nd
  pom.xml2nd
  quickstart archetype
  recommended reading
  src directory
  transitive dependencies
  using the m2eclipse plugin
Apache MINA
Apache OpenJPA
Apache ServiceMix2nd
  message bus
  scalability
Apache Tomcat2nd
  deploying Camel
  hot deployment2nd
  leverage servlet transport
  starting
  using CXFServlet
ApplicationContext2nd
ApplicationContextRegistry registry2nd
Archetypes
asynchronous
  messaging2nd3rd
Atomikos6
@Attachments
auditing
autocomplete
automating tasks
AutoStartup, disabling
@Autowired

B

BatchConsumer
@Bean
bean
  BeanProcessor2nd3rd
  method
    adapting to method signature
    AmbigiousMethodCall Exception
    BeanInvocation
    beanRef
    CamelBeanMethodName
    @Handler
    method selection algorithm
    MethodNotFoundException, 2nd, 3rd
    NoTypeConversionAvailable Exception
    selecting bean method
    selection example, 2nd
    understanding bean method selection
  method call expression
  parameter binding
    @Bean
    @Body, 2nd
    built-in types
    exception
    @Header, 2nd
    multiple parameters
    @NamespacePrefix
    single parameter
    table of annotations
    table of build in types
    table of language annotations
    using annotations
    using language annotations
    @XPath
    @XPath with namespace
  registry
    ApplicationContextRegistry
    JndiRegistry
    lookup
    lookup in OSGi service registry
    lookup in Spring
    lookupByType
    multiple registries
    OsgiServiceRegistry
    SimpleRegistry
    table of registries
    typesafe lookups
  Service Activator EIP
  Spring, @Autowired
  using
    bean in Java DSL
    <bean> in Spring XML
    beanRef
    from a Processor
Bean component2nd
<bean> tag
BeanInvocation
@BeanShell
BeanShell
bindy
  annotations
  BindyType.Csv
  @CsvRecord
  data types used
  @DataField
  specifying package name
  using CSV
  using FIX
  using fixed length
@Body2nd
browse
builder pattern

C

Camel
  alternative languages
  archetypes
    list of archetypes
    using camel-archetype-component
    using camel-archetype-java
  architecture
    CamelContext
    component
    consumer
    domain-specific language (DSL)
    endpoint
    high level
    modular and pluggable
    processor
    producer
    routes
    routing engine
  bridging routes together
  community2nd
  component library
  components, understanding
  configuration, easy
  ConsumerTemplate
  core, lightweight
  creating custom components
  creating routes in Java
  creating routes with Spring
  creating WAR from Camel application
  deploying Camel
  developing interceptors
  developing projects
  directories installed
  EIPs
  endpoint
  example
    first
    revisited
  hide Camel APIs
  hiding middleware
  higher-level abstractions
  Java DSL
    bean method
    choice method
    convertBodyTo method
    end method, 2nd
    endsWith predicate
    executorService method
    from method
    header method
    log method
    multicast method
    noStreamCaching method
    otherwise method
    recipientList method
    regex predicate
    stop method
    stopOnException method
    streamCaching method
    to method
    tokenize method
    using Camel Proxy from Java DSL
    wireTap method
    xpath method
  Maven dependencies
  message model
    exchange
    message
  obtaining
  OSGi ready
  payload-agnostic router
  POJO model
  predicates and expressions
    regular expression predicate
    xpath expression
  producer and consumer templates
  ProducerTemplate2nd
  protocol support
  reasons to use
  remoting and Camel
    proxy
  route startup order
  routing
  routing and mediation engine
  routing annotations2nd
    @Consume example
    dependencies
    injecting a proxy producer
    loading annotated classes into Camel
    @Produce example
    receiving messages with @Consume
    referencing a shared endpoint
    sending messages with @Produce
    specifying what Camel-Context to use
  routing engine
  routing with beans
  running
  Scala DSL
    --> operator
    ==> operator
    adding Scala routes to the CamelContext
    comparison with Java DSL
    EIPs support
    maven-scala-plugin
    Scala RouteBuilder
    using Java-based Camel-Context with routes
  shutting down
  Spring DSL
    adding a processor
    adding multiple routes
    advanced configuration options
    CamelBeanPostProcessor
    configuring components and endpoints
    consumerTemplate element
    custom camelContext element
    defining a reusable endpoint
    dynamic RouteBuilder loading
    example
    finding route builders
    importing configuration and routes
    importing route defined in another file
    naming a component
    packageScan element
    proxy element
    route id
    routeContext element
    routePolicyRef option
    routerBuilder element
    shutdownRoute option
    starting a Spring Camel-Context manually
    streamCache option
    template element
    when method
  starting2nd
  startup options
    scope
    TypeConverter
    using in Eclipse
    web console, 2nd
Camel community
  articles, blogs, podcasts
  IRC and JIRA
  mailing list and reference card
  website
.camel directory
Camel extensions, JUnit
Camel Extra project2nd
Camel registry
Camel Test Kit
camel-core module, components
CamelContext2nd3rd
  accessing via Processor
  createNewProducerTemplate method
  graceful shutdown
  namespace
  setStreamCaching method
  start method
  starting
  startRoute
  stopRoute
CamelContext id
<camelContext> tag
CamelContextFactoryBean
CamelInvocationHandler
CamelNamespaceHandler
Channel2nd3rd4th
code-first2nd
codec
commons-net
compensation
  rollback
  using synchronization
Component2nd
component
  ActiveMQ2nd
  activemq transaction
  actor
  asynchronous
    processing
    akka-camel
  Bean2nd
  bean, using OGNL
  custom component, @ManagedAttribute
  customize output log
  Direct2nd
  @EndpointInject
  fault
  File
  file
    concurrency
    simple language variables
  FTP
    simple language variables
  HawtDB2nd
  HTTP
  Jasypt
  Jetty2nd3rd4th
    continuations
  JMS
  log
  MINA2nd3rd
  Mock2nd
    unit testing
  Properties2nd
    properties file
    syntax
    using without Spring
  SEDA2nd3rd4th
  simulating
  smtp
  velocity
  XSLT
Component interface
component resolver
components
  ActiveMQ
  autodiscovering
    components
  bean
    example using InOut MEP
    how BeanComponent is resolved
  camel-core module
  creating a custom
    component
  CXF
    code-first development
    configuring using endpoint bean
    configuring using URI options
    contract-first development
    cxf-codegen-plugin in Maven
    dataFormat option
    dataformats
    document literal
    exposing a route as a web service, 2nd
    HTTP-based components
    invoking a web service
    Maven dependencies
    modes of development
    operationName header
    portName option
    producer and consumer terminology in web services
    Service Endpoint Interface
    serviceClass option
    serviceName option
    specifying operation to invoke
    transports
    using a WSDL
    using Apache Tomcat for HTTP inbound endpoints
    wsdl2java tool
    wsdl2service tool
    wsdl2xml tool
    wsdlURL option
  dataset
  Direct2nd
    how a consumer calls a producer
  File
    default filename
    delay option
    delete option
    exclude option
    fileName option
    include option
    locking files
    maxMessagesPerPoll option
    move option
    noop option, 2nd
    reading and writing files
    recursive option
    simple expression for filename
    writing files example
  File and FTP
    Components
  FTP
    binary option
    CamelFileName header
    consuming files
    default FTP port
    disconnect option
    example using embedded FTP server
    Maven dependency, 2nd, 3rd
    maximumReconnect-Attempts option
    password
    password option
    reconnectDelay option
    remote directory
    transitive dependencies
    URI options
    username
    username option
    using embedded FTP server for testing
  Hibernate
  HTTP2nd
  JBI
  JBoss
  JDBC
    example
    Maven dependency
    readSize option
    statement option
    URI options
    useJDBC4ColumnName AndLabelSemantics option
    using a bean to create the SQL statement
  Jetty
  JMS2nd3rd
    ActiveMQConnection-Factory
    autoStartup options
    clientId options
    concurrentConsumers options
    configure JMS provider
    connecting to ActiveMQ
    connecting to ActiveMQ: over TCP
    disableReplyTo options
    durableSubscriptionName options
    endpoint URI
    exchangePattern option
    how headers are handled
    how to empty a JMS queue
    JMSCorrelationID header
    JMSReplyTo header
    mapJmsMessage option
    Maven dependency, 2nd
    maxConcurrentConsumers options
    message mappings
    replyTo option, 2nd
    request/reply messaging
    requestTimeout options
    selector options
    sending and receiving messages
    sending messages with the ProducerTemplate
    TCP as transport
    timeToLive option
    transacted options
    URI options
    using a topic
    using multiple JMS providers
    valid JMS headers
  JPA
    connecting Camel JPA to OpenJPA
    consumeDelete option
    consumeLockEntity option
    consumer.delay option
    consumer.initialDelay option
    consumer.namedQuery option
    consumer.nativeQuery option
    consumer.query option
    @Entity
    example
    flushOnSend option
    manually querying the database
    Maven dependencies
    maximumResults option
    maxMessagesPerPoll option
    persistenceUnit option
    persistenceUnitName
    transactionManager option
    URI options
  LGPL/GPL components
  manually adding to the CamelContext
  message headers set
  MINA
    codec option
    CumulativeProtocol-Decoder
    custom codecs, 2nd
    encoding option
    example
    filters option
    Maven dependency
    object serialization codec
    setting up a TCP server
    sync option
    textline codec
    textline option
    textlineDelimiter option
    timeout option
    transferExchange option
    transport types
    URI options
  mock
  naming a component in Spring
  no component found error
  number of components
  overview
  Quartz
    cron option
    cron triggers
    job.name option
    job.propertyName option
    JobDetail
    Maven dependency
    SimpleTrigger
    Trigger
    trigger.propertyName option
    trigger.repeatCount option
    trigger.repeatInterval option
    URI options
  ref
  SEDA2nd3rd
    concurrentConsumers option
    multipleConsumers option
    pros and cons
    publish-subscribe
    size option
    timeout option
    URI options
    waitForTaskToComplete option
  Servlet2nd
  SQL
  stream
  timer
  VM2nd
Composed Message Processor EIP
concurrency
  akka
  asynchronous task
  CPU-bound
  eip
    aggregate
    multicast, 2nd
    recipient list
    split
    threads
    using
    wiretap, 2nd, 3rd
  Future
  IO-bound
  ordering
  parallel processing
  parallelProcessing
  performance
    improving
  splitter, parallelProcessing
  transaction limitation
concurrency client API
  asynchronous task
  Callable
  ExecutorService
  Future2nd
  future
    get
    get with timeout
    isDone
  in Camel
  in Java
  ProducerTemplate
    asyncCallback
    asyncCallbackRequestBody
    asyncCallbackSendBody
    asynchronous methods provided
    asyncRequestBody
    asyncSend
    asyncSendBody
  Runnable
  Synchronization
  SynchronizationAdapter
  timeout2nd
ConnectionFactory
@Consume
consumer2nd
  event-driven consumer
  polling consumer
  ScheduledPollConsumer
Consumers
ConsumerTemplate, list of methods
  receiveBodyNoWait
Content Enricher EIP
  enrich2nd
  pollEnrich2nd
Content-Based Router EIP2nd3rd
<context:property-placeholder> tag
contextConfigLocation
convention over configuration
correlation id2nd
<correlationExpression> tag
cron expressions
CSV2nd
  table of data types used
  transforming using bean
  transforming using Processor
custom component
  changing endpoint URI scheme
  Component and Endpoint classes
  data marshaling
  disabling producer or consumer creating
  extending from default implementations
  how endpoint URI properties work
  Producers and Consumers
  what makes up a component
CXFServlet

D

data format
  configuring
  CSV
    camel-csv
    configure
    consume CSV files
  DataFormat API
  JSON
    camel-jackson
    camel-xstream
  marshal2nd3rd
  table of data formats
  unmarshal2nd3rd
  using JAXB
  using XStream
  writing custom
    ReverseDataFormat
    using Camel type converters
data format transformation
data integration and data mapping
data mapping, definition
data transformation
  enrich
  in routes
  message transformation in component adapter
  using bean
  using components
  using data formats2nd
  using Freemarker
  using Processor
  using templating
  using the Content Enricher EIP
  using the Message Translator EIP
  using transform()
    from Java
    from Spring XML
  using Velocity
  using XStream
  XSL Transformations (XSLT)
data type transformation
  using type converter
database
  HSQLDB
  SQL
databases
Dead Letter Channel EIP2nd3rd
decouple middleware from business logic
DefaultComponent
DefaultConsumer
DefaultEndpoint
DefaultProducer
Delayer EIP
dependencies
deploying Camel
  in a Java application
    file copy example
    pros and cons
    using Main helper class to load Spring context
    using raw Spring
  in a web application
    in Apache Tomcat
    in Jetty
    overriding CamelContext filename
    pros and cons
    using Spring context listener
  in Apache Karaf
  in JBoss Application
    Server
    pros and cons
  in OSGi
    installing a bundle
    pros and cons
  standalone
deployment strategy
  Apache Tomcat
    pros and cons
  Java application
    pros and cons
  Java EE Application Server
  JBoss Application Server
    pros and cons
  Jetty
  OSGi
    pros and cons
  standalone
    pros and cons
  web application
    pros and cons
developing Camel projects
Direct component2nd
distribution, obtaining
doc directory
doCatch
doFinally
domain-specific language (DSL)2nd3rd
doTry
DSL
  which DSL to use?
Dynamic Router EIP2nd
@DynamicRouter

E

EAI
Eclipse2nd3rd
  configuring local Maven repository
  import wizard
  M2_REPO variable
  m2eclipse plugin
  Maven Eclipse plugin
  package explorer
  using Camel
Eclipse Equinox
EIP
  Aggregator
  command message
  Composed Message Processor2nd
  concurrent consumers2nd
  content enricher
  Content-Based Router2nd
  content-based router (CBR)
    example
    routing after a CBR
  Dead Letter Channel2nd3rd4th5th
  Delayer
  Dynamic Router2nd3rd
  @DynamicRouter
  Load Balancer2nd
  log
  message filter
  Message Translator
  multicast
    configuring the thread pool
    implement with a JMS topic
    parallel multicast
    parallelProcessing
    stopping on exception
  multicast, aggregate reply
  patterns supporting
    concurrency
  Recipient List
  recipient list
    comma-separated recipients
    example
    RecipientList annotation
  Routing Slip2nd
  @RoutingSlip
  Service Activator EIP2nd
  Splitter2nd3rd4th
    big file
    configuring thread pool
    file example
    low memory usage
    ordering
    parallelProcessing
    streaming mode
    thread pool
  threads
  Throttler
  Transactional Client
  wiretap2nd
    concurrency
@EL
EL
embedded FTP server
endpoint2nd
  BrowsableEndpoint
  @EndpointInject
  file2nd
  FTP
  HTTP2nd
  mock2nd
  SEDA2nd
  TCP2nd
  URI2nd3rd4th
  URL
<endpoint> tag
Endpoint URI
  context path2nd
  how options work
  options2nd
  scheme2nd
@EndpointInject
enrich
  Enrich
  vs. pollEnrich
enterprise integration patterns (EIPs)
  implemented as Processor
Enterprise Service Bus (ESB)
  Camel is not an ESB
@Entity
entity manager
error handler
  HandleFault
  Load Balancer EIP failover
  TransactionErrorHandler
error handlers
  DeadLetterChannel2nd
  DefaultErrorHandler2nd
  features
  LoggingErrorHandler2nd
  NoErrorHandler2nd
  scope
  TransactionErrorHandler2nd
error handling caught exception
  context scoped2nd
  continued
  dead letter channel
    dead letter endpoint
    dead letter queue
    useOriginalMessage
    using original message
  dead letter queue
  default error handler
    default settings
  detour
  detour message
  doTry...doCatch...doFinally
  error handlers provided
  errorHandler2nd
  errorHandlerRef
  exception
    caused exception
    context scope
    continued
    custom exception handling
    detour message
    exception hierarchy
    gap detection
    handle
    handled
    maximumRedeliveries
    multiple exception
    onException, 2nd
    onWhen
    redeliverDelay
    understanding catching
    understanding handle
    understanding redelivery
    using exception policies
    using processor
  failover
  failure endpoint
  fault
  getException
  handle fault
  ignoring exception
  lifecycle
  logging error handler
  no error handler
  onException2nd3rd
  original input message
  PollingConsumerPollStrategy
  redeliver
  redelivery
    asynchronous, 2nd
    backOffMultiplier
    custom processing
    exhausted, 2nd
    exponential backoff
    file rollback
    maximumRedeliveries
    onRedeliver
    recoverable errors
    redeliverDelay
    redelivered
    redelivery counter
    redelivery policy, 2nd
    redeliveryDelay
    redeliveryPolicy
    retryAttemptedLogLevel
    retryWhile
    synchronous
    table of redelivery options
    useExponentialBackOff
    using
  RedeliveryErrorHandler2nd
  route scoped
  scope2nd3rd
  setException2nd
  setFault
  table of error handlers
  transaction error handler
  try catch
  understanding
    irrecoverable
    recoverable
    redelivery
  where error handling applies
<errorHandler> tag2nd
errors, recoverable and irrecoverable2nd
event
  EventNotifier
  EventObject
  filtering event
  notification
  using custom
    EventNotifier
examples directory
exception policies
<exception> tag
ExceptionHandler
exchange
  exchange ID
  in message
  instance, working on via Processor
  MEP
  out message
  properties
exchange id
Exchange.CAUSED_EXCEPTION
expression
  compound
  custom
  evaluate
  ExpressionAdapter
  fluent builder, syntax sugar
  Message Translator EIP
    transform
  method call2nd3rd4th
  syntax sugar
  using
    custom expression
    in Java DSL
    with Spring XML
  using scripting language as
expression builder methods
expression language
  dependency
  evaluate
  expression
  Simple2nd
external DSL

F

failed to resolve endpoint
failover
  Load Balancer EIP
  strategy
    custom
    priority based
    round robin
<failover> tag
File component
file endpoint2nd
file transfer
files
filesystem
filter
flow of messages in route
fluent interface
<from> tag
FTP2nd
FTPComponent2nd3rd
FTPEndpoint2nd
FTPS

G

generate an Eclipse project
GenericFile
graceful shutdown
  example
@Groovy
Groovy2nd

H

HandleFault
@Handler
HawtDB
  persistence aggregator
  setup
  transaction
HawtDB component2nd
@Header2nd
@Headers
hello world
Hibernate
hiding middleware2nd
high availability
Hohpe, Gregor
HTTP2nd3rd
  HttpOperationFailed-Exception
  ping service
HTTP endpoint2nd
HyperSQL

I

IDEs
importing Camel project into Eclipse
importing generated Eclipse project
in-flight messages
in-flight registry
in-memory messaging
@InOnly
InOnly MEP2nd
@InOut
InOut MEP2nd3rd
inspecting messages
integration testing
interceptors2nd
  adding an interceptor to the CamelContext
  addInterceptStrategy method
  applying more than one interceptor
  delay
  example
  excluding a Processor from interception
  how interceptors modify a route
  intercept
  intercept multiple endpoints
  InterceptFromEndpoint
  InterceptStrategy interface
  wrapping Processors in interceptors
  wrapProcessorInInterceptors method
InterceptStrategy
internal DSL
Inversion of Control (IoC)

J

Jasypt component
Java
Java API for XML Web Services.
    See JAX-WS.
Java DSL2nd
Java EE container
Java Management Extensions.
    See JMX.
Java Message Service.
    See JMS.
Java Persistence Architecture.
    See JPA.
Java Transaction API (JTA)
Java Web Start
java.util.Timer
@JavaScript
JavaScript
javax.jms.Message
javax.jws.WebService
javax.persistence.Entity
javax.sql.DataSource
JAX-WS2nd
jaxb
  annotated bean
  contextPath
  jaxb.index
  using annotations
  @XmlAccessorType
  @XmlAttribute
  @XmlRootElement
JBI
JBoss Application Server
  starting
JConsole2nd3rd4th5th6th
JDBC2nd
jdbc, data source
JdbcTemplate
Jetty
  continuations
  deploying Camel in
JMS2nd
  acknowledge mode, auto
  ActiveMQ, embedded
    broker
  browse queue
  BytesMessage
  consumer
  dead letter queue2nd
  how to empty a JMS
    queue
  JMS message
    implementations
  MapMessage
  ObjectMessage
  StreamMessage
  TextMessage
  transaction
JMS component2nd
JMS destination
JmsTemplate
JMX2nd
  DefaultManagementAgent
  exposed Camel MBeans
  JMX connector
  jmxAgent
  @ManagedResource
  ManagementAgent
  ManagementAware
  managing Camel
    application
  managing lifecycle
  managing Tracer
  MBean
  Spring JMX
  using JConsole
    remotely
  using JMX with Camel
JNDI
  JndiRegistry
  lookup in WebSphere
JndiRegistry2nd3rd
JPA2nd
JpaTransactionManager
jsch
json
  JSON
  marshaling beans
  selecting json library
JUnit
  extensions
JXPath

..................Content has been hidden....................

You can't read the all page of ebook, please click here login for view all page.
Reset