Fuse 6 is no longer supported
As of February 2025, Red Hat Fuse 6 is no longer supported. If you are using Fuse 6, please upgrade to Red Hat build of Apache Camel.5.3. Routing
Table 5.3, “Routing Issues Resolved in 6.2” lists the issues resolved in version 6.2.
Issue | Description |
---|---|
CAMEL-6185 | http4 component should always filter 'host' header |
CAMEL-6679 | Issue when using ZipSplitter and sending entries to a file endpoint |
CAMEL-6716 | ServiceInterfaceStrategy fails to create with interface containing multiple methods without parameters |
CAMEL-6774 | Karaf and servlet 2.5/3.0 due recent jetty upgrade causes karaf problems! |
CAMEL-6783 | getFeatures() method of CxfEndpoint only accept AbstractFeature but Feature |
CAMEL-6807 | Message headers with uppercase letters not matched by jxpath |
CAMEL-6833 | Atomic Number Producer Uses Wrong Name |
CAMEL-6843 | Hazelcast Map Support Uses Wrong Verb "Envict" |
CAMEL-6887 | We should support to set the ContentMetadata of the Payload object through message header |
CAMEL-6918 | Error handler for SEDA producer doesn't work |
CAMEL-6963 | Specify the import package version range for camel-lucene |
CAMEL-6988 | 2.12.1 caches groovy call - resulting with previous caller state |
CAMEL-7033 | camel-quartz2 - When clustering, triggers may be left in a paused and unrecoverable state |
CAMEL-7144 | Blueprint route not shutdown when using OSGi service processor |
CAMEL-7147 | NullPointerException when chaining CXF/Jackson REST services in a Camel route |
CAMEL-7168 | [bean-validation] Provide OSGi-friendly ValidationProviderResolver |
CAMEL-7173 | Default value on jmxAgent createConnector should be 'false' |
CAMEL-7212 | Bean Validator should use OSGi-friendly ValidationProviderResolver if deployed into OSGi environment |
CAMEL-7224 | camel-smpp - fails to correctly send messages that require UCS-2 encoding |
CAMEL-7229 | [cxfrs] Producer override bean bus |
CAMEL-7239 | Address the SchemaFactory thread safe issue. |
CAMEL-7240 | ThreadsProcessor should resolve RejectedPolicy from the referenced ThreadPoolProfile |
CAMEL-7241 | ByteBuffer to String conversion uses buffer capacity not limit |
CAMEL-7244 | PGPDataFormat: verification with subkey restricted by User ID does not work |
CAMEL-7251 | SqlProducer call twice the getResultSet on the PreparedStatement => This cause issue with HSQLDB (NPE) |
CAMEL-7253 | PGPDataFormat: NullPointerException if decryptor gets body with invalid format |
CAMEL-7254 | MailComponent 'peek' doesn't work due to programming error |
CAMEL-7256 | NullPointerException at DefaultCxfRsBinding |
CAMEL-7258 | org.apache.camel.model.dataformat.XmlJsonDataFormat settings assignments are misplaced. |
CAMEL-7262 | IAE with calling String.replaceAll via simple expression in Karaf |
CAMEL-7269 | camel-jpa - joinTransaction called for RESOURCE_LOCAL datasource |
CAMEL-7271 | AbstractListGroupedExchangeAggregationStrategy produces failed exchange if first received exchange fails |
CAMEL-7274 | Support roles in the camel-shiro component |
CAMEL-7276 | camel-quartz - use of management name to provide default scheduler name breaks context isolation |
CAMEL-7277 | camel-ssh should close the session when execution is finished. |
CAMEL-7282 | onException should enable backoff if backOffMultiplier is in use - just as errorHandler does |
CAMEL-7286 | amazonSNSEndpoint option is ignored |
CAMEL-7287 | SJMS: Cannot connect to durable topic because "noLocal" is hardcoded to "true" |
CAMEL-7296 | camel-hbase component have some bugs on Consumer side |
CAMEL-7298 | Simple Language - Binary Expression Equality Fails |
CAMEL-7300 | HL7 converter should not perform validation |
CAMEL-7303 | Simple Language - Header access surrounded with quotes |
CAMEL-7304 | InterceptSendToEndpoint does not work where uri needs to be normalized |
CAMEL-7306 | Camel:Kafka NPE when trying to consume messages from kafka server |
CAMEL-7308 | Timer component : timer should use StartupListener to be initialized before first fire |
CAMEL-7311 | camel-mail - Should not fetch attachments if mapMailMessage=false |
CAMEL-7315 | SPI locator fails when using a charset such as UTF16 |
CAMEL-7317 | xml-specs-api feature in camel features.xml shouldn't have all bundles configured as dependency='true' |
CAMEL-7318 | Concurrency on HDFS Consumer not working efficiently |
CAMEL-7320 | PGP Data Format: EOFException: Unexpected end of ZIP input stream |
CAMEL-7321 | JcrConsumer freezes in some environments |
CAMEL-7323 | createRouteStatisticEndpointJson - Returns invalid json if no routes |
CAMEL-7324 | DynamicRouter sends in-message to next destination |
CAMEL-7336 | camel-cometd jetty jmx version is not suit with camel parent jetty version |
CAMEL-7337 | PGPDataFormat unmarshal doesn't close the stream correctly |
CAMEL-7341 | CXFRS: InInterceptor defined in Spring is ignored |
CAMEL-7344 | Some endpoints configured using beans may result in NPE under DEBUG mode |
CAMEL-7351 | NPE in CamelInternalProcessor |
CAMEL-7353 | Configuring an http4 endpoint with hostname starting with "http" leads to an URISyntaxException |
CAMEL-7356 | Password constant mapped to System Id Header parameter |
CAMEL-7357 | CXFRS does not check JAX-RS Exception mappers |
CAMEL-7359 | Simple Language - Additional after text after inbuilt function call is ignored |
CAMEL-7363 | camel headers are not preserverd in camel-ahc component |
CAMEL-7364 | JpaMessageIdRepository uses EntityManager non thread-safe |
CAMEL-7369 | camel-mongodb - The readPreference option doesn’t work |
CAMEL-7377 | mark openjpa as dependency in Camel JPA feature |
CAMEL-7379 | allChannels should not be static variable for the NettyProducer |
CAMEL-7383 | camel-script-* features should depend on scripting-api bundle |
CAMEL-7389 | camel-quartz component does not define osgi import version for quartz |
CAMEL-7405 | SQS endpoint - HttpRoute class not found at route startup |
CAMEL-7406 | Empty password in JCR Endpoint URI causes NPE |
CAMEL-7407 | FTP route considers files as in progress after error in poll |
CAMEL-7409 | Camel ZipIterator should not eat the IOException |
CAMEL-7411 | EventDrivenPollingConsumer can lose exchanges when the internal queue is full |
CAMEL-7415 | lazyLoad with CSV blows up on last line |
CAMEL-7418 | org.apache.camel.impl.JndiRegistry.findByTypeWithName |
CAMEL-7424 | StaxSource doesn't produce correct SAX events with default namespace |
CAMEL-7428 | Simple Language - Operators are not evaluated for setting body or headers |
CAMEL-7429 | Camel Properties Component concatenation issue |
CAMEL-7431 | Impossible to use an existing javax.mail.Session with DefaultJavaMailSender |
CAMEL-7432 | camel-mybatis - issues calling Oracle Stored procedure with multiple resultsets |
CAMEL-7446 | Fix Eclipse m2e lifecycle configuration problem for maven-scalate-plugin_2.11 |
CAMEL-7448 | throttle EIP - unchanged value |
CAMEL-7449 | Camel Subscribing to messages published by non-camel producers |
CAMEL-7450 | CsvDataFormat unable to setup header when useMaps="true" |
CAMEL-7451 | FTP consumer sometimes throws NullPointerException |
CAMEL-7452 | beanRef is caching instances - unwanted behavior |
CAMEL-7457 | [camel-cxf] cxfrs: SimpleConsumer does not honur Accept header |
CAMEL-7459 | parseQuery Drops Char When Last Parameter is RAW with value ending in ')' |
CAMEL-7471 | SOAP with attachments not mapped correctly from CXF to Camel for CXF_MESSAGE |
CAMEL-7476 | cxfrs throwExceptionOnFailure option not working |
CAMEL-7478 | Simple Language - Length of array properties is not correctly evaluated |
CAMEL-7479 | Test fails in non-English environments |
CAMEL-7482 | camel:route-stop does not clean up resources |
CAMEL-7483 | SmppConfiguration has wrong value setDataCoding |
CAMEL-7488 | PropertiesComponent gets initialized by util:constant |
CAMEL-7497 | Duplicate classes |
CAMEL-7500 | Concurrent modification of exchange during retry after netty TCP failure leads to futher processing of failed messages |
CAMEL-7502 | camel-elastichsearch - starts up an instance even though IP specified |
CAMEL-7503 | PAYLOAD Producer select first available operation if OPERATION_NAME don't specified |
CAMEL-7513 | Using JPA entities as the argument in Aggregator using POJO |
CAMEL-7518 | FileUtil.renameFile - should return true if file was renamed using copy/delete approach |
CAMEL-7524 | CxfProducer created from wsdl detected as provider |
CAMEL-7541 | RedisIdempotentRepository doesn't work out of box |
CAMEL-7544 | XML DSL with customId attribute cannot be read by Camel |
CAMEL-7557 | CxfRsProducer does not copy headers between Camel and CXF messages in a proxy mode |
CAMEL-7560 | camel-test - AdviceWith transacted does not work |
CAMEL-7562 | camel-test - AdviceWith in CBR may add twice |
CAMEL-7565 | SFTP using PollEnrich with "disconnect=true" and "delete=true" does NOT delete the file |
CAMEL-7568 | OnComplete does not work on transactioned route after rollback |
CAMEL-7570 | enrich doesn't send out ExchangeSendingEvent nor ExchangeSentEvent |
CAMEL-7571 | Potential NPE in rabbitmq producer if header has null value and DEBUG logging enabled |
CAMEL-7572 | Using custom id in CBR will output id duplicated when dumping route as XML using JMX |
CAMEL-7577 | camel-zipfile - ZipIterator should be closable |
CAMEL-7578 | camel-bindy - pattern attribute should not be ignored if locale is not set |
CAMEL-7582 | Python scripts with multiple statements return null |
CAMEL-7584 | XML-Aware Tokenizer failing with utf-8 multibyte characters |
CAMEL-7586 | NotCompliantMBeanException : Attribute MessageHistory has more than one getter |
CAMEL-7587 | MessageHistory stores passwords in plain text |
CAMEL-7595 | camel-jdbc - Overrides with old headers when used the 2nd time in a route |
CAMEL-7598 | Camel does not clear the jpa session after each processed message batch |
CAMEL-7600 | QueueLoadBalancer does not set callback |
CAMEL-7603 | camel-cxfrs need to store the security context information into the message header |
CAMEL-7611 | org.apache.camel.util.KeyValueHolder equals bug |
CAMEL-7617 | JavadocApiMethodGenerator has problems extracting method signatures from JavaDoc |
CAMEL-7622 | advice-with - No outputs found matching id when upgrading from 2.13 to 2.14 |
CAMEL-7627 | Quartz/Quartz2 in cluster mode doesn't apply changed trigger settings |
CAMEL-7630 | BlueprintPropertiesParser doesn't handle the Blueprint Encryption: EncryptionOperationNotPossibleException |
CAMEL-7636 | camel-jms - Reply manager during timeout must use a catch to ensure onEviction can return correclty |
CAMEL-7644 | Scala camel DSL creates numerous DefaultCamelContext instances |
CAMEL-7646 | Remove cyclic package dependency in xmlsecurity component |
CAMEL-7650 | camel-restlet - Return 405 if method not allowed instead of 404 |
CAMEL-7653 | camel-sql endpoint oracle failure |
CAMEL-7656 | Component api - error in camel-box component in assembly phase |
CAMEL-7659 | camel-atom filter always returns the last consumed entry from feed more than once |
CAMEL-7662 | MQTTProducerTest fails once enables it |
CAMEL-7665 | RabbitMq don't reject messages when consumer or endpoint fail. |
CAMEL-7666 | CamelContext.addService may fail with java.util.ConcurrentModificationException |
CAMEL-7673 | subscribeTopicName leaks out as a property and used as a destination for mqtt producer, causes infinite delivery |
CAMEL-7676 | advice with - CBR may be removed if advicing an output in a when |
CAMEL-7679 | [cxfrs] Second argument is null when consumer invoke the bean with two arguments |
CAMEL-7693 | PropertyPlaceholder fails when string contains three consecutive curly brackets |
CAMEL-7701 | Chaining cxfrs endpoints |
CAMEL-7706 | Camel JGroups does not disconnect shared JChannel correctly |
CAMEL-7707 | OnCompletion - Should route even if original exchange has route stop / exception handled |
CAMEL-7712 | camel-scala - Route id not set when using onException definition |
CAMEL-7715 | SjmsConsumer and SjmsProducer do not remove thread pool when stop |
CAMEL-7718 | Constants used in camel-infinispan component have restricted access |
CAMEL-7730 | URI option "command" is not working in camel-infinispan component |
CAMEL-7731 | DefaultBeanRowMapper broken |
CAMEL-7735 | ProducerTemplate - Sending manually created Exchange causes 2x sent event notification |
CAMEL-7739 | camel-mail poller onCompletion Folder is not Open |
CAMEL-7745 | Using @EndpointInject with ref does not enlist endpoint in JMX |
CAMEL-7751 | Trace interceptor use add instead of remove in removeTraceHandler |
CAMEL-7754 | Property Trigger.timerZone is declared as constant but not implemented |
CAMEL-7757 | camel-restlet 2.13.1 throwing EOFException on reading ZipInputStream |
CAMEL-7762 | Camel CxfPayload issue when using namespace with no prefix (xmlns:xmlns) |
CAMEL-7763 | NettyServerBootstrapConfiguration should provide default SSL settings |
CAMEL-7767 | Mock - Defining assertion on message doest work if using convertTo |
CAMEL-7768 | Handle fault - Should convert the payload to String using type converter |
CAMEL-7772 | Maven plugin camel-api-component-maven-plugin cannot read empty API name for components with single proxy class |
CAMEL-7784 | Camel : RSS - Ignores posts with identical published or updated date. |
CAMEL-7785 | setUnitOfWork in DefaultExchange throws NPE when called from Splitter.java |
CAMEL-7793 | camel-rabbitmq - Consumer should not ack if an exception was thrown |
CAMEL-7795 | Regression: MDC may lose values after when Async Routing Engine is used |
CAMEL-7798 | Exchange formatter configured on Log Component may lead to incoherent results |
CAMEL-7803 | DefaultJdbcPrepareStatementStrategy Iterator fails on null value inserts |
CAMEL-7805 | Camel Olingo2 doesn't set HTTP headers correctly |
CAMEL-7806 | Olingo2 component doesn't support entity container names for batch requests |
CAMEL-7821 | BridgePropertyPlaceholderConfigurer fails to use custom PropertiesParser |
CAMEL-7826 | Olingo2 component sets incorrect value for "id" element in create entry endpoint |
CAMEL-7829 | Olingo2 component should handle 200 OK responses from OData servers for PUT method |
CAMEL-7830 | RestLetHeaderFilterStrategy should filter the header of "Transfer-Encoding" |
CAMEL-7836 | ConcurrentModificationException when creating dynamic routes |
CAMEL-7839 | Xpath is not namespace aware in choice |
CAMEL-7842 | Avoid using InputStreamEntity for byte[] input |
CAMEL-7849 | Decrypting properties via Jasypt outside of <camelContext> |
CAMEL-7852 | camel-msv component cannot be resolved in OSGi |
CAMEL-7855 | If you suspend a JMS route that is stopped, calling resume on it does not work and reports no error |
CAMEL-7856 | camel-cxf producer HttpAPI should not send the message body when using DELETE method |
CAMEL-7866 | barcodeFormat is always QR CODE |
CAMEL-7867 | NullPointerException when using CXF endpoint to enrich |
CAMEL-7868 | wrong concatenation of parameters in JettyHttpComponent |
CAMEL-7870 | [camel-barcode] Writer/Reader hints should be re-optimized when setBarcodeFormat method called. |
CAMEL-7871 | [camel-barcode] failed to create AZTEC barcode |
CAMEL-7874 | json DataFormat: The prettyPrint option does not work as expected |
CAMEL-7876 | GroupIterator should respect the exchange's CHARSET_NAME property. |
CAMEL-7880 | Cannot use custom DataFormats in REST DSL |
CAMEL-7881 | camel-resetlet feature should include httpclient4 bundle |
CAMEL-7882 | camel-syslog's CamelSyslogTimestamp header is suddenly a GregorianCalendar |
CAMEL-7883 | XSD decoding bad guess in Validator |
CAMEL-7886 | Charset not correctly set from content-type |
CAMEL-7888 | HL7Decoder leaks memory |
CAMEL-7890 | XmlConverter.toSAXSourceFromStream does not set setNamespaceAware |
CAMEL-7892 | Unable to perform a restlet DELETE with no entity |
CAMEL-7894 | Encoder exception after sending a message with null body |
CAMEL-7896 | camel-netty-http producer should close the channel when the connection header is not keep alive |
CAMEL-7899 | camel-jetty should support to define multiple http method for the rest service |
CAMEL-7900 | hdfs2 - chunkSize not honored |
CAMEL-7909 | camel-netty-http consumer need to close the connection if the response connection header is close |
CAMEL-7910 | Netty {Client|Server}ChannelHandler need to pass the close and open event around |
CAMEL-7914 | MQTT Endpoint disconnects on failure. Does not reconnect |
CAMEL-7916 | OsgiServiceRegistry forces name property |
CAMEL-7917 | camel-jsch unit tests are failing |
CAMEL-7919 | Add tests for camel-jira component |
CAMEL-7922 | MQTT endpoint misses QoS > 0 messages due to startup timing issue |
CAMEL-7924 | java.lang.ClassNotFoundException: org.codehaus.groovy.runtime.callsite.CallSiteArray |
CAMEL-7931 | JCR need to support multi-valued property |
CAMEL-7935 | JcloudsPayloadConverter.toPayload(InputStream) cannot deal with FileInputStreamCache |
CAMEL-7953 | Hazelcast seda documentation is misleading about pollInterval |
CAMEL-7964 | camel-jetty should support Post Redirect Get WebDesign pattern |
CAMEL-7966 | Doesn't set the blank or empty string to the mail recipients |
CAMEL-7967 | camel-rabbitmq logging exceptions as debug |
CAMEL-7968 | Container has undefined concurrency behaviour |
CAMEL-7971 | Setting bean reference in <restConfiguration> fails with IllegalFormatWidthException |
CAMEL-7973 | CircuitBreakerLoadBalancer fails on async processors |
CAMEL-7977 | sftp compression option is not set rightly |
CAMEL-7978 | QuartzEndpoint should share the same camel context name when it working in cluster mode |
CAMEL-7981 | JMX - Routes with transacted does not enlist processor mbeans |
CAMEL-7983 | Using named query parameters doesn't work |
CAMEL-7986 | Route disappears with routeId set to "route1" |
CAMEL-7988 | file consumer - Should call abort in case read lock cannot be acquired if exception was thrown |
CAMEL-7989 | FileIdempotentRepository should create the file store on startup |
CAMEL-7990 | IdempotentConsumer - If no messageId should allow Camel error handler to react |
CAMEL-7992 | Container lifecycle event method invoked outside of extension observer method invocation |
CAMEL-7994 | SJMSComponent effectively ignores setConnectionCount() |
CAMEL-7996 | OID of created object should be stored in the message header |
CAMEL-8001 | SmppUtils.isGsm0338Encodeable() called with arbitrary data |
CAMEL-8005 | Simple language produces null for a method call on a header value |
CAMEL-8008 | SubmitMulti and DataSm not checking CamelSmppAlphabet header |
CAMEL-8011 | MyBatis consumer ignores maxMessagesPerPoll option |
CAMEL-8030 | camel-netty need to release the thread pool when shutdown |
CAMEL-8031 | camel-netty maximumPoolSize option is ignored |
CAMEL-8032 | FileUtil leaks FileInputStream when renameFile fails due to permission issue |
CAMEL-8033 | Exchange Leak Caused By pollEnrich |
CAMEL-8035 | CXFRS consumer should set Exchange's charset name, if content type provides one |
CAMEL-8036 | JettyComponent should not setup the security handler more than once |
CAMEL-8045 | Not possible to load a public key from a a PrivateKeyEntry in a keystore |
CAMEL-8049 | DefaultRestletBinding can not deal with multi-valued HTTP request parameters |
CAMEL-8051 | feature camel-core does not install in karaf 4 |
CAMEL-8053 | Memory leak when adding/removing a lot of routes |
CAMEL-8062 | camel-rx - EndpointSubscriber does not call unsubscribe to stop the consumer |
CAMEL-8063 | Persistent tail tracking picks random tail tracker from mongoDB collection |
CAMEL-8065 | Camel won't build on windows (camel-box and camel-api-component-maven-plugin) |
CAMEL-8073 | Camel may clear attachments during routing |
CAMEL-8077 | NullPointerException in getRouteDefinition before context is started |
CAMEL-8081 | Multicast Aggregator should keep processing other exchange which is not timeout |
CAMEL-8082 | CxfRs producer should close the connection if MEP is InOnly |
CAMEL-8086 | Possible memoryleak when convertBodyTo is used in a dynamicRouter |
CAMEL-8087 | missing dependency for "camel-example-restlet-jdbc" example |
CAMEL-8088 | FTP can wait indefinitely when connection timeout occurs during connect |
CAMEL-8092 | cxf:producer Matrix Params are missing |
CAMEL-8094 | camel-netty: Do not use org.jboss.netty.util.internal.ExecutorUtil as it breaks the camel-netty Karaf feature |
CAMEL-8096 | CxfEndpoint schema should support to publishEndpointUrl from the element attribute |
CAMEL-8097 | Error in AST/Graph translation |
CAMEL-8100 | Collection should be optional for getDbStats |
CAMEL-8106 | XML parsing error is ignored by xtoknize XML tokenizer |
CAMEL-8118 | BigDecimalPatternFormat overwrites Locale setting |
CAMEL-8121 | Infinite Loop Within Camel if the temp file directory is not writable |
CAMEL-8123 | Mina2 SSL initiates handshake backwards |
CAMEL-8125 | PropertyInject gives NullPointerException |
CAMEL-8134 | We should not add synchronisation if the CachedOutputStream closedOnCompletion option is false |
CAMEL-8137 | Simple language does not resolve overloaded method calls |
CAMEL-8146 | Starting and stopping routes leak threads |
CAMEL-8148 | Avoid possible NPE in Camel Box component on exceptions during initial login |
CAMEL-8153 | Fix potential connection leak in StreamList mode |
CAMEL-8156 | SNSClient should setup endpoint before creating the topic |
CAMEL-8157 | camel-http - NPE after recent changes |
CAMEL-8158 | Provide way to specify fields to patch in google drive endpoints |
CAMEL-8160 | Generic methods used as endpoints fail in Java 8 |
CAMEL-8168 | Mina Does Not Unbind From Listening Port |
CAMEL-8169 | Camel Jetty/Http4 producers should respect Content-Length/Transfer-Encoding:Chunked headers |
CAMEL-8185 | camel-scr - IllegalArgumentException: argument type mismatch |
CAMEL-8189 | camel-scr-archetype produces invalid package structure |
CAMEL-8190 | Kafka producer: partition key is optional, not required by kafka client api |
CAMEL-8193 | Frequent BlockingOperationExceptions under load |
CAMEL-8194 | Elasticsearch component fails in an OSGi environment due to missing names.txt |
CAMEL-8200 | Race condition in JmsProducer for request/response messaging causing nondeterministic setting body to null. |
CAMEL-8201 | NPE with language:ruby and concurrentConsumers |
CAMEL-8213 | UseOriginalAggregationStrategy is suspicious to NullPointerException |
CAMEL-8214 | Support partial responses in google APIs |
CAMEL-8216 | Unable to specify startHistoryId for history list in camel-google-mail |
CAMEL-8217 | camel-xmljson option typeHints does not work |
CAMEL-8218 | REST DSL with RestletComponent doesn't support servelet container |
CAMEL-8222 | Jetty component setting responseHeaderSize is impossible |
CAMEL-8226 | Deprecated feature dataSourceRef not working correctly |
CAMEL-8227 | Using exchangePattern=InOnly in to uris are not used |
CAMEL-8228 | camel-mqtt - From mqtt to mqtt fails sending to specified publishTopicName |
CAMEL-8231 | StompEndPoint does not throw exceptions in case of the underlying connection broken at the time of sending a message |
CAMEL-8233 | Splitter - Option parallelAggregate is not in use when using parallel procession as well |
CAMEL-8236 | WebSphere class loader detection is too sensitive |
CAMEL-8241 | Exec command failures using Java 8 on Unix |
CAMEL-8245 | CXFRS endpoint ignores model references |
CAMEL-8247 | [AWS-S3] Producer does not use ObjectMetaData when exchange is a File |
CAMEL-8253 | CXFRS Throws IndexOutOfBoundsException for Empty Headers |
CAMEL-8261 | spring-dm may not be able to load resources from classpath from camel-core |
CAMEL-8268 | camel-hbase - The scan method is not thread safe when using a filter list |
CAMEL-8272 | Camel-box socks proxy implementation is incomplete |
CAMEL-8289 | camel-netty-http should not try to send out error message to the client if the connection is closed. |
CAMEL-8295 | Change Camel Context Name on Camel Spring Boot |
CAMEL-8296 | camel-box - OSGi troubles - NoClassDefFoundError: org.apache.commons.lang.NotImplementedException |
CAMEL-8303 | InvalidPayloadException when storing a String using camel-couchdb |
CAMEL-8313 | AddNamespace should not override the element's namespace |
CAMEL-8314 | Cannot select text() using xquery |
CAMEL-8315 | set Component Option "responseHeaderSize",but no effect |
CAMEL-8326 | Project created from camel-blueprint-archetype does not work |
CAMEL-8327 | ContextTestSupport does not support weaveByType in test cases |
CAMEL-8329 | camel-sql - May not propagate headers for operations with no resultset |
CAMEL-8336 | XML Signature: XAdES: Wrong value for attribute "Qualifier" of element CommitmentTypeId |
CAMEL-8338 | ScriptBuilder relies on TCCL to discover engines |
CAMEL-8339 | Usage of camel-mail depends on TCCL |
CAMEL-8341 | Usage of camel-rss depends on TCCL |
CAMEL-8346 | JsonPathEngine skips file encoding |
CAMEL-8352 | NettyServerBossPoolBuilder build() method is package-protected |
CAMEL-8353 | FileLockExclusiveReadLockStrategy - Should defer closing channel till release lock |
CAMEL-8355 | Dynamicity flag on Mongodb endpoint run a dropIndex() command on specified collection |
CAMEL-8356 | IOConverter.toInputStream(file, charset) returns strange behaving stream |
CAMEL-8358 | Avoid using Olingo2 library classes from 'core' package as it has been designated internal and not part of the API exposed using OSGi headers |
CAMEL-8359 | LinkedIn consumer endpoints have to specify an empty 'fields' parameter |
CAMEL-8369 | weaveAddLast does not work property when route ends with a split |
CAMEL-8382 | dumpRoutesAsXml should resolve "from" endpoint property values as with "to" endpoint URI |
CAMEL-8395 | Handle empty Salesforce picklist types |
CAMEL-8401 | CamelOverruleFileName does not work correctly for remote file endpoints |
CAMEL-8409 | Kafka producer: when no message key specified, use partition key |
CAMEL-8411 | camel-netty-http - Checking for host header is invalid |
CAMEL-8417 | RAW_TOKEN_START and RAW_TOKEN_END not removed when query parameter occurs multiple times |
CAMEL-8424 | Transaction being propagated ignoring REQUIRES_NEW when using direct component |
CAMEL-8425 | Handle invalid client id gracefully in Camel LinkedIn component |
CAMEL-8426 | Handle invalid client id gracefully in Camel Box component |
CAMEL-8427 | camel-scala - Testing with useOverridePropertiesWithPropertiesComponent issue |
CAMEL-8430 | Camel HDFS2 - readSuffix option does not work |
CAMEL-8431 | Consume all files in aws S3 bucket where deleteAfterRead = false |
CAMEL-8432 | camel-mqtt: MQTT wildcard ('+') subscription broken |
CAMEL-8434 | Camel HDFS2 - Unable to consume an empty file |
CAMEL-8436 | camel-spring-boot - Some routes not being initialized after CamelContext have been removed from CamelAutoConfiguration |
CAMEL-8437 | Simple bean call doesn't like parenthesis in parameter values |
CAMEL-8445 | camel-hdfs2 - Does not work on windows |
CAMEL-8450 | Netty component should not stop/null static timer when stopping |
CAMEL-8453 | camel-avro throws SAXParseException when used from spring or blueprint |
CAMEL-8455 | camel-linkedin - update_key option should be optional in getHistoricalStatusUpdateStatistics |
CAMEL-8456 | Remove addCompanyUpdateComment endpoint from camel-linkedin |
CAMEL-8457 | Correct return types of some endpoints in camel-linkedin |
CAMEL-8458 | camel-linkedin - public_profile_url option should be String |
CAMEL-8461 | camel-netty-http does not respect client's keep-alive setting |
CAMEL-8462 | HttpServerChannelHandler should not store the instance of HttpRequest |
CAMEL-8464 | Remove likeCompanyUpdate endpoint from camel-linkedin |
CAMEL-8466 | Feature camel-linkedin is missing dependencies for xalan, xerces and xmlresolver |
CAMEL-8469 | Several enum types should generate lower case values in camel-linkedin |
CAMEL-8470 | Several small fixes for camel-linkedin |
CAMEL-8476 | Unexpected behavior in fault handling with doTry/doCatch |
CAMEL-8479 | TrapReceiveTest is failed within Camel 2.15.0 |
CAMEL-8480 | camel-catalog has unnecessary imports if it cannot access some other artifacts |
CAMEL-8484 | File language - Should support file extensions with multiple dots such as tar.gz |
CAMEL-8492 | BeanInfo introspection ignores overriden methods |
CAMEL-8498 | CamelContextFactoryBean missing setEndpoints method |
CAMEL-8500 | ClassCastException when something other than PropertiesComponent is bound to "properties" JNDI name |
CAMEL-8504 | Failed to process Schematron XSLT templates and/or rules on windows |
CAMEL-8505 | Missed CamelSchematronValidationStatus header |
CAMEL-8510 | NPE will be thrown from doAppend() of PaxLoggingConsumer during load testing |
CAMEL-8515 | Camel marshal/unmarshal - Should catch throwable in case dataformat causes an java.lang.Error |
CAMEL-8519 | Salesforce component security listener does not replace old auth header |
CAMEL-8520 | Camel XMPP doesn't use a DNS resolver to look at SRV records |
CAMEL-8521 | camel-script - Should try all classloaders before throwing IAE |
CAMEL-8530 | can't install camel-github feature in karaf |
CAMEL-8540 | S3Consumer uses maxMessagesPerPoll incorrectly |
CAMEL-8546 | No LanguageResolver found for language=js |
CAMEL-8547 | Usage of camel-xmlbeans depends on TCCL |
CAMEL-8556 | AnnotationTypeConverterLoader treats package as class |
CAMEL-8566 | Feature camel-cxf doesn't install all required dependencies |
CAMEL-8568 | Feature camel-swagger doesn't install all required dependencies |
CAMEL-8573 | Feature camel-hbase doesn't install all required dependencies |
CAMEL-8574 | Feature camel-hdfs doesn't install all required dependencies |
CAMEL-8575 | Salesforce component doesn't properly retries the request when doing re-login |
CAMEL-8584 | Circuit breaker does not honour halfOpenAfter period |
CAMEL-8585 | The lazy load option doesn't unlock the file |
CAMEL-8589 | url.getPort returning -1, needs additional check |
CAMEL-8592 | NPE in AbstractListAggregationStrategy if empty list |
CAMEL-8597 | Elasticsearch component ignores indexType header set from endpoint URL |
CAMEL-8607 | Camel endpoint RAW password unsafe characters |
CAMEL-8609 | Remove open-jpa bundle from camel-jpa feature |
CAMEL-8624 | Bean component - Potential NPE in BeanInfo |
CAMEL-8626 | Leaking exchangesInFlightKeys in ManagedRoute |
CAMEL-8628 | camel-dozer component fails when multiple expressions are used in a mapping |
CAMEL-8636 | camel-kafka need to commit the last batch of messages when the auto commit is false |
CAMEL-8649 | Camel RAW() cannot handle String of %2050 |
CAMEL-8660 | camel-ftp - Disconnect when no messages dont call disconnect |
CAMEL-8672 | Restlet Rest Component properties are ignored |
CAMEL-8673 | ConcurrentModificationException when creating dynamic routes |
CAMEL-8674 | Camel-Netty4 does not set remote UDP address in headers |
CAMEL-8678 | Infinite recursion in TransactionErrorHandler toString method |
CAMEL-8682 | Context scoped OnException should not be stopped if a route is stopped |
CAMEL-8687 | SyslogConverter doesn't handle the structured data rightly |
CAMEL-8690 | Camel HDFS2 - ShutdownHookManager class not found when shutting down OSGi framework |
CAMEL-8694 | java.lang.NullPointerException in at org.apache.camel.component.netty4.http.NettyHttpProducer$NettyHttpProducerCallback.done |
CAMEL-8702 | when occurs "Connection reset by peer",netty4 client's EventLoopGroup select thread won't shut down |
CAMEL-8707 | camel-smpp: smpps doesn't work over proxy |
CAMEL-8713 | ParallelAggregate option when using parallel mode does not run in parallel |
CAMEL-8715 | camel-sql - Should close ResultSet |
CAMEL-8717 | camel-kafka feature miss kafka-clients bundle |
CAMEL-8718 | Connection leak with ftp consumer and invalid credentials |
CAMEL-8737 | camel-salesforce - Unable to generate DTOs for Filtered Lookup fields |
CAMEL-8746 | Jasypt with BridgePropertyPlaceholderConfigurer is not handling spring property injection with defaults anymore |
ENTESB-2460 | ParallelAggregate option for camel multicast with parallel processing is not working |
ENTESB-2786 | Make sure we we don't ship OpenJPA |
ENTESB-2891 | Backport CAMEL-8521 to JBoss Fuse 6.2 |
ENTESB-2938 | Repeated ERROR: Bundle org.apache.camel.camel-script [231] EventDispatcher: Error during dispatch. (java.lang.NullPointerException) java.lang.NullPointerException during Fuse startup |
ENTESB-3018 | Camel HDFS2 - Missing library "libsnappyjava.so" |
ENTESB-3019 | Camel HDFS2 - ShutdownHookManager class not found when shutting down Fuse |
ENTESB-3171 | Jasypt with BridgePropertyPlaceholderConfigurer is not handling spring property injection with defaults anymore |
ENTESB-3271 | Disable the camel-swagger feature |
HTTPCLIENT-1478 | [HTTPCLIENT-1478] https calls ignore http.socket.timeout during SSL Handshake |
HTTPCLIENT-1547 | [HTTPCLIENT-1547] HttpClient OSGi bundle doesn't import the package "javax.naming" |
SMX4-1709 | OSGi bundles for avro 1.7.5+ should not require "sun.misc" |
CAMEL-1077 | tcp client mode / server mode determined by "to" or "from" elements limits usability. |
CAMEL-3110 | Support GETNEXT and GETBULK for the Camel SNMP component. |
CAMEL-4015 | camel-hazelcast - Allow to specify operation in uri instead of just as a header |
CAMEL-5113 | Parallel and fault tolerant message processing for SQS endpoints. |
CAMEL-5286 | Add option to onCompletion to configure if it should be synchronous |
CAMEL-5398 | Optimize String.replaceAll() to cache Patterns where suitable |
CAMEL-5604 | camel-jackson - Make it easier to support List as output out of the box |
CAMEL-5790 | aws-s3 should support retrieving a single object request |
CAMEL-5806 | DefaultHttpBinding shouldn't assume null payload if HttpMethod == GET |
CAMEL-6028 | camel-hdfs - Support CamelFileName to write to a new file, when not using split strategy |
CAMEL-6065 | SJMS: inOut() in route and exchangePattern=InOut are not equivalent |
CAMEL-6099 | File producer - See if we can support chmod option like ftp producer |
CAMEL-6321 | Moving logic out of getTypeConverter |
CAMEL-6337 | camel-cdi dependencies are wrong for most cases |
CAMEL-6365 | After the Spring 3.1.x support has been dropped then better make use of IOHelper utility to close the Spring contexts in our code base. |
CAMEL-6458 | Add option renameUsingCopy option to file component |
CAMEL-6612 | upgrade camel-elasticsearch to 0.90.3 version |
CAMEL-6613 | upgrade camel-solr to use SolrJ 4.4.0 |
CAMEL-6698 | Component camel-cache to support non-serializable objects |
CAMEL-6701 | org.apache.camel.util.IOHelper.loadText(InputStream) doesnt not return text as written |
CAMEL-6744 | Aggregator - Using groupExchanges should store them on body by default |
CAMEL-6759 | camel-hazelcast component just allows Hazelcast maps and multimaps with key type String |
CAMEL-6775 | Aggregate - Potential little optimization to send aggregated exchange to completion outside the lock |
CAMEL-6777 | We are building two different source distributions which should not be the case |
CAMEL-6819 | Use exceptionHandler on Xmpp Consumer |
CAMEL-6820 | Improve SJMS handling of exchange body data types |
CAMEL-6826 | Use Mock Objects Instead of Live HazelcastInstances to Speed Up Testing |
CAMEL-6892 | Scala version upgrade |
CAMEL-6893 | [Scala] Migrate from Manifests to ClassTags |
CAMEL-6919 | FileIdempotentRepository doesn't create the whole directory structure |
CAMEL-6929 | Narrow ExcludeRoutes annotation values to RoutesBuilder instances |
CAMEL-6934 | Create new Address for every openConnection call |
CAMEL-6955 | Migrate camel-hl7 and camel-syslog from mina to netty |
CAMEL-7027 | Support to set the expression on the split DSL of Spring and Blueprint |
CAMEL-7030 | camel-quartz - Register quartz scheduler in JMX by default |
CAMEL-7038 | tooling - Provide an option for the JNDI properties file by the Guice Maven Plugin |
CAMEL-7039 | Upgrade to BouncyCastle 1.50 |
CAMEL-7050 | camel-jms drops messages when errorHandler throws an exception |
CAMEL-7051 | camel-bindy - Add timezone support to the date pattern |
CAMEL-7056 | Support streaming in camel-base64 data type |
CAMEL-7104 | Add support for "all" permissions for authorization in camel-shiro |
CAMEL-7121 | Relative dot segment paths not resolved in org.apache.camel.core.osgi.OsgiClassResolver |
CAMEL-7135 | Add page orientation property to camel-printer component |
CAMEL-7148 | Added the ability to send messages to several participants. |
CAMEL-7162 | [Bean Validator] Bean Validator should try to resolve ValidationProviderResolver reference |
CAMEL-7175 | Create FnAggregationStrategy wrapping Any result into Exchange |
CAMEL-7178 | Create JAX-RS MessageBodyWriter and Reader which will work with Camel data format |
CAMEL-7191 | Disable JMX load performance statistics - Avoids background thread |
CAMEL-7201 | PGPDataFormat: allow caching of PGP keys via key access interface |
CAMEL-7218 | Extract OSGi-detection logic into utility class |
CAMEL-7225 | camel-smpp - should check Exchange.CHARSET_NAME header |
CAMEL-7228 | Avoid setting port number 80 in http/http4 host header |
CAMEL-7231 | Support receiving attachments with Spring-WS |
CAMEL-7250 | In Threads DSL thread pool options and executorServiceRef should be mutually exclusive |
CAMEL-7257 | Add getRegistry(T) - To get the registry as type T |
CAMEL-7261 | Provide camel:context-suspend and camel:context-resume commands |
CAMEL-7265 | Add API to get JSON representation of route input and output endpoints |
CAMEL-7281 | Add support for "certAlias" in SSLContextParameters |
CAMEL-7283 | PGP Data Format: Signature Verification Options |
CAMEL-7284 | Missing setter for ApnsDelegate |
CAMEL-7285 | Upgrade Apache Jackrabbit Library for camel-jcr Component |
CAMEL-7309 | Tone down the excessive INFO logging about Woodstox xml parser not in use |
CAMEL-7312 | File -> Properties type converter |
CAMEL-7313 | camel-sql - Add support for fetching generated primary keys when using INSERT |
CAMEL-7326 | Improve Eclipse development with m2e Maven integration |
CAMEL-7327 | Improve Container.Instance API to deal with setting a Container after CamelContexts have been created. There is a big risk CamelContext's won't get managed right now |
CAMEL-7328 | A minor refactoring in camel-ahc so that it can be directly reused for websocket client |
CAMEL-7332 | camel-sql - Should have dynamic import so jdbc driver can be loaded |
CAMEL-7334 | Event notification for routes added/removed |
CAMEL-7335 | Kafka : Expose kafka configuration properties to the camel component |
CAMEL-7346 | Cleanup Maven Project Definitions |
CAMEL-7349 | JaxbDataFormat should not parse the Schema over and over again |
CAMEL-7358 | Tracer - Should have options to allow streams or files |
CAMEL-7360 | Add HTTP Date header |
CAMEL-7361 | would be nice if org.apache.camel.spring.Main could take a system property or CLI option to package scan classes too |
CAMEL-7370 | camel-mongodb - Should properly close the underlying physical connection to MongoDB while shutting down |
CAMEL-7372 | Allow users to pass in their own EntityManager through the exchange |
CAMEL-7373 | Reduce the logging noise from the log definition |
CAMEL-7382 | Enable retrieving auto generated keys in JDBC component when using named parameters |
CAMEL-7387 | MainSupport - Should not barf if no CamelContext found |
CAMEL-7388 | xmlTokenizer to optionally wrap the token with the enclosing elements |
CAMEL-7396 | Add defaultMethodName option to camel-xmlrpc |
CAMEL-7397 | support to deploy the camel-example-spring-javaconfig into Karaf |
CAMEL-7401 | Added continuationTimeout option to camel-cxf component |
CAMEL-7403 | Update camel-hl7 to support HAPI v2.2 |
CAMEL-7404 | Zip Aggregation Strategy preserves folder structure |
CAMEL-7421 | camel-rabbitmq - Channel is not fully thread safe |
CAMEL-7422 | camel-rabbit - Consumer tuning: thread count, prefetch |
CAMEL-7430 | Support property setting in BeanIODataFormat |
CAMEL-7435 | Create a generic callback to configure the APNS service builder |
CAMEL-7436 | Copy CXF Http header into Camel message header |
CAMEL-7442 | Upgrade Apache Jackrabbit to Version 2.8.0 |
CAMEL-7453 | Add schema attribut to the SoapJaxbDataFormat |
CAMEL-7465 | DefaultHeaderFIlterStrategy should be case insensitive. |
CAMEL-7466 | Allow to configure flatpack from its unmarshall tag |
CAMEL-7468 | Make xmlTokenizer more xml-aware so that it can handle more flexible structures |
CAMEL-7473 | MQTT consumer - Add topic destination name as header |
CAMEL-7474 | Error blocks mail-consumer |
CAMEL-7486 | Expose the component options for Camel MyBatis |
CAMEL-7487 | Create an archetype and code generation plugins to generate Camel Components that wrap a third party API |
CAMEL-7490 | Redelivery delay cannot be modified in asynchronous mode for multiple retries with different redelivery intervals for each retry specified in Exchange.REDELIVERY_DELAY header parameter. |
CAMEL-7493 | Expose the component options for Camel JDBC |
CAMEL-7494 | parameter json schema should support enum types |
CAMEL-7495 | parameter json schema should support object types |
CAMEL-7496 | BridgePropertyPlaceholderConfigurer should take ignoreResourceNotFound into consideration when it loads the property files |
CAMEL-7498 | Expose the component options for Camel SQL |
CAMEL-7499 | Expose the component options for Camel Mail |
CAMEL-7504 | Improve the throttler to have discarding/filtering capabilities |
CAMEL-7507 | Expose the component options for Camel JPA |
CAMEL-7508 | Expose the component options for Camel Infinispan |
CAMEL-7509 | Expose the component options for Camel JGroups |
CAMEL-7510 | Expose the component options for Camel Quartz |
CAMEL-7511 | Expose the component options for Camel Quartz2 |
CAMEL-7512 | Expose the component options for Camel Netty |
CAMEL-7514 | Dozer should not initialize the same DozerBeanMapperConfiguration twice |
CAMEL-7515 | Expose the component options for Camel Netty HTTP |
CAMEL-7516 | Expose the component options for Camel HDFS |
CAMEL-7517 | Expose the component options for Camel HDFS2 |
CAMEL-7521 | Provide an option for unsynchronized aggregation when splitter is streaming and not parallel |
CAMEL-7523 | Expose the component options for Camel CXF |
CAMEL-7525 | Behavior change for file component in 2.10 causes problems with no workaround available |
CAMEL-7527 | Zip component does not unpack files from directories into zip archive |
CAMEL-7529 | Update HeaderFilterStrategyComponent to extend UriEndpointComponent |
CAMEL-7530 | Expose the component options for Camel CXFRS |
CAMEL-7532 | VelocityEndpoint should support take the VelocityContext from message header |
CAMEL-7533 | Expose the component options for Camel HTTP |
CAMEL-7534 | Expose the component options for Camel HTTP4 |
CAMEL-7535 | Expose the component options for Camel Jetty |
CAMEL-7537 | Expose the component options for Camel OptaPlanner |
CAMEL-7538 | FreemarkerEndpoint should support to set data model from message header |
CAMEL-7539 | StringTemplateEndpoint should support set variable map from message header |
CAMEL-7540 | Quartz Endpoint with a SimpleTrigger does not support referencing a bean in URI |
CAMEL-7542 | Expose component options for Camel JCR |
CAMEL-7548 | Spring XML: Support {{ }} placeholder syntax inside pgp data format |
CAMEL-7549 | Quartz2 Endpoint with a SimpleTrigger doesn't support referencing a bean in URI |
CAMEL-7552 | RabbitMQ Component: property to allow declare or not queue and exchange. |
CAMEL-7563 | Allow passing HazelcastInstance as a query parameter of a Hazelcast component endpoint. |
CAMEL-7567 | Add camelId and managementName attributes to JMX tracer mbeans |
CAMEL-7569 | Expose the component options for Camel GAE |
CAMEL-7574 | Expose the component options for Camel Atmosphere Websocket |
CAMEL-7575 | BeanInvokeProcess should copy the attchment from the resultExchange |
CAMEL-7576 | camel-cache - Turn off ET phone home |
CAMEL-7581 | Enrich and pollEnrich should call aggregate even if exception occurred |
CAMEL-7583 | Make NettyWorkerPoolBuilder#build public |
CAMEL-7589 | Missing 'null' check in methods sendBodyAndHeaders() of class DefaultProducerTemplate |
CAMEL-7592 | Support setMode in XStreamDataFormat |
CAMEL-7594 | TypeConverter - Should support CamelLogDebugBodyMaxChars to limit logging message body |
CAMEL-7597 | Throw an more meaningful exception for camel-rabbitmq |
CAMEL-7599 | LogEndpoint ignores setter (setGroupSize) - set via uri working |
CAMEL-7602 | AWS SQS component does not support Message Attributes |
CAMEL-7604 | camel-core - Enlist Camel producers in JMX on startup |
CAMEL-7606 | Expose the component options for Camel Zookeeper |
CAMEL-7624 | camel-jackson - Add option to set inclusion to skip null fields from pojos |
CAMEL-7626 | camel-restlet - Should set content-type header |
CAMEL-7629 | camel-jackson - Add support for header to define the unmarshalType dynamic |
CAMEL-7631 | Enhancement for xmlsecurity component (XML Signature): Configurable Signature Id |
CAMEL-7633 | camel-restlet - Add back support for async |
CAMEL-7637 | Avoid null throwable message in FailedToCreateRouteException |
CAMEL-7639 | camel-jackson - Add support for prettyPrint option |
CAMEL-7645 | camel-jdbc - outputClass should also be supported for List |
CAMEL-7647 | camel-blueprint - Add logic to detect consumer scheduler for quartz2/spring |
CAMEL-7648 | Using scheduler=blueprint does not work in OSGi |
CAMEL-7654 | AWS SQS Component Does Not Support Message Attribuets In The Producer |
CAMEL-7657 | different results of lookup methods in SpringRouteBuilder |
CAMEL-7663 | SFTP consumers cannot be triggered by Quartz2 scheduler with JDBC trigger persistence: NotSerializableException |
CAMEL-7667 | camel-jms - MessageListenerContainer should stop quicker when CamelContext is stopping |
CAMEL-7668 | @Consume may restart during a shutdown event |
CAMEL-7680 | Throw NPE when stopping if transport client is used |
CAMEL-7682 | bean DSL should support to set multiParameterArray option |
CAMEL-7686 | camel-jdbc - Fix this issue report about retriving generated keys |
CAMEL-7688 | XPathBuilder initDefaultXPathFactory implementation incorrect |
CAMEL-7691 | camel-serlvet - Potential NPE if no servlet name configured for osgi |
CAMEL-7695 | CamelContext - Allow to check if a service by its type has been added |
CAMEL-7700 | Limit the SQL component maxMessagesPerPoll option by using the jdbcTemplate.setMaxRows(size) method |
CAMEL-7711 | camel-servletlistener - Store created CamelContext on ServletContext attribute |
CAMEL-7713 | Set the Xerces SecurityManager for the DocumentBuilderFactory by default |
CAMEL-7716 | Migrate camel-csv component to Apache CSV 1.0 |
CAMEL-7717 | camel-jsch - Should throw UnsupportedOperationException when creating a consumer instead of causing a NPE |
CAMEL-7719 | Set the XMLReader for the SAXSource in XmlConverter |
CAMEL-7720 | Support to set the DocumentBuilderFactory from exchange property |
CAMEL-7721 | Support to setup the SaxParserFactory from the exchange property |
CAMEL-7723 | Support starting and stopping consumers and producers asynchronously |
CAMEL-7724 | camel-bindy - Add support for boolean data type formatter |
CAMEL-7725 | camel-scala - Startup order not available in Scala DSL |
CAMEL-7727 | Unify MessageProducerResources handling into SjmsProducer |
CAMEL-7728 | Setup the TCCL before create the instance from the BaseResolver |
CAMEL-7734 | Replace custom pool implementation by commons-pool |
CAMEL-7740 | Allow pool prefill configuration for SjmsProducer |
CAMEL-7742 | Support grouping separator for Camel Bindy (BigDecimal) |
CAMEL-7744 | xslt component - Allow to configure custom error listener |
CAMEL-7753 | xslt component - Store warning/errors etc as exchange properties so end users can get hold of those |
CAMEL-7759 | Using the TCCL as the default value of ApplicationContextClassLoader in DefaultCamelContext |
CAMEL-7761 | Setup the application context classloader of OSGiDefaultCamelContext |
CAMEL-7769 | Mock - Allow to invoke a method while specifying an assertion |
CAMEL-7771 | Improve the API Component Framework to support callback APIs |
CAMEL-7776 | updated dependency for camel-flatpack |
CAMEL-7780 | ManagedCamelContext - Add operation to check if you can send to an endpoint |
CAMEL-7787 | Multicast - Should defer UoW done until after the aggregate has been done |
CAMEL-7794 | Topics support in camel-hazelcast |
CAMEL-7796 | camel-cxfrs consumer: Allow setting a custom binding |
CAMEL-7801 | XMLTokenizer's wrapped mode to handle grouping without replicating the wrapper part |
CAMEL-7802 | XML Signature: parameter for output character encoding and parent node via XPath |
CAMEL-7804 | MessageHelper - dump message for logging should catch throwable |
CAMEL-7827 | When using CXFRS with simple HTTP api, variable replacement should be available |
CAMEL-7858 | Allow to disable Jaxb annotations in JacksonDataFormat |
CAMEL-7859 | Language component - Add support for binary content |
CAMEL-7860 | Add sendReply functionality in RabbitMQConsumer |
CAMEL-7863 | Tone down info logging pr. message |
CAMEL-7864 | The kafka component does not properly support zookeeper chroot configuration |
CAMEL-7878 | Swagger's base.path should be calculated rather than hardcoded |
CAMEL-7895 | Upgrade XML Security + BouncyCastle dependencies |
CAMEL-7902 | Add tests for camel-github component |
CAMEL-7908 | Add a DestinationCreationStrategy to the SJMS component |
CAMEL-7912 | Add Character support to ObjectHelper::loadSimpleType() |
CAMEL-7913 | ObjectConverter does not support String to java.lang.Character conversion (only char primitive) |
CAMEL-7915 | Share the HashedWheelTimer across the Camel NettyComponent |
CAMEL-7927 | Add support for Multi-Select picklists in Salesforce component |
CAMEL-7929 | OptimisticLockRetryPolicyTest fails from time to time |
CAMEL-7930 | org.apache.camel.itest.ftp.SpringFtpEndpointTest is failing |
CAMEL-7932 | Adding initial properties to PropertiesComponent |
CAMEL-7940 | Disable SSL security protocol by default |
CAMEL-7947 | Support to set SSLContext in the camel-restlet |
CAMEL-7948 | Add support for more/new encryption/signature algorithms |
CAMEL-7949 | JmsMessageHelper to support automatic conversion from ByteBuffer to BytesMessage |
CAMEL-7951 | No way to configure the ExchangeFormatter in RedeliveryErrorHandler (want to see the Exchange's properties by default) |
CAMEL-7958 | Java DSL - Should support nested choice in doTry .. doCatch |
CAMEL-7959 | Rest DSL - Add support for onException, interceptor and other cross functionality |
CAMEL-7961 | camel-scala - Auto startup not available in Scala DSL |
CAMEL-7962 | Pipeline factories names on netty4 component |
CAMEL-7965 | EndpointCache - Should keep endpoints from routes in the cache |
CAMEL-7975 | SJMS Endpoint does not reverse header encoding |
CAMEL-7980 | camel-ognl need to use the class resolver from camel context |
CAMEL-7984 | camel-sjms - Add support for jmsKeyFormatStrategy |
CAMEL-7991 | Add MultiPartUpload functionality to S3Producer |
CAMEL-8000 | Add global notion of CamelContextRegistry |
CAMEL-8006 | S3Producer should use File to upload directly. |
CAMEL-8012 | camel-stream's scanStream mode should read available lines before going into sleep (or delay) |
CAMEL-8014 | camel-metrics - Let route policy and metrics component reuse same metricsregistry |
CAMEL-8016 | MongoDB should use EmbedMongo in tests |
CAMEL-8028 | Validator component - Make it like the others |
CAMEL-8034 | xslt component - Make it like the others |
CAMEL-8037 | Type converters for enums should support case insensitve |
CAMEL-8039 | Implement halfOpen state in CircuitBreaker |
CAMEL-8043 | saxon component - Make it like the others |
CAMEL-8048 | Main overrides context's registry |
CAMEL-8064 | MockEndpointsAndSkip annotation does not resolve property placeholders |
CAMEL-8066 | Add swagger ui to the camel swagger rest example |
CAMEL-8068 | SplitAttachmentsExpression should set ID of splited attachment |
CAMEL-8070 | Supporting byte[] messages in camel-websocket |
CAMEL-8072 | Netty Http Server should close the channel once it return an error message |
CAMEL-8075 | Camel sftp should send a command to check if the connection is broken |
CAMEL-8076 | We should avoid checking the DupTriggerKey if the recoverableJob is true |
CAMEL-8078 | camel-restlet should support to decode the response entity which is represent resource |
CAMEL-8084 | PGP Data Format: file name parameter |
CAMEL-8085 | Add handling of offset in case of auto commit is disabled to prevent data loss |
CAMEL-8089 | Support paging and restricting results from google drive |
CAMEL-8091 | DefaultExchangeFormatter does not consider Exchange.LOG_DEBUG_BODY_MAX_CHARS |
CAMEL-8095 | CaseInsensitiveMap for Camel headers should preserve original key cases in keySet |
CAMEL-8098 | Route model using body expression should be representable in the xml model |
CAMEL-8099 | Add support for default values in Camel properties |
CAMEL-8101 | Add runCommand to MongoDB Camel component operations list |
CAMEL-8102 | Add support to ObjectHelper to create Iterable's |
CAMEL-8103 | Make CxfEndpoint Camel Context aware |
CAMEL-8105 | AWS-SQS - support for redrivePolicy inside SQSEndpoint |
CAMEL-8107 | Allow to use property placeholder with default values without having to setup the properties component |
CAMEL-8108 | Type converters should not check for null values |
CAMEL-8109 | Allow to plugin custom functions to property placeholder |
CAMEL-8113 | Look into optimize Camels type converter registry lookup |
CAMEL-8115 | Properties component - Include default functions to lookup from ENV / SYS etc |
CAMEL-8116 | Allow more control of message splitting policy |
CAMEL-8117 | set encoding on a per-message basis |
CAMEL-8120 | ChannelHandlerFactories.newDelimiterBasedFrameDecoder always strips delimiters |
CAMEL-8124 | Using ServicePool in ConsumerCache |
CAMEL-8128 | Polish the camel-example-servlet-tomcat-no-spring to show how to setup the registry |
CAMEL-8129 | XAdES BES/EPES for XML Signature Signer |
CAMEL-8130 | camel-sql - Allow selectList outputType to map to class as well |
CAMEL-8133 | rest-dsl - Make it easy to support CORS |
CAMEL-8139 | rest-dsl - Allow to configure data format properties for IN vs OUT |
CAMEL-8145 | Mina Consumer doesn't send the message back if the response is set on in message |
CAMEL-8149 | Support application-generated document identifiers in bulk index requests |
CAMEL-8152 | Add enumeration value EXTENDED for NotifyOperationsEnum in Salesforce component |
CAMEL-8154 | allow configuration of fallbackTimeout in BacklogDebugger |
CAMEL-8155 | rest-dsl - Add support for bridgeErrorHandler |
CAMEL-8159 | Using setHeader is not enlisted in JMX |
CAMEL-8161 | camel-swagger - Use JMX to lookup Camel's so we support everyone |
CAMEL-8166 | provide access to suspended exchanges in BacklogDebugger |
CAMEL-8172 | Enable multiple consumers for kafka endpoint |
CAMEL-8173 | Support to set InflightRepository from Camel XML DSL |
CAMEL-8174 | Added TimeoutInflightRepository to track the long processing exchange |
CAMEL-8176 | camel-jackson - Make it easier to register custom modules |
CAMEL-8177 | Graceful shutdown - Should allow background thread to terminate |
CAMEL-8178 | ThreadPoolProfile - Add option for allowCorePoolTimeout |
CAMEL-8179 | Support to set the ErrorHandler from the JettyHttpComponent |
CAMEL-8180 | Incorrect handling of ConsumerTimeoutException |
CAMEL-8182 | xpath - Add documentType option to xml dsl |
CAMEL-8184 | [AWS-S3] Add support to set/retrieve custom headers in S3 for Producers & Consumers |
CAMEL-8188 | Support to configure the scripte engine from CamelContext propertes |
CAMEL-8191 | Charset is ignored for SFTP producer endpoints |
CAMEL-8202 | Excessive loggging: JSCH -> Permanently added 'X' (RSA) to the list of known hosts. |
CAMEL-8204 | Throw Exception if the JMS correlationId is not unique. |
CAMEL-8205 | CXFRS Server should be able to invoke on JAX-RS service implementations |
CAMEL-8209 | Added "inputHeader" parameter to use a header value as input to the component instead of the body |
CAMEL-8212 | CXFRS Consumer should always be able to work with interfaces only |
CAMEL-8225 | Graceful shutdown - Show inflight exchange details if forced shutdown triggered |
CAMEL-8234 | DefaultClassLoader - Should use applicationContextClassLoader from CamelContext as fallback |
CAMEL-8235 | MessageHistory - Should use CamelLogDebugBodyMaxChars to limit max length of message body |
CAMEL-8246 | ZipAggregationStrategy does not preserve headers |
CAMEL-8248 | Camel Mail should filter the "Camel*" out header by default |
CAMEL-8252 | Camel route status - Include inflight counter per processor node |
CAMEL-8256 | Include deadLetterUri in ExchangeFailureHandledEvent |
CAMEL-8259 | [Groovy] Add SPI hook to support customized creation of the GroovyShell |
CAMEL-8260 | Camel EIP model - Ensure consistent getter/setter style also for Boolean types |
CAMEL-8262 | Optimize CaseInsensitiveMap |
CAMEL-8263 | Add adapt(T) to CamelContext to use instead of type cast to ModelCamelContext |
CAMEL-8266 | [camel-sftp] Allow directories which are un-readable to be ignored on permission error |
CAMEL-8267 | Allow to configure Salesforce URL when creating DTOs via camel-salesforce-maven-plugin |
CAMEL-8279 | ZipAggregationStrategy fails when used in multicast |
CAMEL-8284 | MultiCast in Parallel Processing Mode with StreamCache leads to wrong results |
CAMEL-8288 | Attach Lucene Documents to the Results(Hits) if header contains RETURN_LUCENE_DOCS=true |
CAMEL-8298 | Remove the spring-test dependency from camel-spring-javaconfig |
CAMEL-8299 | Let BulkRequest return the whole BulkResponse |
CAMEL-8305 | Aggregate - Remove groupExchanges option as ppl should just configure to use GroupedExchangeAggregationStrategy |
CAMEL-8307 | Properties are loaded only from the first source if whitespaces are used in propertyPlaceholder#location |
CAMEL-8309 | Camel XML DSL - Allow to specify uri attributes in multi lines to make long urs easier to read and maintain |
CAMEL-8310 | RabbitMQConsumer has hard coded requeue flag set to false |
CAMEL-8312 | XML External Entity (XXE) issue in XPath |
CAMEL-8316 | Rename property language to exchangeProperty |
CAMEL-8321 | camel-box - Do not use dot in header keys |
CAMEL-8324 | Camel JMX - Allow to configure default management name pattern using JVM system property |
CAMEL-8330 | camel-jms - Use 1000 as default receiveTimeout |
CAMEL-8343 | Migrate the two pax osgi components to be like the others |
CAMEL-8345 | We should use Properties instead of Property to define the properties in restConfiguration |
CAMEL-8349 | Context should be started with defined TCCL |
CAMEL-8354 | Bean component - Should not support consumer |
CAMEL-8363 | Camel archetypes for xml dsl should not use camel: prefix |
CAMEL-8366 | Close used iterator if RuntimeException is thrown at next()/hasNext() in Splitter |
CAMEL-8367 | Better report runtime exceptions from the route builder while Unit Testing |
CAMEL-8371 | Update Camel Docker Component to support docker-java version 0.10.5 |
CAMEL-8372 | CXFRS consumer should use a default handler if a model resource has no registered handler |
CAMEL-8375 | activity task thread pool is not configurable |
CAMEL-8383 | CXFRS Consumer processors should be able to use JAX-RS contexts |
CAMEL-8386 | Wiretap - Should copy stream cache when tapping |
CAMEL-8387 | File consumer fails to acquire lock if readLockTimeout >= readLockCheckInterval |
CAMEL-8389 | camel-jackson - Allow to configure jackson object mapper from XML DSL |
CAMEL-8394 | camel-docker - DockerConfiguration should not keep client state |
CAMEL-8399 | Support setMode in JsonDataFormat |
CAMEL-8400 | camel-mqtt: multiple topic subscriptions |
CAMEL-8416 | camel-jetty - Allow multiple restrict headers |
CAMEL-8421 | Add minimum age option to readLock=changed |
CAMEL-8423 | Enhance Aggregate EIP to let AggregationStrategy to allow it to determine if aggregation is complete |
CAMEL-8428 | Cleanup some core interfaces (Consumer, Producer, EndpointAware) |
CAMEL-8441 | Add required 3rd party dependencies to the BOM |
CAMEL-8443 | Add properties to route via DSL and XML, expose route properties via JMX |
CAMEL-8444 | Camel Toolbox - Component properties to include setters |
CAMEL-8447 | Add camel-jetty module to republish the camel-jetty8 jar into maven repo |
CAMEL-8448 | Expose mina-2.0 instead of mina-1.1 through BOM |
CAMEL-8449 | camel-cdi - Support CDI 1.0 |
CAMEL-8451 | Upgrade jetty9 version to 9.2.9.v20150224 |
CAMEL-8452 | Camel route model - Preserve {{ }} placeholders in model |
CAMEL-8468 | Usage of camel-xstream depends on TCCL |
CAMEL-8483 | MongoDB Endpoints: Allow ReadPreference to be set on consumers |
CAMEL-8488 | Java DSL - Improved CBR to detect if endChoice vs end was invalid used |
CAMEL-8489 | camel-sjms - Allow to create empty message for null body |
CAMEL-8497 | Add extra capabilities to the github component |
CAMEL-8509 | camel-catalog - Add api to parse endpoint uri and reverse |
CAMEL-8511 | Properties component - Add encoding option to use when reading the properties files |
CAMEL-8513 | FTP consumer - Add option to use a larger buffer size so download is faster |
CAMEL-8514 | camel-castor should depend on castor-xml |
CAMEL-8516 | Salesforce component does not return the list of matching records for HTTP status code 300 |
CAMEL-8517 | Salesforce session handling must declare shared fields volatile |
CAMEL-8532 | Spring Boot applications should block the main thread of the execution |
CAMEL-8541 | Camel main TestSupport class is incompatible with the CDI specification |
CAMEL-8543 | Support easy configuration of HTTP proxy parameters for Camel salesforce component and maven plugin |
CAMEL-8544 | Camel - Dynamic router - unsupported cacheSize attribute |
CAMEL-8552 | camel-jackson should provide Map => Object converter |
CAMEL-8558 | Camel Catalog - Add humanize component name |
CAMEL-8561 | Camel Catalog - Add better description of components and others |
CAMEL-8562 | Removing a route - Should check if the route input endpoint is static and used by other routes |
CAMEL-8564 | Add support for dataformat ref parameter |
CAMEL-8571 | Split EIP - Should use new message id per splitted message |
CAMEL-8593 | JmsEndpoint.configureListenerContainer() some debug logs miss {} |
CAMEL-8600 | Change the ftp default separator to be Unix style |
CAMEL-8601 | Add Support for SFDC-specific Field Types To The Camel SFDC Component |
CAMEL-8615 | Update Dropbox-core-sdk from 1.7.6 to 1.7.7 |
CAMEL-8616 | Update Twitter4j to latest version |
CAMEL-8620 | Update LightCouch version from 0.1.3 to 0.1.6 |
CAMEL-8621 | Update Apache Kafka version from 0.8.1.1 to 0.8.2.0 |
CAMEL-8623 | Update Dropwizard Metrics from version 3.1.0 to 3.1.1 |
CAMEL-8634 | Wire tap - Should emit event notification about sending to tapped endpoint |
CAMEL-8635 | XStream no longer supports dynamic CL updates |
CAMEL-8645 | Camel Netty component should not intercept consumers with httpMethodRestrict=OPTIONS |
CAMEL-8693 | java.net.URISyntaxException: Invalid uri syntax: Trailing & marker found error should be configurable or skipped |
CAMEL-8710 | Make auth configurable for Google app components |
KARAF-2746 | Hibernate feature enhancements |
SSHD-268 | Upgrade to BouncyCastle 1.49 |