You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@sling.apache.org by ro...@apache.org on 2017/11/07 09:33:10 UTC

[sling-org-apache-sling-event-api] annotated tag org.apache.sling.event.api-1.0.0 created (now 0aa9ab4)

This is an automated email from the ASF dual-hosted git repository.

rombert pushed a change to annotated tag org.apache.sling.event.api-1.0.0
in repository https://gitbox.apache.org/repos/asf/sling-org-apache-sling-event-api.git.


      at 0aa9ab4  (tag)
 tagging ebe7dcbe7254332630ddc60f3184970d849e616f (commit)
      by Stefan Egli
      on Wed Apr 12 08:23:17 2017 +0000

- Log -----------------------------------------------------------------
org.apache.sling.event.api-1.0.0
-----------------------------------------------------------------------

This annotated tag includes the following new commits:

     new 5f8ddad  Import initial Sling source
     new c7153f6  Correct lock handling.
     new 1e03c27  Ignore Eclipse and build artifacts
     new 6be935d  Clean up dependencies.
     new 8f5aa14  Fix scm settings
     new 74b4b96  Formating pom.
     new 4454011  Refactor core classes part three - update other bundles.
     new e2ea8db  Refactor core classes part three - update other bundles.
     new b4511c4  Clean up and use generics.
     new 8239f77  Ignore Eclipse .settings
     new 4eb3f41  Fix license headers.
     new 7fc4417  Fix license headers.
     new 852fc46  Immediately remove lock token from shared global session.
     new 781cbe8  Keep lock token in global session until it is released by another session.
     new 9a42e57  Use new sling.id for the application instance id.
     new 1f4070b  Change namespace according to SLING-23
     new cca445f  Use constant for sling.id.
     new e488dfe  Remove sling module versions from parent pom to make release management easier. Add some more versions of dependencies to parent pom.
     new 6081924  Refactor event handler and put all the common stuff into AbstractRepositoryEventHandler. Start new TimedEventHandler.
     new a155c14  Load unlocked timed events on startup and queue them.
     new 90c1aab  Events can be scheduled by using a cron config, a period or a fixed date.
     new c72a5ce  Class should not be abstract.
     new b89c1cb  Add some debug messages when an event is scheduled.
     new e90b654  Log message if illegal topic is used.
     new 8141376  Timed events can be stopped by resending a timed event with the same id but without scheduling information (fixes SLING-26)
     new d815d3b  First implementation of persisting timed events for clustered applications.
     new f9eb708  Persist timed events into the repository (for failover). This fixes SLING-27.
     new 048a3ee  Fix NPE if no cleanup period is configured.
     new 50175b3  Event bundle defines and uses sling-event prefix.
     new ecef2be  Do not use a hyphen for the prefix (jackrabbit is not able to parse the cnd file)
     new dbec53f  Remove trailing ,
     new fb9ff82  javadoc fixes and use of generics.
     new cd24464  Add some junit tests for the eventing stuff.
     new 5be786d  Maven surefire plugin does not work with latest junit, so we have to use an older release (4.3) for now.
     new 1973b30  Test writeEvent method.
     new dc09de7  Remove event node after test.
     new 79c3f8b  Clean up repository after each test.
     new 452c91c  Ignore derby log.
     new 958a6a5  Fix several bugs in the timed events implementation. Applying patches from Philipp Kock (pkoch@day.com) (SLING-95): - TimedEvent must be lockable - Local events were ignored instead of remote events (comment was correct, but code not) - It's only an error if more than *one* scheduling information is specified.
     new b6aeeda  Catch IllegalArgumentException in case a faulty event is stored in the repository.
     new fdcef9e  Implement updating of expired date based timed events (SLING-96)
     new 7c319e3  Remove a timed event if it is based on a date after it has been fired from the repository.
     new 2313bcb  Synchronize removal of nodes for date based timed events. This should fix SLING-96.
     new 20edd6f  SLING-83 Move modules according to the new module structure
     new 5bb5ef6  Sync from branch: Allow updates of timed events: on update, the old schedule is stopped, the old event is removed from the repository and then the new one is written into the repo and scheduled (see SLING-96)
     new 0e3830d  SLING-83: Fix path to parent pom and svn location.
     new 1b8ebd6  SLING-83: Add only some modules to parent pom and adapt event module to api changes.
     new 5477038  SLING-83: Fix artifactId and symbolic name.
     new b6dcf77  SLING-83: Define Bundle-Symbolicname in parent pom.
     new efa2a03  Adapt to latest changes in sling core.
     new d7582e9  Adapt to latest changes in sling core.
     new b6c51f4  SLING-93 Fix artifactId of references Sling projects
     new eb7e427  Fix javadocs and ignore warning for type cast.
     new acaa66b  Remove dependencies to sling core by copying relevant stuff.
     new d609261  List containers first and use nt:base as base.
     new 97a38e0  Remove unused occurances of the sling plugin (it's not configured anyway)
     new 531ae90  Fix bugs in cleanup tasks (query was wrong) and TimedEventHandler is invoked either by a timed event or periodically.
     new d9cd779  More debug logging improvements.
     new 119e96f  Move session creation into same thread which is using the session.
     new 0c4e192  Add missing throws clause.
     new 13e187d  Fix test case.
     new 29f1c52  RESOLVED - issue SLING-178: Jobs should not need a job id https://issues.apache.org/jira/browse/SLING-178
     new d20eabf  Log query.
     new 4f29aa9  Referenced services can come and go - always check if service is available before calling to avoid ugly NPEs
     new 190a32d  Use new testing module and embed jcr commons.
     new 3b9342e  Use OSGi core and cmpendium jars from Felix project.
     new 8ad5380  SLING-204 - add svn ignore patterns for intellij
     new bfad7cd  Move node name creating into separate method.
     new b7f93b1  SLING-177: Start adding support for rescheduling and retrying jobs.
     new 6301440  SLING-177: Improvements to the event and job handling: - Adding a retry count and retry delay for jobs - Remove locking of parent node - Use separate write queue for minimum delay between publishing and storing - Improve parallel job processing, only jobs of same type are now serialized, everything else runs in parallel.
     new 0ef4ff1  Job topic and id together form a unique identifier.
     new 145d803  Add dynamic import for classes contained in the events.
     new 5b64ede  Fix lock token handling.
     new a226594  Fix lock token handling.
     new 145e217  SLING-177: Simplify job: no active and finished flags needed, job is removed after processing from the repository.            Handle case where a job is sent directly.
     new ec1625a  SLING-177: Don't bring the threads down just because of initial load errors.
     new f684abd  Don't unlock before remove (avoids observation events)
     new 370c9fe  Bug fixing.
     new dcd612c  SLING-177: Handle lazy loading of jobs and events if required bundles are not started yet.
     new dc68783  SLING-177: Only schedule distributing event handler.
     new 64d506d  SLING-177: Remove the use of the Locked class completly, refactor code.
     new 4c99b61  Use same session for unlocking and unlock node before removing.
     new 875e23b  Fix for synchronization.
     new 33de265  No need to pass lock token around.
     new 202a01c  Clean up session handling a litle bit.
     new a8de8d9  Synchronize on session
     new f44ddff  Use thread pool to create new threads instead of directly instantiating threads.
     new 6a97e04  Use thread pool to create new threads instead of directly instantiating threads.
     new 5173ab2  Create own thread pool for eventing.
     new b78e68e  Use thread pooling for scheduler as well. Create own pool for eventing.
     new 17c9041  Use thread pool configuration object to be extensible.
     new bdbbd1c  Improve test case.
     new ec54386  #0000 - Proper handling of jobs if used in a clustered environment.
     new 77748ef  Better node names to store the events in the repository.
     new 9f4d9cf  Log exception during job processing.
     new 64d5423  Set clean up time to half of scheduled time.
     new 9d168eb  Correctl handle retry count: retry exactly the number specified which makes (worst case): number of executions = 1 + number of retries.
     new cd2f8a6  Use nt:folder as base type and not nt:unstructured.
     new 593e92d  Move licence and notice to top level dir.
     new 37dafff  Add incubator disclaimer.
     new 6ceeb62  Add notice files.
     new 2c37795  Write first element in pom in one line (to avoid problems with the maven release plugin) and minor pom fixes.
     new a328648  Update notice files.
     new d8ee155  SLING-417: Move threads to commons.
     new eb06d1f  SLING-418: Move event stuff to extensions
     new 6bd472e1 Eclude maven-eclipse.xml generated by the maven eclipse plugin.
     new 5ea7fa0  Correct svn location.
     new e2ce5df  SLING-423: Correct node name handling for timed jobs; applied a slightly modified patch from Philipp Koch.
     new e8490b5  SLING-446: Refactor classes to use the commons package.
     new fa6d38e  SLING-446: Refactor classes to use the commons package and correct poms.
     new 1dea374  Correct svn urls.
     new b1c1e4e  SLING-449: Refactor core to engine.
     new 6887d9c  #SLING-414: Move generation and managing of the sling id to own service in the engine.
     new 22bbcc5  SLING-477: Add default max retry count with default value of 10.
     new b0e996c  SLING-442: Clean up exports, imports, dependencies and used plugins.
     new a129312  SLING-462: Don't reschedule a job if it fails with an exception.
     new d1ee6d3  SLING-481 Create metatype descriptions for the extensions/event bundle
     new 33420bb  Use OsgiUtil to get property values.
     new 1a960cf  Avoid concurrency problems on startup.
     new ca7c83a  SLING-483: Add excludes for javadocs and fix javadocs (WiP)
     new 2692ba6  SLING-495 - NOTICE files generated using mknotice script
     new ac38cb2  Better filter invalid characters when creating node names.
     new 99c6391  Ignore finished jobs on startup.
     new 8e2461c  SLING-495 - NOTICE files updated according to changes in revision 662927
     new f59747d  SLING-495 - NOTICE files regenerated with revision 663097 changes
     new 336eef8  SLING-495 - NOTICE files regenerated with Carsten's latest changes
     new be5f701  Use released version of parent pom.
     new 6930511  Use released versions (or soon to be released versions).
     new 909b366  [maven-release-plugin] prepare release org.apache.sling.event-2.0.0-incubator
     new b689609  [maven-release-plugin] prepare for next development iteration
     new 5216fe2  Set version to next development version.
     new 917f946  Fix reference to parent pom.
     new edb5aa2  SLING-521: Restore more notice files.
     new a4c4afe  Set immediate to true to start components automatically.
     new a0d0fa9  SLING-521: Separate between notice files for bin and src dists.
     new 6d496aa  SLING-521: Separate between notice files for bin and src dists.
     new df91963  SLING-521: Separate between notice files for bin and src dists.
     new f0e76a2  Change copyright year to 2008.
     new 47f0088  Update to released versions.
     new bba5822  [maven-release-plugin] prepare release org.apache.sling.event-2.0.2-incubator
     new 5bc747f  [maven-release-plugin] prepare for next development iteration
     new b2fb3cf  Use latest snapshots again to make project buildable.
     new a02dbe0  Use released versions.
     new 522d8da  Use released parent pom where possible.
     new dac0e00  Immediate isn't inherited anyway, so we can remove it from the base class.
     new 6caf9b5  SLING-555 : Update all poms to use the latest parent pom; update parent pom to include the incubator repo for plugins and use latest plugins.
     new e55f5bb  SLING-612 : Put the job back in the queue after the configured waiting time (which is secs and not ms). Check if job has already been processed by another cluster node
     new a3ec919  SLING-611 - Save event properties as jcr properties if possible.
     new ae8c51a  SLING-614 : Persist retry count in repository
     new b5f2dc8  SLING-611 - Save event properties as jcr properties if possible.
     new 2d6ac81  #0000 - Use scheduler to reschedule jobs instead of starting own threads.
     new 5b92672  SLING-616: Improved search: filter properties.
     new e7597b7  Set default sleep time to 30 secs.
     new 0d73d7e  Move property handling to EventUtil.
     new e0d642f  Improve wrapper implementation
     new db94dfc  Reduze object creation by using a map that also extends dictionary.
     new 850eb23  Simplify node type handling and store jobs into sub trees depending on the job topic.
     new 60ad469  Correct ignoring prefixes and add convenience methods.
     new 74e5e11  Convenience constructor.
     new 164b376  Fix endless recursion
     new 30edf2d  Implement toString()
     new d3d2b42  SLING-498 : Provide a new property to execute a job only on the instance it was created on.
     new 7698fc9  SLING-628 : Provide separate queues if property queue name is provided.
     new 7f3601d  SLING-628 - Implement separate queues, requeuing and ordered queues.
     new 16f6e8c  SLING-339 : Add wait time before startup to give handlers time to register. Correctly handle application id property.
     new 64c578f  Folders don't need to be lockable.
     new 4bab97e  Don't redistribute local events.
     new b111a0a  SLING-616 : Allow to query all jobs (running and queued)
     new 5098f58  SLING-616 : Improve query - each topic has its own folder.
     new 1e770cd  Make event property map modifiable
     new 74c0b50  Fix query when props are specified.
     new 1d527e0  Check if the job node has been removed in the meantime from the repository and store node path into resulting event object.
     new 11e5fd1  SLING-606 : Provide a method to cancel a job.
     new e10c94d  Support for multi-values (Arrays)
     new 1b2e495  Fix handling of own queues: use provided name and use proper synchronisation.
     new 822d63b  Provide or search functionality; fix shutdown problem,  when service is shutdown before the background thread started
     new f69d3ed  Fix synchronization for own queues.
     new 464c1e6  SLING-640 : Add status provider for timed events.
     new ff71142  SLING-640 : Fix search query.
     new 6f185d5  Fix cancel job.
     new 520b6fa  Better synchronization for timed events.
     new f361480  Create sub directory for topics.
     new 1e6e4c2  Use same node name decoding as the job event handler.
     new 6456540  Move helper method to helper class.
     new 57ad55b  SLING-665 - slingevent:Event now extends nt:unstructured *and* nt:hierarchyNode
     new 60a868d  SLING-665 Fix unit test failure due to missing sling:Folder node type
     new aaa32e5  Clean up eventing code
     new 2aeb119  Handle invalid class in the same way as class not found.
     new 076846c  Improve error messages.
     new 66566e1  SLING-339 Implementing a job acknowledge mechanism: All started jobs are queried after a configured time, if someone started to process them. If not, they're requeued. If more than one job processor wants to process a job, only the first one is used to notify the job event handler of success/failure.
     new 5169a0e  Improve exception message.
     new 0a63358  Make event properties map serializable.
     new 0c36ba6  SLING-759 Avoid synching on jcr sessions. Use extra lock objects for this.
     new ce6f8e5  Improve synchronization and thread handling.
     new cbf0cb4  Add log statement when queue is started.
     new 2f9dbe0  SLING-764 : Add an own thread pool service and change configuration with a fixed queue. By using a fixed queue, the max pool size is used and the pool growth. In addition the minimum size of the pool is increased to all ootb more parallel job queues.
     new d39bfab  Remove unused default user id setting (this even breaks startup with Jackrabbit 1.5)
     new 5646594  Use Java Runtime Collections class to get an Enumeration over a collection instead of Commons Collections.
     new 0396606  SLING-769 Explicit Jackrabbit Dependency Versions SLING-794 Adapt to new commons/testing functionality
     new 017bc53  SLING-794 Adapt to new commons/testing functionality
     new ba1c7ad  SLING-797 - Fix class check and add junit tests to cover this.
     new 80f29ee  SLING-806 Revert dependency to Jackrabbit JCR Commons to 1.4.2
     new 8faf55d  SLING-799: Create ordered folder to store events and sort the query result for jobs.
     new 7ebd5de  SLING-808 : Increase version to 5-incubator-SNAPSHOT
     new 48448f3  SLING-635: Remove a thread after two clean up cycles by marking it in the first cycle to be removed and remove it in the second cycle - if the thread hasn't been used in the meantime.
     new 8d5188c  Update notice files to include 2009 in copyright statement.
     new ad7f1d0  SLING-829 Cosmetics to the bundle/project names
     new bb3def5  SLING-829 - Add descriptions for thread pool and prefix configs with "Apache Sling"
     new 92d19b5  SLING-838 : Reduce initial wait time to 30 secs.
     new a31f309  SLING-809 : Add possibility to force reprocessing of a named queue.
     new 61460d3  Log starting only once
     new b9d3282  Correctly handle shutdown of job queue
     new b9276af  Fix typo.
     new f4c6a61  SLING-865 : Move to bundles
     new 50163ce  SLING-865 : Adjust reactor pom and svn information in each module.
     new 4745385  SLING-865 : Adjust path to parent pom and add profiles for samples and contrib
     new 255f5aa  Add new configuration property to handle maximum number of parallel processes for the main queue. Optimize acknowledge handling.
     new bd91ab1  Acknowledge the job processing before thread is started to avoid problems when a thread pool is used
     new ce74142  SLING-941: Lots of svn:eol-style settings missing
     new cbb0736  Use release parent pom
     new dbf00f8  Use released version as dependencies.
     new 99bc090  [maven-release-plugin] prepare release org.apache.sling.event-2.0.4-incubator
     new 2df74cc  [maven-release-plugin] prepare for next development iteration
     new 5b4affb  Use next dev version of parent pom
     new 639bca1  Use mock for value implementation
     new b4f288b  Set parent pom to released version.
     new be1ee16  Ignore exception and don't print it to standard out.
     new 2b37500  SLING-987 : Set the eventing thread pool queue to unlimited.
     new 9b18d84  Move Sling to new TLP location
     new 1ffa4e8  SLING-1011 : Remove disclaimer file.
     new 7f39b2d  SLING-1011 : Adjust svn location
     new 70de6cc  SLING-1011 : Remove disclaimer from readme's, adjust links to webite, fix versions in poms.
     new d266c66  SLING-1033 Upgrade to Sling parent POM 6 (and ensure web app has the leglize stuff, too)
     new 0952ae9  SLING-1046 : Use commons class loader instead of dynamic import package *.
     new 7a8948c  Clarify javadocs.
     new e22dff5  Add new method which explicitly gets a class loader for loading serialized java objects.
     new 0934af9  SLING-1058 : Notify waiting job if finish processing fails and change defaults for the thread pool.
     new efbbfa5  SLING-1063 - Include required packages from jackrabbit commons to avoid imports.
     new a9bc544  Prepare for upcomming 4.2 release and avoid ambigious method call.
     new 2cf43a4  SLING-1071 - Create hierarchy of child nodes to avoid too many child nodes.
     new 5c54c7e  Use official release instead of incubator release.
     new 2af40b8  SLING-1125 : Deprecate internal methods
     new bceb591  SLING-1125 : Deprecate internal methods
     new 176d987  Fix wrong org.apache.sling.commons.classloader version number
     new 47f4dfd  Update to latest Sling releases.
     new 438ce76  Remove unused dependencies.
     new c9d687f  [maven-release-plugin] prepare release org.apache.sling.event-2.0.6
     new 53fa99e  [maven-release-plugin] prepare for next development iteration
     new 97a5f52  Update to latest release.
     new 0aad80f  Clean up code
     new 0f3881a  Clean up code
     new 2cfaad1  SLING-1199 : TimedJobHandler and DistributionEventHandler should not be delayed
     new 1e4fa85  SLING-1205 Upgrade all projects to parent POM 8 and use OSGi provided OSGi libraries
     new 08a31d1  SLING-1235 : Access to writer session is not synchronized
     new 607794d  SLING-1238 : Counter for maximum parallel threads is not handled correctly
     new 8c839e9  Add some debug logging
     new d36a066  SLING-1243 : Scheduler reference is not defined for job event handler
     new 1530249  Make thread pool variable volatile.
     new 59d20f5  SLING-1248 : Use new commons threads
     new c594049  Remove version info from comment.
     new 56db49c  Fix jcr commons embedding.
     new 340a262  Remove debug logging.
     new e1be982  Use released version.
     new d72de3a  [maven-release-plugin] prepare release org.apache.sling.event-2.1.0
     new 3b5cbfd  [maven-release-plugin] prepare for next development iteration
     new 1a3f97c  Go back to current version.
     new 799a23d  Use released versions
     new 94fcc68  Typo
     new b95ff12  Use StringBuilder instead of StringBuffer.
     new 742fd2c  Some typos
     new 76e8657  SLING-770 : Send notification event when a job is cancelled
     new 96e92eb  Create session for event handling lazy
     new 50ad4c2  SLING-1002 : Reduce memory consumption and improve startup behaviour of the job handler
     new 7858229  SLING-1002 : Reduce memory consumption and improve startup behaviour of the job handler
     new f23fa99  Minor performance improvement: get root node only once and store it
     new b85b82d  Use latest jcr api to decouple modules from jcr 1.0 (contained in older jcr api releases)
     new 4982f2e  SLING-1349 :  Check if parallel property for jobs has value false
     new 5997a0e  SLING-1348 : Disable DistributingEventHandler by default
     new 3d76d61  SLING-1358 : Number of parallel threads is wrongly calculated
     new 379a3f4  SLING-1365 : Limit the number of parallel jobs Move job related utility classes into own package. Add limit check to main queue Restructure queue handling and fix rescheduling if an error occurs
     new 0212b90  Further refactoring for rescheduling.
     new a9bc570  SLING-1365 : Limit the number of parallel jobs Change behaviour of ordered queues: the first job arriving defines if the queue is ordered!
     new b12e615  SLING-1365 : Limit the number of parallel jobs First implementation for job queues.
     new a3d46bb  SLING-1365 : Limit the number of parallel jobs Add more debug logging.
     new 1fa52ad  SLING-1365 : Limit the number of parallel jobs Add more debug logging, fix shutdown order and fix job counter for job queues.
     new 2baf710  SLING-1369 : Make the maximum number of job queues configurable
     new 31b90ad  [maven-release-plugin] prepare release org.apache.sling.event-2.2.0
     new 969a6ad  [maven-release-plugin] prepare for next development iteration
     new 7676f95  SLING-1389 : Background loading might not load all stored jobs SLING-1390 : Deadlock in rare circumstances SLING-1396 : Include only used classes from jcr commons This is mostly a refactoring affort to reduce the complexity and make the code more understandable. With this I could fix the above mentioned errors. Started to add some basic test cases.
     new b2fe83c  Add some comments.
     new 6a36787  SLING-1397 : Add an acknowledge method to EventUtil
     new acde459  SLING-1398 : Remove deprecated stuff from EventUtil
     new abef434  Fix javadoc
     new ba0eb9c  Move private class into private package and fix include instructions
     new 6ffc467  [maven-release-plugin] prepare release org.apache.sling.event-2.3.0
     new 2b0f35c  [maven-release-plugin] prepare for next development iteration
     new 6ec255b  SLING-1426 : Spurious wakeups are not handled correctly
     new 90f7505  SLING-1426 : Spurious wakeups are not handled correctly
     new b3c6cbe  SLING-1426 : Spurious wakeups are not handled correctly
     new d37db66  SLING-1426 : Spurious wakeups are not handled correctly
     new a10cd8c  Minor code cleanup
     new ed35531  SLING-1433 : Move ThreadPool interface into impl package
     new f976fbf  Add tag to avoid sonar rule checks for this code.
     new 817eff0  activate does not throw exceptions
     new a3a366f  Clean up javadocs and code
     new 110f0db  Use new service from Sling API and support jcr 2 property types
     new 7d13ca9  Put licence header above package statement
     new c1e736b  Exclude job impl package from javadoc
     new 72fdf40  SLING-1462 : Add methods to get the sling home to SlingSettingsService
     new b58caab  Remove deprecated stuff
     new 2325b2b  SLING-1467 : Cancelling a job does not work
     new 9e9facf  SLING-1467 : Cancelling a job does not work
     new 00d71e3  SLING-1467 : Cancelling a job does not work
     new 551d46e  SLING-1474 : Allow to change the priority for jobs
     new d190168  Correct "since" handling
     new 0019619  SLING-1494 : Update to JCR 2 API
     new ab24b02  SLING-1518 - making unit tests compatible with jmock 2.5.1
     new b112493  Use released parent pom.
     new 7d3b5c0  SLING-1467 :  Cancelling a job does not work
     new 1bf1836  Add additional logging
     new 0c2243a  SLING-1535 : Application id is not cleared for job events
     new 23eac29  Log app id on startup
     new 9f289d8  SLING-1537 : Illegal job topics are not handled correctly
     new d4bca1b  SLING-1581 : Concurrent session access in event handlers
     new fb17954  SLING-1581 : Concurrent session access in event handlers
     new 479d7fe  Fix typos
     new 61b655a  SLING-1460 : Move SlingSettingsService to new Settings bundle
     new 7ee26d6  SLING-1640 add missing methods to mock SlingSettingsService
     new 1aacade  Use released version of the settings bundle and use provided scope for SCR annotations
     new e8e4a88  SLING-1685 : Method to force remove a job
     new 49c46b4  Fix tests
     new aa4bdbb  Make sure all jobs are started for the notification test.
     new d9992b2  Make sure all jobs are started for the notification test.
     new 4a391a1  Make sure to wait for jobs to be written into the repo
     new 7d45a32  SLING-1687 : JobStatusProvider should lazy load events when returning
     new 09f6c59  SLING-1710 : JobEventHandler: jobs in a waiting state won't be waked up anymore if job.getProperty(EventUtil.PROPERTY_JOB_QUEUE_NAME) != null
     new 061ddd9  SLING-1536 : Job Queue might be stopped during job processing
     new 724cd65  SLING-1536 : Job Queue might be stopped during job processing
     new a158103  [maven-release-plugin] prepare release org.apache.sling.event-2.4.0
     new e73f1a4  [maven-release-plugin] prepare for next development iteration
     new 2e112c2  SLING-1748 : Observation uses wrong filter mask
     new 2d9423f  SLING-1754 : Jobs nodes should be unlocked after they have been changed
     new d3d1a12  SLING-1788 : Fail early if loaded job should not be processed on the current app node
     new 8271010  SLING-1791 : Background threads should be daemon threads
     new facc352  SLING-1790 : Job handling does only use cluster for failover
     new f23e51d  SLING-1806 : Include helper classes in bundle
     new 6ad759b  Save only intermediate nodes on path creation.
     new a842923  Prepare for release.
     new 8cf86ca  [maven-release-plugin] prepare release org.apache.sling.event-2.4.2
     new 2d57cb3  [maven-release-plugin] prepare for next development iteration
     new 859e8a3  updating all modules to parent 10-SNAPSHOT in anticipation of emma additions to parent
     new e072a42  Move code from 3.0 branch to trunk
     new 006119e  Use released versions
     new ec6fa1f  Don't throw illegal state exception if queue has been removed in the meantime; use status message Avoid division by zero
     new 9b7262c  Improve webconsole layout and add restart method
     new b50fa73  Improve webconsole layout and add restart method
     new 58fdf7f  Lock on special lock object and add a dropping queue
     new 2ea9d53  Use special lock objects for syncing
     new bf6d3cf  Ignore emma file Add new tests for drop and ignore queue Fix drop queue handling
     new d01b5e7  Make new queue name unique when renaming.
     new 092a962  SLING-1849 : DropQueueTest failure
     new c6c413f  SLING-1849 : DropQueueTest failure
     new f979b20  Clear markedForCleanup flag if queue should not be removed
     new 79ae2d5  It's enough to just configure the min pool size
     new 843b945  SLING-1854 : IgnoreQueueTest failure on Windows Vista
     new ce16c6d  Adding Jira version id
     new f9dcff8  SLING-1869 - upgrading to latest SCR plugin and putting scr.annotations in parent
     new f10190d  SLING-1878 Fix set of allowed characters (remove [, ], *) and use BitSet instead of String; add unit tests
     new ee779dc  SLING-1864 : Queue.resume() has no effect
     new a29c8c6  Fix potential sync problem in ordered queue: a job might be finished before the queue starts waiting
     new ca08ed9  Add empty line for better output
     new c924727  Fix potential dead log if the job is processed "very" fast
     new 6575599  SLING-1889 : Make job creation date available
     new e0d8f12  Fix queue configuration detection if queue name is provided in the job event.
     new aaf02f4  Update to recent snapshots
     new 4651390  SLING-1891 : Replace Cass.forName uses by ClassLoader.loadClass
     new 8296a60  Use latest releases.
     new 5a86bcb  SLING-1896 : Provide a configuration option to disable/enable all event processing
     new 37fabcd  Several fixes: fix timeout handling and clear statistics. Refactoring: rename *cleanUp to
     new d58df25  Fix reset statistics
     new 129373d  Shorten clean up interval for queues
     new 59f8f0a  Fix potential NPE in rescheduling of unprocessed jobs and add test case
     new 66a7860  Use scope test for test lib
     new cfadb0c  Fix remove all jobs from queue and wake up queue if clearing
     new 21b52e0  Set timeout for test
     new 36b1629  Correctly handle queue count if no ack has been received
     new 966bc52  SLING-1917 : Make Locking Strategy Configurable (for Cluster Usage)
     new 210f48a  SLING-1918 : Use time based folder structure for jobs without an id
     new 1d6be36  SLING-1918 : Use time based folder structure for jobs without an id
     new c34f320  [maven-release-plugin] prepare release org.apache.sling.event-3.0.0
     new 60cb37c  [maven-release-plugin] prepare for next development iteration
     new 33829e3  SLING-1955 : Event Support Unit Tests stall in full trunk build
     new 552876a  SLING-1955 : Event Support Unit Tests stall in full trunk build
     new 643bec0  SLING-1955 : Event Support Unit Tests stall in full trunk build
     new 40bd785  SLING-1955 : Event Support Unit Tests stall in full trunk build
     new 5f3be3f  SLING-1955 : Event Support Unit Tests stall in full trunk build
     new b32645a  [maven-release-plugin] prepare release org.apache.sling.event-3.0.2
     new ab1ade7  [maven-release-plugin] prepare for next development iteration
     new c51a9be  SLING-1982 : Potential deadlock if job manager is restarted
     new 64feab9  Use latest Apache Jackrabbit to avoid problems with the tests on Windows XP
     new 9d14106  Fix for potential timing problem in IgnoreQueueTest
     new 948cc02  SLING-2030 - switching query to use SQL instead of SQL2
     new 8747535  Fix typo and add some sanity locking.
     new 8e6b41b  SLING-2037 : Add limit to job query
     new 9f3d04d  Add sleep after shutdown to give the repository time to really shutdown before the next test starts
     new 6ac68e6  SLING-2071 : Job is not locked and can be removed if locking manager is configured with "none"
     new 3f87efe  Correct path handling
     new 69e8499  Add toString for debugging
     new 2db2f5d  SLING-2117 : Only remove empty job folders which are older than one hour
     new 92bbf83  SLING-2118 : Refresh long running sessions if save fails
     new 5f34b9d  SLING-2119 : Add a periodic sanity check to the internal job cache
     new a4351db  Add new method to avoid problems if we upgrade to a newer sling settings api
     new 80d2c5a  SLING-2119 : Add a periodic sanity check to the internal job cache
     new 13a95f9  [maven-release-plugin] prepare release org.apache.sling.event-3.1.0
     new b4c1814  [maven-release-plugin] prepare for next development iteration
     new 91d70c8  SLING-2150 : Update plugins to use the latest available versions
     new d7380cc  Update to recent snapshot
     new b5372db  Using latest released parent pom
     new 55ee28d  SLING-2187 - adding new module to contain our custom notice file; adding remote-resources plugin configuration to parent pom and removing all existing appended-resources NOTICE files
     new 2e009e1  temporarily using snapshots during release vote
     new 5562e31  SLING-2205 : Enable / disable job processing based on Sling ID
     new 337f2e3  using latest releases
     new bc2af5b  SLING-2286 : Ignore repository exception for loading of a single job
     new a6c001b  SLING-2323 : OrderedQueue: remove all might leave a stale entry
     new 2db4b70  [maven-release-plugin] prepare release org.apache.sling.event-3.1.2
     new e6434fb  [maven-release-plugin] prepare for next development iteration
     new 14846c1  Update mock scheduler to latest scheduler interface
     new 6bd3892  SLING-2456 : JobManager should ignore empty entries in application id array
     new d57714c  [maven-release-plugin] prepare release org.apache.sling.event-3.1.4
     new 8f42399  [maven-release-plugin] prepare for next development iteration
     new a80c4e6  SLING-2480 : Add config for maven-sling-plugin to m2e configuration
     new 2133274  Update to latest parent pom
     new 4dd63fc  Use released versions
     new 021ff26  Use latest releases and update to new parent pom
     new 5d8247b  Update to latest parent pom and use latest releases in launchpad
     new 38cdf91  SLING-2597 Added some beans for general monitoring of event queues. Work In Progress. The bundle builds and passes all tests, but does nothing at present.
     new 0410dde  SLING-2597 Operation JMX beans for Queues with notification when new queues are added. Each queue is given its own MBean.
     new 7769aca  SLING-2597 small change to the web console to add a test button which allows a queue to be tested by firing an empty event at the queue. This causes the queue to become active. The side effect is the queue appears in JMX.
     new b619e43  SLING-2597 Correctly acknowledged tests jobs.
     new 3aa667e  SLING-2597 Start time output format wasnt exactly readable, added Date
     new b546fa4  SLING-2748 Adjusted compartable checks to match output of the Comparable API.
     new b84ffa8  SLING-2749 fixed potential synchronization issues with activate and deactivate in the LockManager.
     new fde713f  SLING-2751 Fixed JMX names for event JMX objects.
     new dd5d8fa  Typo
     new b7b5a47  Typo
     new b03acb9  SLING-2832 : Use resource API SLING-2831 : Use new discovery API SLING-2830 : Discontinue per job configurations for queue processing SLING-2829 : Add API for starting a job and service interface for executing a job
     new af21f8d  SLING-2829 : Add API for starting a job and service interface for executing a job
     new a8f5a7b  SLING-2829 : Add API for starting a job and service interface for executing a job
     new 65eb50e  Update svn:ignore
     new cb8223f  Handle retry delay
     new 356b86c  SLING-2830 : Discontinue per job configurations for queue processing
     new 0fb5475  SLING-2830 : Discontinue per job configurations for queue processing  - make service ranking configurable through web console and always apply sorting
     new 6cea053  SLING-2830 : Discontinue per job configurations for queue processing  - make service ranking configurable through web console and always apply sorting
     new 50d1f3e  SLING-2830 : Discontinue per job configurations for queue processing
     new f792bbf  SLING-2829 :  Add API for starting a job and service interface for executing a job
     new 9f1be45  SLING-2839 :  Use package-info.java for exports
     new 654b8d4  SLING-2829 :  Add API for starting a job and service interface for executing a job - first shot at an async processing api
     new 09afc45  SLING-2829 :  Add API for starting a job and service interface for executing a job - first shot at an async processing api
     new 981ccfa  SLING-2829 :  Add API for starting a job and service interface for executing a job - first shot at an async processing api
     new 1bf8440  Fix test case
     new b6a48ee  Code cleanup
     new 78d340f  Add missing support for old binary properties.
     new 161658d  SLING-2829 : Remove dangerous wait for async configuration option again - it's not needed
     new f830136  SLING-2829 : Fix NPE in async handler
     new 39f3a66  correcting comma issues in annotations (from SLING-2829)
     new ba09075  SLING-2829 : Correctly handle first run of background loader
     new 95b388a  SLING-2829 : Sort instances correctly if there is more than a single cluster view
     new afdde2f  SLING-2829 : Be prepared to handle read failures in value map
     new 685df7f  SLING-2848 : Event integration tests fail due to unresolvable artifacts
     new ad7a6d4  SLING-2848 :  Event integration tests fail due to unresolvable artifacts
     new 434207a  SLING-2851 :  Topic Round Robin Queue is not correctly marked for removal
     new 00f5088  SLING-2829 : Don't close queue if async jobs are running
     new cee1ccf  SLING-2829 : Get job consumers lazy to avoid service reference cycles if the job consumer needs the job manager (which in turn needs the job consumer manager)
     new 348aa7a  Correct reactor pom and update to parent pom 16
     new 1a5e764  SLING-2856 : NPE in JobManagerImpl to read priority for Job SLING-2829 : Distributed jobs only across local cluster if possible
     new ad4ef12  SLING-2856 : NPE in JobManagerImpl to read priority for Job SLING-2829 : Distributed jobs only across local cluster if possible Correct metatype information from previous commit
     new 3036b06  Remove todo's for log statements
     new 2497533  SLING-2829 : Provide better error message if a job/event/timed job can't be read from the repository
     new 8ee4077  SLING-2829 : Ignore empty handler when closing queue
     new 9f54c9e  SLING-2829 : Fix checking of local topic list
     new 52a13a7  SLING-2829 : Don't remove timed event if it's in the past
     new cacb0d7  Add more log messages when a job is discarded
     new 04a2b9c  SLING-2829 :  Add API for starting a job and service interface for executing a job
     new c72a482  Don't cache statistics
     new c4ea502  Avoid double sync
     new 4772680  SLING-2867 Improve implementation : Change some log messages to info for easier debugging, Fix reassign jobs handling when job has been sent via event admin
     new bb5e50c  Use latest api snapshot
     new 3a4950f  SLING-2867 Improve implementation : Improve logging and check topic when a new job is added
     new 111f460  SLING-2867 Improve implementation : Use improved change detection for earlier detection of cluster changes
     new 8a037b6  SLING-2868 :  Improve and cleanup implementation : Set sling:resourceType for lock resources
     new db0854b  SLING-2868 :  Improve and cleanup implementation : Improve logging for timed events
     new 6a4add2  SLING-2868 :  Improve and cleanup implementation : don't wait for resume on shutdown
     new c20e1ff  SLING-2868 :  Improve and cleanup implementation : remove unused code from beans
     new 88319cb  SLING-2868 :  Improve and cleanup implementation : use correct discovery modules
     new 65b1f1b  SLING-2868 :  Improve and cleanup implementation : Remove unprocessed job from repository after test
     new 9f8ecac  SLING-2868 :  Improve and cleanup implementation : Don't use event admin with custom event objects to update jmx information
     new 5890346  SLING-2868 :  Improve and cleanup implementation : Remove async handler when sending notifications
     new b7df5eb  Remove configurations and dangling jobs after each test
     new a276f46  SLING-2878 :  NPE in JobConsumerManager
     new f7d2ae8  SLING-2896 :  Job might be executed twice if a topology event occurs
     new a50afa2  Add topology information to web console
     new 3dbbcfd  SLING-2906 :  Queue might be outdated and closed while still processing
     new 4419c15  SLING-2909 :  Add inventory printer for JSON output
     new 466b9d2  SLING-2909 :  Add inventory printer for JSON output
     new 7a1bf03  SLING-2909 :  Add inventory printer for JSON output
     new 934ebf9  SLING-2906 :  Queue might be outdated and closed while still processing
     new bf3112a  SLING-2906 :  Queue might be outdated and closed while still processing
     new 8c853f8  SLING-2906 :  Queue might be outdated and closed while still processing
     new 24ccff1  SLING-2925 : Wasted work in InternalQueueConfiguration.checkIsValid(). Apply patch from Adrian Nistor
     new 583b1da  SLING-2946 : IOOBE in TopicRoundRobinJobQueue. Apply patch from Timothee Maret
     new 38c457e  SLING-2950 :  Disabling the distribution flag takes only effect after bundle restart
     new d4cecf1  SLING-2954 :  Event ITs spuriosly fail on Jenkins
     new 9f1c252  SLING-2954 - Event ITs spuriosly fail on Jenkins
     new 020d92f  SLING-2954 - Event ITs spuriosly fail on Jenkins
     new 9975a45  Remove port setting from java code (it's in the pom)
     new a0cfcd2  Add resource path to returned job
     new 7d6d2f8  SLING-2970 :  Notification events should not be distributed
     new fab7d8f  SLING-2969 - IT failure: ClassloadingTest.testSimpleClassloading fails intermitently
     new 4475e7b  SLING-2969 - IT failure: ClassloadingTest.testSimpleClassloading fails intermitently
     new d793027  SLING-2969 - IT failure: ClassloadingTest.testSimpleClassloading fails intermitently
     new 8ede384  SLING-2972 :  Improve processing performance if job is processed locally
     new 12beff3  SLING-2971 :  BackgroundLoader thread dies for invalid paths
     new b1b722b  SLING-2971 :  BackgroundLoader thread dies for invalid paths
     new c0e4e4c  Update to latest parent pom
     new b68cda6  Use released discovery api
     new 72fd5da  Correct queue type, ignore was missing in the list
     new c522c22  Update javadocs
     new 5c8e6c4  Add simpler addJob() method
     new 8ff39b7  Prevent NPE if the topology is not established on startup
     new 6ed8ccc  Update javadocs
     new d8afbdd  Remove unused configuration property
     new cd02b35  SLING-2944 Revert Jackrabbit Server to 2.1.0 release (instead of 2.1.1-SNAPSHOT)
     new 2868ca0  Correct license header
     new e5a35eb  Update locking code to handle SNS
     new 386ea68  Correct marker of job consumer interface, mark manager as provider type
     new eed14bd  Remove propertyIsPrivate for properties where no metatype is generated
     new 47580f9  Avoid deprecated methods
     new a623f6d  Use latest jcr jackrabbit server version for tests
     new f29bd54  Avoid deprecated methods
     new ca96692  Prepare for release
     new c5817d2  [maven-release-plugin] prepare release org.apache.sling.event-3.2.0
     new cf0a95f  [maven-release-plugin] prepare for next development iteration
     new 7322337  Back to latest snapshot after release
     new 8298a34  SLING-3005 - Event integration tests: update bundle versions for jackrabbit.server, tika
     new 645cd18  SLING-3004 - Event ITs should use timeouts
     new b069b29  Updated .gitignore files
     new cc77616  SLING-3012 :  Create unique id if timed event does not contain one
     new 9026656  SLING-3012 :  Create unique id if timed event does not contain one
     new 03823f6  Use released version for testing
     new 9871c18  SLING-3028 :  Support for progress tracking of jobs  - prototype of an API
     new b1139d0  SLING-3039 :  Obsolete events should be removed in batches from the resource tree
     new 678e509  SLING-3028 :  Support for progress tracking of jobs  - prototype of an API
     new 67c80c6  Update to parent pom 18
     new d9bb8b7  SLING-3028 :  Support for progress tracking of jobs
     new 2c36af7  SLING-3028 :  Support for progress tracking of jobs
     new e9e1e51  SLING-3028 :  Support for progress tracking of jobs
     new b015e60  SLING-3028 :  Support for progress tracking of jobs
     new 486fca5  SLING-3028 :  Support for progress tracking of jobs
     new f2118cc  SLING-3028 :  Support for progress tracking of jobs
     new 271dcb0  SLING-3028 :  Support for progress tracking of jobs
     new 72ec88e  SLING-3028 :  Support for progress tracking of jobs
     new 15e5ade  SLING-3028 :  Support for progress tracking of jobs
     new 304f4df  SLING-3028 :  Support for progress tracking of jobs
     new 83e3561  SLING-3028 :  Support for progress tracking of jobs
     new b2e5f64  SLING-3139 : Provide a way to schedule jobs SLING-3138 : Add fluent api to create new jobs
     new ca42416  SLING-3139 : Provide a way to schedule jobs SLING-3138 : Add fluent api to create new jobs
     new c83103a  SLING-3139 : Provide a way to schedule jobs SLING-3138 : Add fluent api to create new jobs
     new 974cdc6  SLING-3139 : Provide a way to schedule jobs SLING-3138 : Add fluent api to create new jobs
     new d0154d3  SLING-3139 : Provide a way to schedule jobs SLING-3138 : Add fluent api to create new jobs
     new 14c2f0f  SLING-3139 : Provide a way to schedule jobs SLING-3138 : Add fluent api to create new jobs
     new 635ef8c  SLING-3041 : Mark job as failed if async job consumer disappears
     new 70fbd0c  SLING-3139 : Provide a way to schedule jobs
     new bcfd99a  SLING-3139 : Provide a way to schedule jobs
     new d34580c  SLING-3139 : Provide a way to schedule jobs
     new 6a5d226  SLING-3139 : Provide a way to schedule jobs
     new a2829b6  SLING-3139 : Provide a way to schedule jobs
     new 55dfbc2  SLING-3139 : Provide a way to schedule jobs
     new 09680fa  SLING-3168 : Deprecating JobUtil class?
     new fbf7767  SLING-3171 : Deprecate job name handling
     new 1c817e1  SLING-3166  : Job Scheduling Possibilities
     new 3b52da7  SLING-3166  : Job Scheduling Possibilities
     new 25a573c  SLING-3169 : Naming of Job related enumerations
     new fa9389a  SLING-3171 : Deprecate job name handling
     new c02c689  SLING-3167 : Job Logging
     new f743e48  SLING-3172 : Job schedule name handling
     new c1d604c  SLING-3169 : Naming of Job related enumerations
     new 7eb13cb  SLING-3170 : Complex Job Result Structures
     new b0c1800  SLING-3170 : Complex Job Result Structures
     new cab1722  SLING-3169 : Job state and related enumerations
     new 8efa624  SLING-3028 :  Support for progress tracking of jobs
     new d87b610  SLiNG-3184 : Create a job consumer to clean up the history
     new 40ae579  SLiNG-3184 : Create a job consumer to clean up the history
     new 1158346  SLING-3172 : Job schedule name handling
     new 84ef248  SLiNG-3184 : Create a job consumer to clean up the history
     new 87a09b0  Clean up after each it test
     new 80e072f  SLING-3188 : Thread pool configuration per queue
     new ec4265a  [maven-release-plugin] prepare release org.apache.sling.event-3.3.0
     new abf6539  [maven-release-plugin] prepare for next development iteration
     new 378b917  SLING-3194 : failure running sling.extensions.event unit/integraiton tests on windows?
     new ae74ec3  SLING-3220 - avoid infinite loop in TimedEventSender, patch contributed by Marc Pfaff, thanks!
     new 95121f8  SLING-3239 - Upgrade to SCR 1.8.0
     new a58a062  SLING-3268 : TopicRoundRobin queue thread is not stopped when queue is closed
     new 99b37dc  SLING-3282 : No metatype generated for JobManagerImpl OSGi configuration
     new d6e7409  Correct javadocs
     new 1d24ebf  SLING-3306 : Job consumer configuration is distributed in a cluster
     new 3ccb58e  Fix type in cron expression
     new d8c8461  [maven-release-plugin] prepare release org.apache.sling.event-3.3.2
     new 483f000  [maven-release-plugin] prepare for next development iteration
     new 6129e7c  SLING-3329 : Jobs in ordered queue might be ignored
     new 68c61fd  [maven-release-plugin] prepare release org.apache.sling.event-3.3.4
     new abafaaf  [maven-release-plugin] prepare for next development iteration
     new 8418d80  SLING-3381 : JobManager.getQueue() might not return queue
     new b15c898  SLING-3383 : Non stopping thread in AbstractJobQueue causes classloader leak
     new ebac94d  SLING-3392 : JobManager MaintenanceTask should not rely on search for removing locks
     new cce7a45  [maven-release-plugin] prepare release org.apache.sling.event-3.3.6
     new 9d6d599  [maven-release-plugin] prepare for next development iteration
     new 711e23a  corrected annotation error because of spare commas
     new ce579d2  Update to parent pom v19
     new 003f61d  SLING-3497 : Provide option to run jobs on same instance where job was created
     new 13f7ad9  [maven-release-plugin] prepare release org.apache.sling.event-3.3.8
     new 34a424a  [maven-release-plugin] prepare for next development iteration
     new fe5a668  SLING-3502 : handling of main queue name fixed: not filtering active main queue name, as kept in the queues map
     new e2022f3  [maven-release-plugin] prepare release org.apache.sling.event-3.3.10
     new e20a691  [maven-release-plugin] prepare for next development iteration
     new 2d0dcf0  let IDEA find the org.apache.sling.testing.tools dependency
     new abb15aa  SLING-3575 SLING-3576 SLING-3577 optimize Sling JCR Jackrabbit Server (update tests and ignore one for now)
     new 458a289  Less SNAPSHOTs in tests
     new b298a97  SLING-3725 : JobManager.queryJobs/findJobs should match with empty templates
     new e78bff9  SLING-3701 : [Job Scheduling] : No API to search through the scheduled jobs based on some properties.
     new b1aa691  SLING-3699 : [Job Scheduling] A job scheduled using JobBuilder does not get removed if the JobConsumer returns JobResult.OK
     new 05c0972  Remove spurious html output from inventory printer
     new 008f2a7  SLING-3812 : Avoid search when loading jobs
     new 27c41c1  Updated to parent version 20
     new 2fd4a1a  SLING-3813 - Pax-Exam tests fail when executed under Java 8
     new 1a7ab51  [maven-release-plugin] prepare release org.apache.sling.event-3.3.12
     new 485d98b  [maven-release-plugin] prepare for next development iteration
     new 2cb7579  SLING-3824 - Unneeded volatile fields in StatisticsImpl and TopicStatisticsImpl
     new eca7e2f  SLING-3856 : NPE in JobManager.getJob if no map is provided
     new de20dfa  [maven-release-plugin] prepare release org.apache.sling.event-3.3.14
     new 18da701  [maven-release-plugin] prepare for next development iteration
     new af8c941  event ITs: use current SNAPSHOT for jcr.jackrabbit.server
     new 2a0e13a  Use correct SNAPSHOT version for org.apache.sling.jcr.jackrabbit.server
     new 6da29bf  Event ITs: use released version of org.apache.sling.jcr.jackrabbit.server
     new ac3ed40  Update to Sling Parent POM 22 with baselining enabled
     new 41679d9  SLING-4014 - Sling Jobs do not get picked at times
     new 80ea7ae  SLING-4014 - Sling Jobs do not get picked at times
     new a55e69c  SLING-4044 : Remove distributed eventing from job handling
     new 910a423  Add deprecating warning if name feature is used
     new c6db4a3  SLING-4047 : Unable to schedule jobs using JobManager
     new 2ede121  SLING-4048 : Avoid keeping jobs in memory. Make configuration a service
     new 4dfa04a  SLING-4048 : Avoid keeping jobs in memory. Move job reading to a utility class
     new 2da7865  SLING-4048 : Avoid keeping jobs in memory. Refactor and move resource resolver creation to a single place
     new 9c4fbb1  SLING-4048 : Avoid keeping jobs in memory. Move topology handling to own handler service
     new 03c90e2  SLING-4048 : Avoid keeping jobs in memory. Move topology handling to own handler service
     new 3fb3b45  SLING-4048 : Avoid keeping jobs in memory. Rewrite statistics, queue and topic handling (WiP)
     new ddbd791  SLING-4048 : Avoid keeping jobs in memory. Rewrite statistics, queue and topic handling (WiP)
     new d6f9e69  SLING-4048 : Avoid keeping jobs in memory. Refactor job traversal and implement different queue strategies (WiP)
     new 18c3e25  SLING-4048 : Avoid keeping jobs in memory. Fix rescheduling of a job and synchronizing rescheduling (WiP)
     new aa7e06f  SLING-4068 : Drop support PROPERTY_NOTIFICATION_JOB event property SLING-4065 : Add notification when a job is added SLING-4063 : Fix job queue statistics
     new fe81950  SLING-4053 : Deprecate queue types IGNORE and DROP
     new b47cd3d  SLING-4048 : Avoid keeping jobs in memory. Fix round robin queue and implement statistics reset (WiP)
     new 3215cc8  SLING-4048 : Avoid keeping jobs in memory. Fix bridged events (WiP)
     new cba83de  SLING-4048 : Avoid keeping jobs in memory. Fix bridged events (WiP)
     new b380926  SLING-4048 : Avoid keeping jobs in memory. Fix job removal (WiP)
     new 12e7494  Disable integration tests for now
     new d1a2b52  SLING-4048 : Avoid keeping jobs in memory. Fix suspending/resume (WiP)
     new ab3a532  SLING-4048 : Avoid keeping jobs in memory. Enable tests again and add more basic tests (WiP)
     new de80314  SLING-4066 : Reassign unhandled jobs
     new 83e0778  SLING-4048 : Avoid keeping jobs in memory.  (WiP)
     new 8d358b8  SLING-4048 : Avoid keeping jobs in memory.  Increase test covers, update test setup to more recent bundles (WiP)
     new eac5877  SLING-4048 : Avoid keeping jobs in memory.  Initial version done
     new 9a83ed0  Correctly name variable
     new 2504491  SLING-4048 : Avoid keeping jobs in memory.
     new d23a1ba  SLING-4048 : Avoid keeping jobs in memory.  Prevent from being hit by SLING-4073
     new bcecb75  Disable integration tests for now
     new 2653e8c  SLING-4048 : Avoid keeping jobs in memory. Another refactoring: move job cache to queue (WiP)
     new 413df21  SLING-4048 : Avoid keeping jobs in memory. Another refactoring: move all configuration code into config package (WiP)
     new d4f1cbc  SLING-4048 : Avoid keeping jobs in memory. Another refactoring: move all configuration code into config package (WiP)
     new 5e226d2  SLING-4048 : Avoid keeping jobs in memory. Another refactoring: move all configuration code into config package (WiP)
     new 19ce06b  SLING-4048 : Avoid keeping jobs in memory. Another refactoring: move all configuration code into config package
     new 7e7f7b4  SLING-4048 : Avoid keeping jobs in memory. Fix rescheduling bug when topology changes in between
     new 0b83ec6  Disable tests for now
     new 21848aa  SLING-4048 : Avoid keeping jobs in memory. Simplify queue configuration handling.
     new 9239959  SLING-4048 : Avoid keeping jobs in memory. Remove obsolete and outdated stuff
     new 3f9a153  SLING-4048 : Avoid keeping jobs in memory. Remove obsolete and outdated stuff
     new da4653d  SLING-4065 : Add notification when a job is added. Calculate event properties from path instead of reading the job
     new ab9e473  Move port allocation plugin before test plugin
     new 3583320  SLING-4048 : Avoid keeping jobs in memory. Fix job loading when cache is full and use a specific port range for integration tests to avoid port clashes
     new 54d59d8  [maven-release-plugin] prepare release org.apache.sling.event-3.4.0
     new 6bd472ef [maven-release-plugin] prepare for next development iteration
     new 213cedb  SLING-4048 : Avoid keeping jobs in memory. Readd full cache update
     new 6a13cc7  Minor code cleanup
     new ff41317  Pass http port configuration to pax framework, remove unused code, reduce logger statements to debug level.
     new 17ee3d4  Increase timeout to see whether the failing test cases are caused by very slow machines
     new 902d29b  Clean up logging
     new aed4288  SLING-4095 : Clean up code and logging statements
     new 4906ba2  SLING-4095 : Clean up code and logging statements
     new b8a9fdb  SLING-4096 : Jobs might stay unprocessed when topology changes
     new 41751e7  SLING-4095 : Clean up code and logging statements
     new d4f1c73  SLING-4095 : Clean up code and logging statements
     new cbe8832  SLING-4095 : Clean up code and logging statements
     new 872df01  SLING-4095 : Clean up code and logging statements
     new 10fb7ac  SLING-4095 : Clean up code and logging statements
     new 34a0d12  SLING-4095 : Clean up code and logging statements
     new 2c0e216  SLING-4095 : Clean up code and logging statements
     new 746d434  SLING-4096 : Jobs might stay unprocessed when topology changes
     new c644c93  SLING-4102 : Queue state information missing
     new 1dfeb90  SLING-4103 : Potential NPE when services get restarted
     new a036593  SLING-4103 : Potential NPE when services get restarted
     new d26d6c9  Use different port ranges for different jdk versions
     new c801861  SLING-4096 : Jobs might stay unprocessed when topology changes
     new 21aadbd  Use latest jcr resource release and remove workaround
     new d4bbbb0  IT: Remove tree in batches and sleep a second after tests
     new 2123a19  IT: Remove tree in batches and sleep a second after tests
     new 6d22330  [maven-release-plugin] prepare release org.apache.sling.event-3.4.2
     new 6450618  [maven-release-plugin] prepare for next development iteration
     new 757d7ca  Disable org.apache.felix.http.jetty to avoid opening a port, leads to conflicts
     new e6b4066  Remove superfluos test
     new 787374b  SLING-4122 : Folders might be created concurrently resulting in SNS nodes
     new e28943d  SLING-4122 : Folders might be created concurrently resulting in SNS nodes
     new 940c888  SLING-4122 : Folders might be created concurrently resulting in SNS nodes. Copy code from Sling's API to avoid relying on the latest API release
     new 9f08561  SLING-4129 : Remove obsolete functionality from web console
     new 29d28f6  SLING-4130 : Potential NPE on startup of queue manager
     new 6f7955e  [maven-release-plugin] prepare release org.apache.sling.event-3.4.4
     new eadfd1a  [maven-release-plugin] prepare for next development iteration
     new ed31cde  SLING-4133 : Allow job consumers to register for a topic and all subtopics
     new 6cf08dd  SLING-4134 : Add switch to surpress deprecation log entries
     new 21074e9  Correct setDaemon settings
     new a3ff41d  SLING-4133 : Allow job consumers to register for a topic and all subtopics
     new fb17169  Update pax exam to latest version
     new fad6719  Use old pax version for java 6, new version for java 7+
     new 98865dc  Check status of job manager instead of internal count
     new 9322478  Restrict search result
     new 32280f0  Code cleanup for test
     new b1b1435  Reduce sleep times in test
     new 80a40a7  SLING-4270 : Deactivate capabilities and listeners on deactivation
     new 92b4541  Try adding a sleep at the end of the test
     new 0709117  Use latest pax exam
     new fe3c18a  [maven-release-plugin] prepare release org.apache.sling.event-3.5.0
     new 84d1a86  [maven-release-plugin] prepare for next development iteration
     new c6aa72f  SLING-4418 : Round robin queue is handled as an ordered queue
     new 8594ec8  [maven-release-plugin] prepare release org.apache.sling.event-3.5.2
     new 9abf451  [maven-release-plugin] prepare for next development iteration
     new 40e7fcc  SLING-4480 : All queues are started on a restart
     new f6f17e3  [maven-release-plugin] prepare release org.apache.sling.event-3.5.4
     new b7526fd  [maven-release-plugin] prepare for next development iteration
     new 1603060  Potential fix for the failing test cases in Jenkins
     new 11dcdb3  SLING-4487 : Potential NPE in TimedEventSender
     new 1a7ed6a  SLING-4491 : Potential NPE when JobManagerConfiguration is deactivated
     new 094616e  Another try to fix the sporadic test failures with Java 8 : use a separate directory for each test run
     new dda97ef  SLING-4481 : Reduce the number of controller threads for queue
     new 1704387  SLING-4481 : Reduce the number of controller threads for queue
     new 47f8f38  SLING-4481 : Reduce the number of controller threads for queue
     new 970002b  SLING-4509 : Job creation fails if combination of topic and name is too long on OAK
     new b059535  SLING-4481 : Reduce the number of controller threads for queue
     new 96ffc7a  SLING-4481 : Reduce the number of controller threads for queue
     new 5271907  SLING-4481 : Reduce the number of controller threads for queue
     new 6a05ba1  SLING-4481 : Reduce the number of controller threads for queue
     new d107dd0  SLING-4481 : Reduce the number of controller threads for queue
     new da55e74  [maven-release-plugin] prepare release org.apache.sling.event-3.6.0
     new af2f441  [maven-release-plugin] prepare for next development iteration
     new d40ec87  SLING-4582 : Maintenance tasks should guard against NPE
     new 3dd4e68  SLING-4581 : Job notifications should only be sent out after the job resource has been updated
     new 936a3ba  SLING-4407 : introduce an audit-style logger to job handling
     new ab6e732  Add additional null check, relax negative time check
     new 91e03a5  SLING-4634 : Directly check if view is still current
     new c2b7aa2  SLING-4642 : Revisit statistics implementation
     new 80fbb68  Fix comment
     new 499d681  SLING-4642 : Revisit statistics implementation
     new a24f6e8  SLING-4582 : Maintenance tasks should guard against NPE
     new ece284c  SLING-4642 : Revisit statistics implementation
     new 1815ea8  SLING-4642 : Revisit statistics implementation
     new 564f493  SLING-4642 : Revisit statistics implementation
     new a6cb9c1  Exclude derby.log
     new 5189464  SLING-4679 : Perform periodically a full topic scan
     new 7139414  SLING-4678 : Background tasks not stopping when bundle is stopped
     new f37df78  SLING-4680 : Decouple scheduled jobs from observation
     new 6d0c0e5  SLING-4680 : Decouple scheduled jobs from observation
     new ea1f4ab  SLING-4680 : Decouple scheduled jobs from observation
     new 2712034  SLING-4683 : Ensure that topology change events are processed quickly
     new b161cf3  SLING-4683 : Ensure that topology change events are processed quickly
     new 2228c92  SLING-4679 : Perform periodically a full topic scan
     new 4d73cd1  SLING-4698 - Set parent.relativePath to empty for all modules
     new 9a1f241  SLING-4743 Event: Web Console Name Hints for Job Queue Configuration
     new bdd6c1a  SLING-4759 : Queue might be closed while job is waiting for retry
     new 57895a1  SLING-4759 : Queue might be closed while job is waiting for retry
     new f02ba73  SLING-4634 : Disable check again due to potential problems with the view implementation
     new 2a747ad  SLING-4762 : Latest job handling expects created date job property
     new 1625c4a  SLING-4763 Job Handling should access Job ValueMap in a typed way
     new b2cb091  SLING-4774 JobManager does not allow finding jobs for all topics
     new 1ebb9e3  Update to Sling Parent 23
     new 076e872  Remove superflous sling.java.version=6 as it's the default now
     new 67c4abe  [maven-release-plugin] prepare release org.apache.sling.event-3.7.0
     new e2efab0  [maven-release-plugin] prepare for next development iteration
     new 9fa8d5e  set parent version to 24 and add empty relativePath where missing
     new f6b34e7  SLING-4853: safeguard Utility.readJob against RuntimeExceptions that can occur when the underlying node is removed
     new 26fc41c  SLING-4874 : applying SLING-4874-patch.txt by Carsten
     new cbdfd8c  [maven-release-plugin] prepare release org.apache.sling.event-3.7.2
     new b827555  [maven-release-plugin] prepare for next development iteration
     new 517dec5  SLING-4645 Update Tika to 1.9
     new faf8306  SLING-4885 : creation of jobs via OSGI events stops working on Exceptions
     new 8dbba02  [maven-release-plugin] prepare release org.apache.sling.event-3.7.4
     new c71984e  [maven-release-plugin] prepare for next development iteration
     new 680a3ef  SLING-4933 : Dependency to inventory api should be optional
     new 36b01f8  SLING-4634 : Directly check if view is still current
     new dd8ce9b  SLING-4634 : Directly check if view is still current
     new 6ee6e33  SLING-4634 : Directly check if view is still current
     new ffe963b  Update the main reactor to parent 25
     new 68319a7  [maven-release-plugin] prepare release org.apache.sling.event-3.7.6
     new 0a89495  [maven-release-plugin] prepare for next development iteration
     new 032b9fd  SLING-5194 : Remove all deprecated features
     new e4efdae  Switch to java 7 as the base
     new 81ffae6  SLING-5194 : Remove all deprecated features
     new 0256e78  SLING-5320 : Optimize query for jobs by using configured path
     new 1c580c3  SLING-5319 : When loading a job distinguish between fatale and recoverable error
     new ee2ea9f  SLING-5315 : rescheduled failed jobs increment queued jobs counter
     new ec8b26a  Update javadoc
     new e47e46e  [maven-release-plugin] prepare release org.apache.sling.event-4.0.0
     new f06885b  [maven-release-plugin] prepare for next development iteration
     new bc280b5  Add comment
     new 4ce2075  Update javadocs
     new 231d297  Code cleanup - remove unused locks path
     new 747baf6  Remove unused constants
     new b97579e  Clean up test dependencies and wait for service registrations to propagate
     new a465d77  Clean up tests
     new 2ac5fc9  SLING-5406 : Optimize configuration change handling
     new 8369aab  SLING-5406 : Optimize configuration change handling
     new b187ca5  Test to see whether this fixes build problems on our CI
     new 2616e4d  Switch to parent pom 26
     new 940f817  Update it tests to latest releases
     new cb6ee27  Potential fix for sometimes failing on java 8
     new d74db44  Update to latest jackrabbit server and jcr bundles
     new 0a51740  SLING-5417 : Jobs are only partially persisted
     new 266eb15  SLING-5417 : Jobs are only partially persisted
     new 36b347a  SLING-5422 : Sling Event - HistoryCleanUpTask removes Jobs younger than configured. Apply tests from Christoph Nagel
     new c86b019  SLING-5467 : Sling Event - CleanUpTask wrongly marks folders
     new d2a0c1f  Use latch instead of polling
     new 1a768ab  Catch NPE from repository on cleanup
     new 1b83fe8  SLING-5560 : added 'startup.delay' config param to job manager with a default of 30sec, which helps avoiding unnecessary reassignment of jobs on a cluster restart - ITs adjusted to have a 1sec delay only
     new 49f0ce8  SLING-5560 : lowered those two warns to debug, of course
     new 9742b2f  [maven-release-plugin] prepare release org.apache.sling.event-4.0.2
     new c2967c4  [maven-release-plugin] prepare for next development iteration
     new fe988b5  SLING-5666 : Unscheduling a job should remove corresponding node
     new 899ef1b  SLING-5255 : Jobs: allow to configure queue.maxparallel in terms of % of number of CPU cores. Apply patch from Zygmunt Wiercioch
     new 16327ef  SLING-5666 : Unscheduling a job should remove corresponding node
     new 3babf5c  SLING-5805 : NPE in JobSchedulerImpl when shutting down instance
     new 22ffaa5  SLING-5805 add debug log message when handling scheduled job resource events
     new b286892  SLING-5805 : NPE in JobSchedulerImpl when shutting down instance
     new bb1322d  Fix typo in method name
     new 0392eac  Fix some javadocs
     new be01ef7  Fix javadoc package exclusion
     new cac70f0  Fix javadocs
     new 4c3c199  Documented the internals of Sling Event, with help from Carsten
     new 57dbd17  Update readme
     new 5be6ccf  SLING-5876 - make ChaosTest shorter and increase execution timeout
     new 0b0c693  [maven-release-plugin] prepare release org.apache.sling.event-4.1.0
     new ba0e6f2  [maven-release-plugin] prepare for next development iteration
     new ed11237  SLING-6013 clarify queue.maxparallel for ordered queues
     new a88592e  SLING-5998 : NewJobSender should move to new ResourceChangeListener API
     new acfd9f2  SLING-5998 : NewJobSender should move to new ResourceChangeListener API
     new d79f6dc  SLING-5998 : NewJobSender should move to new ResourceChangeListenerAPI
     new a56423b  SLING-5997 : JobManagerImpl should move to new ResourceChangeListener API
     new b0f1cfc  No need to enable resource event bridge
     new c56bec7  No need to increase queue size
     new 00635a0  SLING-6133 : Refactor Event Utility. Apply patch from Jörg Hoh
     new 6b23cfb  SLING-5232 : Remove loginAdministrative() usage from org.apache.sling.event
     new e9c56d1  [maven-release-plugin] prepare release org.apache.sling.event-4.2.0
     new 5548ed9  [maven-release-plugin] prepare for next development iteration
     new 95b023e  Update eventing to latest parent pom
     new 4050907  Remove obsolete java version property
     new bc27093  SLING-6286 : adding SERVICE_PID to main job queue to avoid webconsole link to be rendered as .../configMgr/null
     new bdf4960  SLING-5454 : Improve logging on startup of QueueManager and Job reassignment. Apply patch from Jörg Hoh
     new 281fda0  SLING-6496 Use ServiceUserMapped to ensure presence of service user mapping
     new 214bcff  [maven-release-plugin] prepare release org.apache.sling.event-4.2.2
     new 5322378  [maven-release-plugin] prepare for next development iteration
     new b54b4f0  use Sling Parent 30
     new 5ea0f2a  add missing Felix SCR annotations
     new 6191b69  use Felix SCR BndTools plugin (fixes build with Sling Parent 30)
     new 1e6ead0  SLING-6287 support maxparallel for main job queue to be -1 or between 0.0 and 1.0
     new ccf8af8  SLING-6739 : copied bundles/extensions/event into event/api and event/resources - done via svn cp to preserve history of both new parts
     new 85d5be2  SLING-6739 : split of sling.event to sling.event.api - initial adjustment in pom.xml, removed impl, resources and test
     new dfacad9  SLING-6739 : pom.xml cleanup to reflect its status as the new sling.event.api bundle - eg no dependencies needed, no ITs etc
     new 6958d68  SLING-6739 : README adjusted to reflect the new status of this API bundle
     new eda91cc  SLING-6739 : removed unnecessary properties
     new 3bd9a3c  SLING-6739 : site.jira.version.id set to version Event API 1.0.0
     new e29a01f  SLING-6739 : port-java8 and surefire-plugin removed
     new e12cdc7  [maven-release-plugin] prepare release org.apache.sling.event.api-1.0.0
     new ebe7dcb  [maven-release-plugin] copy for tag org.apache.sling.event.api-1.0.0

The 888 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


-- 
To stop receiving notification emails like this one, please contact
['"commits@sling.apache.org" <co...@sling.apache.org>'].