You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@sling.apache.org by bu...@apache.org on 2012/05/22 10:25:36 UTC

svn commit: r818658 [2/23] - in /websites/staging/sling/trunk/content: ./ tutorials-how-tos/

Modified: websites/staging/sling/trunk/content/apache-sling-eventing-and-job-handling.html
==============================================================================
--- websites/staging/sling/trunk/content/apache-sling-eventing-and-job-handling.html (original)
+++ websites/staging/sling/trunk/content/apache-sling-eventing-and-job-handling.html Tue May 22 08:25:32 2012
@@ -83,464 +83,166 @@
       </div>
       <h1>Apache Sling Eventing and Job Handling</h1>
       <p><em>NOTE: This documentation is work in progress!</em></p>
-<p><a name="ApacheSlingEventingandJobHandling-Overview"></a></p>
 <h2 id="overview">Overview</h2>
-<p>The Apache Sling Event Support bundle provides interesting services for
-advanced event handling and job processing. While this bundle leverages the
-OSGi EventAdmin, it provides a very powerful support for so called jobs: a
-job is a task which has to be performed by a component - the Sling job
-handling ensures that exactly one component performs this task.</p>
+<p>The Apache Sling Event Support bundle provides interesting services for advanced event handling and job processing. While this bundle leverages the OSGi EventAdmin, it provides a very powerful support for so called jobs: a job is a task which has to be performed by a component - the Sling job handling ensures that exactly one component performs this task.</p>
 <p>To get some hands on code, you can refer to the following tutorials:
-<em> <a href="how-to-manage-events-in-sling.html">How to Manage Events in Sling</a>
-</em> <a href="scheduler-service-(commons-scheduler).html">Scheduler Service (commons scheduler)</a></p>
+<em> <a href="/tutorials-how-tos/how-to-manage-events-in-sling.html">How to Manage Events in Sling</a>
+</em> <a href="/scheduler-service-commons-scheduler.html">Scheduler Service (commons scheduler)</a></p>
 <p>The Sling Event Supports adds the following services:
-<em> <a href="#jobs.html">Jobs</a>
-</em> <a href="#distributed.html">Distributed Events</a>
-* <a href="#timed.html">Scheduled Events</a></p>
-<p>{anchor:jobs}
-<a name="ApacheSlingEventingandJobHandling-Jobs(GuaranteeofProcessing)"></a></p>
+<em> <a href="">Jobs</a>
+</em> <a href="">Distributed Events</a>
+* <a href="">Scheduled Events</a></p>
+<p>{anchor:jobs}</p>
 <h2 id="jobs-guarantee-of-processing">Jobs (Guarantee of Processing)</h2>
-<p>In general, the eventing mechanism (OSGi EventAdmin) has no knowledge about
-the contents of an event. Therefore, it can't decide if an event is
-important and should be processed by someone. As the event mechanism is a
-"fire event and forget about it" algorithm, there is no way for an event
-admin to tell if someone has really processed the event. Processing of an
-event could fail, the server or bundle could be stopped etc.</p>
-<p>On the other hand, there are use cases where the guarantee of processing a
-job is a must and usually this comes with the requirement of processing
-this job exactly once. Typical examples are sending notification emails (or
-sms) or post processing of content (like thumbnail generation of images or
-documents).</p>
-<p>The Sling Event Support adds the notion of a job to the OSGi EventAdmin. A
-job is a special OSGi event that someone has to process (do the job). The
-job event has a special topic <em>org/apache/sling/event/job</em> to indicate that
-the event contains a job. These job events are consumed by the Sling Job
-Handler - it ensures that someone does the job! To support different jobs
-and different processors of such jobs, the real topic of the event is
-stored in the <em>event.job.topic</em> property of the original event. When a job
-event (event with the topic <em>org/apache/sling/event/job</em>) is received, a
-new event with the topic from the property <em>event.job.topic</em> is fired
-(Firing this event comes of course with a set of rules and constraints
-explained below).</p>
-<p>In order to distinguish a job which occured twice and a job which is
-generated "at the same time" on several nodes, each job can be uniquely
-identified by its topic (property <em>event.job.topic</em>) and an optional job
-name, the <em>event.job.id</em> property. It is up to the client creating the
-event to ensure that the <em>event.job.id</em> property is unqiue <em>and</em> identical
-on all application nodes. If the job name is not provided for the job, then
-it is up to the client to ensure that the job event is only fired once.
-Usually for jobs generated based on user interaction, a unique job name is
-not required as the job is only created through the user interaction.</p>
-<p><a name="ApacheSlingEventingandJobHandling-JobProcessors"></a></p>
+<p>In general, the eventing mechanism (OSGi EventAdmin) has no knowledge about the contents of an event. Therefore, it can't decide if an event is important and should be processed by someone. As the event mechanism is a "fire event and forget about it" algorithm, there is no way for an event admin to tell if someone has really processed the event. Processing of an event could fail, the server or bundle could be stopped etc.</p>
+<p>On the other hand, there are use cases where the guarantee of processing a job is a must and usually this comes with the requirement of processing this job exactly once. Typical examples are sending notification emails (or sms) or post processing of content (like thumbnail generation of images or documents).</p>
+<p>The Sling Event Support adds the notion of a job to the OSGi EventAdmin. A job is a special OSGi event that someone has to process (do the job). The job event has a special topic <em>org/apache/sling/event/job</em> to indicate that the event contains a job. These job events are consumed by the Sling Job Handler - it ensures that someone does the job! To support different jobs and different processors of such jobs, the real topic of the event is stored in the <em>event.job.topic</em> property of the original event. When a job event (event with the topic <em>org/apache/sling/event/job</em>) is received, a new event with the topic from the property <em>event.job.topic</em> is fired (Firing this event comes of course with a set of rules and constraints explained below).</p>
+<p>In order to distinguish a job which occured twice and a job which is generated "at the same time" on several nodes, each job can be uniquely identified by its topic (property <em>event.job.topic</em>) and an optional job name, the <em>event.job.id</em> property. It is up to the client creating the event to ensure that the <em>event.job.id</em> property is unqiue <em>and</em> identical on all application nodes. If the job name is not provided for the job, then it is up to the client to ensure that the job event is only fired once. Usually for jobs generated based on user interaction, a unique job name is not required as the job is only created through the user interaction.</p>
 <h3 id="job-processors">Job Processors</h3>
-<p>A job processor is a service consuming and processing a job. It listens for
-OSGi events with the job topic. The OSGi EventAdmin usually comes with a
-timeout for event handlers. An event handler must consume an OSGi event as
-fast as possible otherwise the handler might get a timeout and get
-blacklisted. Therefore a job processor should never directly process the
-job in the event handler method, but do this async.</p>
-<p>In addition the Sling Job Handler needs to get notified if someone is
-processing a job and when someone has finished processing this job.</p>
-<p>To make implementing such a job processor easier, there is the <em>JobUtil</em>
-utility class along with the <em>JobProcessor</em> interface. The <em>JobUtil</em> class
-has a helper method for this: <em>processJob(Event, JobProcessor)</em>. The job
-processor must implement the <em>JobProcessor</em> interface which consists of a
-single <em>process(Event)</em> method. When the event handler receives a job event
-through the OSGi EventAdmin, it calls <em>JobUtil.processJob(event, this)</em> and
-returns. This utility method takes care to notify the Sling Job Handler
-that someone is processing the job. Then the <em>process(Event)</em> method of the
-job processor is called in the background and when it returns, the Sling
-Job Handler is notified that the job is completed (or processing failed).</p>
-<p>If the job processor wants to do the background processing by itself or
-does not need background processing at all, it must signal starting and
-completition of the job by call <em>JobUtil.acknowledgeJob(Event),
-_JobUtil.finishedJob(event)</em> or _JobUtil.rescheduleJob(Event).</p>
-<p><a name="ApacheSlingEventingandJobHandling-ProcessingofJobs"></a></p>
+<p>A job processor is a service consuming and processing a job. It listens for OSGi events with the job topic. The OSGi EventAdmin usually comes with a timeout for event handlers. An event handler must consume an OSGi event as fast as possible otherwise the handler might get a timeout and get blacklisted. Therefore a job processor should never directly process the job in the event handler method, but do this async.</p>
+<p>In addition the Sling Job Handler needs to get notified if someone is processing a job and when someone has finished processing this job.</p>
+<p>To make implementing such a job processor easier, there is the <em>JobUtil</em> utility class along with the <em>JobProcessor</em> interface. The <em>JobUtil</em> class has a helper method for this: <em>processJob(Event, JobProcessor)</em>. The job processor must implement the <em>JobProcessor</em> interface which consists of a single <em>process(Event)</em> method. When the event handler receives a job event through the OSGi EventAdmin, it calls <em>JobUtil.processJob(event, this)</em> and returns. This utility method takes care to notify the Sling Job Handler that someone is processing the job. Then the <em>process(Event)</em> method of the job processor is called in the background and when it returns, the Sling Job Handler is notified that the job is completed (or processing failed).</p>
+<p>If the job processor wants to do the background processing by itself or does not need background processing at all, it must signal starting and completition of the job by call <em>JobUtil.acknowledgeJob(Event), </em>JobUtil.finishedJob(event)<em> or </em>JobUtil.rescheduleJob(Event).</p>
 <h3 id="processing-of-jobs">Processing of Jobs</h3>
-<p>Incoming jobs are first persisted in the repository (for failover etc.) and
-then a job is put into a processing queue. There are different types of
-queues defining how the jobs are processed (one after the other, in
-parallel etc.).</p>
-<p>For managing queues, the Sling Job Handler uses the OSGi ConfigAdmin - it
-is possible to configure one or more queue configurations through the
-ConfigAdmin. One way of creating and configuring such configurations is the
-Apache Felix WebConsole.</p>
-<p><a name="ApacheSlingEventingandJobHandling-QueueConfigurations"></a></p>
+<p>Incoming jobs are first persisted in the repository (for failover etc.) and then a job is put into a processing queue. There are different types of queues defining how the jobs are processed (one after the other, in parallel etc.).</p>
+<p>For managing queues, the Sling Job Handler uses the OSGi ConfigAdmin - it is possible to configure one or more queue configurations through the ConfigAdmin. One way of creating and configuring such configurations is the Apache Felix WebConsole.</p>
 <h4 id="queue-configurations">Queue Configurations</h4>
 <p>A queue configuration can have the following properties:</p>
-<table>
-<tr><td> *Property Name*     </td><td> *Description* </td></tr>
-<tr><td> _queue.name_        </td><td> The name of the queue. If matching is used for
-topics, the value \{0\} can be used for replacing the matched part. </td></tr>
-<tr><td> _queue.type_        </td><td> The type of the queue: ORDERED, UNORDERED,
-TOPIC_ROUND_ROBIN, IGNORE, DROP </td></tr>
-<tr><td> _queue.topics_       </td><td> A list of topics processed by this queue. Either
-the concrete topic is specified or the topic string ends with /* or /. If a
-star is at the end all topics and sub topics match, with a dot only direct
-sub topics match. </td></tr>
-<tr><td> _queue.maxparallel_        </td><td> How many jobs can be processed in parallel?
--1 for number of processors.</td></tr>
-<tr><td> _queue.retries_    </td><td> How often should the job be retried. -1 for
-endless retries. </td></tr>
-<tr><td> _queue.retrydelay_    </td><td> The waiting time in milliseconds between job
-retries. </td></tr>
-<tr><td> _queue.priority_    </td><td> The thread priority: NORM, MIN, or MAX </td></tr>
-<tr><td> _queue.runlocal_    </td><td> Should the jobs only be processed on the cluster
-node they have been created? </td></tr>
-<tr><td> _queue.applicationids_       </td><td> Optional list of application (cluster
-node) ids. If configured, these jobs are only processed on this application
-node.</td></tr>
-<tr><td> _service.ranking_ </td><td> A ranking for this configuration.</td></tr>
-</table>
-
-<p>The configurations are processed in order of their service ranking. The
-first matching queue configuration is used for the job.</p>
-<p><a name="ApacheSlingEventingandJobHandling-OrderedQueues"></a></p>
+<p>| <em>Property Name</em>     | <em>Description</em> |
+| <em>queue.name</em>       | The name of the queue. If matching is used for topics, the value {0} can be used for replacing the matched part. |
+| <em>queue.type</em>       | The type of the queue: ORDERED, UNORDERED, TOPIC<em>ROUND</em>ROBIN, IGNORE, DROP |
+| <em>queue.topics</em>       | A list of topics processed by this queue. Either the concrete topic is specified or the topic string ends with /<em> or /. If a star is at the end all topics and sub topics match, with a dot only direct sub topics match. |
+| </em>queue.maxparallel<em>       | How many jobs can be processed in parallel? -1 for number of processors.|
+| </em>queue.retries<em>       | How often should the job be retried. -1 for endless retries. |
+| </em>queue.retrydelay<em>       | The waiting time in milliseconds between job retries. |
+| </em>queue.priority<em>       | The thread priority: NORM, MIN, or MAX |
+| </em>queue.runlocal<em>       | Should the jobs only be processed on the cluster node they have been created? |
+| </em>queue.applicationids<em>       | Optional list of application (cluster node) ids. If configured, these jobs are only processed on this application node.|
+| </em>service.ranking* | A ranking for this configuration.|</p>
+<p>The configurations are processed in order of their service ranking. The first matching queue configuration is used for the job.</p>
 <h4 id="ordered-queues">Ordered Queues</h4>
 <p>An ordered queue processes one job after the other.</p>
-<p><a name="ApacheSlingEventingandJobHandling-UnorderedQueues"></a></p>
 <h4 id="unordered-queues">Unordered Queues</h4>
 <p>Unordered queues process jobs in parallel.</p>
-<p><a name="ApacheSlingEventingandJobHandling-Topic-Round-RobinQueues"></a></p>
 <h4 id="topic-round-robin-queues">Topic-Round-Robin Queues</h4>
-<p>The jobs are processed in parallel. Scheduling of the jobs is based on the
-topic of the jobs. These are started by doing round-robin on the available
-topics.</p>
-<p><a name="ApacheSlingEventingandJobHandling-IgnoringQueues"></a></p>
+<p>The jobs are processed in parallel. Scheduling of the jobs is based on the topic of the jobs. These are started by doing round-robin on the available topics.</p>
 <h4 id="ignoring-queues">Ignoring Queues</h4>
-<p>A queue of type <em>ignoring</em> ignores this job. The job is persisted but not
-processed. This can be used to delay processing of some jobs. With a
-changed configuration and a restart of the Sling Job Handler the ignored
-jobs can be processed at a later time.</p>
-<p><a name="ApacheSlingEventingandJobHandling-DroppingQueues"></a></p>
+<p>A queue of type <em>ignoring</em> ignores this job. The job is persisted but not processed. This can be used to delay processing of some jobs. With a changed configuration and a restart of the Sling Job Handler the ignored jobs can be processed at a later time.</p>
 <h4 id="dropping-queues">Dropping Queues</h4>
-<p>A queue of type <em>drop</em> is dropping a job - which means it is not processed
-at all and directly discarded.</p>
-<p><a name="ApacheSlingEventingandJobHandling-Persistence"></a></p>
+<p>A queue of type <em>drop</em> is dropping a job - which means it is not processed at all and directly discarded.</p>
 <h3 id="persistence">Persistence</h3>
-<p>The job event handler listens for all job events (all events with the topic
-<em>org/apache/sling/event/job</em>) and will as a first step persist those events
-in the JCR repository. All job events are stored in a tree under the job
-root node <em>/var/eventing/jobs</em>. Persisting the job ensures proper handling
-in a clustered environment and allows failover handling after a bundle stop
-or server restart. Once a job has been processed by someone, the job will
-be removed from the repository.</p>
-<p>When the job event listener tries to write a job into the repository it
-will check if the repository already contains a job with the given topic
-<em>event.job.topic</em> and job name (property <em>event.job.id</em>). If the event has
-already been written by some other application node, it's not written
-again.</p>
+<p>The job event handler listens for all job events (all events with the topic <em>org/apache/sling/event/job</em>) and will as a first step persist those events in the JCR repository. All job events are stored in a tree under the job root node <em>/var/eventing/jobs</em>. Persisting the job ensures proper handling in a clustered environment and allows failover handling after a bundle stop or server restart. Once a job has been processed by someone, the job will be removed from the repository.</p>
+<p>When the job event listener tries to write a job into the repository it will check if the repository already contains a job with the given topic <em>event.job.topic</em> and job name (property <em>event.job.id</em>). If the event has already been written by some other application node, it's not written again.</p>
 <p>Each job is stored as a separate node with the following properties:
-<table>
-<tr><td> <em>Property Name</em>     </td><td> <em>Description</em> </td></tr>
-<tr><td> <em>event:topic</em>       </td><td> The topic of the job </td></tr>
-<tr><td> <em>event:id</em>       </td><td> The unique identifier of this job (optional).
-</tr>
-<tr><td> <em>event:created</em>     </td><td> The date and time when the event has been created
-(stored in the repository)
-</tr>
-<tr><td> <em>event:application</em> </td><td> The identifier of the node where the job was
-created </td></tr>
-<tr><td> <em>event:properties</em>  </td><td> Serialized properties </td></tr>
-<tr><td> <em>event:finished</em>    </td><td> The date and time when the job has been finished </td></tr>
-<tr><td> <em>event:processor</em>   </td><td> The identifier of the node which processed the job
-(after successful processing) </td></tr>
-</table></p>
-<p>The failover of an application node is accomplished by locking. If a job is
-locked in the repository a session scoped lock is used. If this application
-node dies, the lock dies as well. Each application node observes the JCR
-locking properties and therefore gets aware of unlocked event nodes with
-the active flag set to true. If an application node finds such a node, it
-locks it, updates the <em>event:application</em> information and processes it
-accordingly. In this case the event gets the additional property
-<em>org/apache/sling/job/retry</em>. </p>
-<p>Each application is periodically removing old jobs from the repository
-(using the scheduler).</p>
-<p><a name="ApacheSlingEventingandJobHandling-DistributionofJobs"></a></p>
+| <em>Property Name</em>     | <em>Description</em> |
+| <em>event:topic</em>       | The topic of the job |
+| <em>event:id</em>          | The unique identifier of this job (optional).
+| <em>event:created</em>     | The date and time when the event has been created (stored in the repository)
+| <em>event:application</em> | The identifier of the node where the job was created |
+| <em>event:properties</em>  | Serialized properties |
+| <em>event:finished</em>    | The date and time when the job has been finished |
+| <em>event:processor</em>   | The identifier of the node which processed the job (after successful processing) |</p>
+<p>The failover of an application node is accomplished by locking. If a job is locked in the repository a session scoped lock is used. If this application node dies, the lock dies as well. Each application node observes the JCR locking properties and therefore gets aware of unlocked event nodes with the active flag set to true. If an application node finds such a node, it locks it, updates the <em>event:application</em> information and processes it accordingly. In this case the event gets the additional property <em>org/apache/sling/job/retry</em>. </p>
+<p>Each application is periodically removing old jobs from the repository (using the scheduler).</p>
 <h3 id="distribution-of-jobs">Distribution of Jobs</h3>
-<p>A job event is an event like any other. Therefore it is up to the client
-generating the event to decide if the event should be distributed. If the
-event is distributed, it will be distributed with a set <em>event.application</em>
-on the remote nodes. If the job event handler receives a job with the
-<em>event.application</em> property set, it will not try to write it into the
-repository. It will just broadcast this event asynchronously as a ~FYI
-event.</p>
-<p>If a job event is created simultanously on all application nodes, the event
-will not be distributed. The application node that actually has the lock on
-the stored job in the repository will clear the <em>event.application</em> when
-sending the event locally. All other application nodes will use the
-<em>event.application</em> stored in the repository when broadcasting the event
-locally.</p>
-<p><a name="ApacheSlingEventingandJobHandling-UsagePatterns"></a></p>
+<p>A job event is an event like any other. Therefore it is up to the client generating the event to decide if the event should be distributed. If the event is distributed, it will be distributed with a set <em>event.application</em> on the remote nodes. If the job event handler receives a job with the <em>event.application</em> property set, it will not try to write it into the repository. It will just broadcast this event asynchronously as a ~FYI event.</p>
+<p>If a job event is created simultanously on all application nodes, the event will not be distributed. The application node that actually has the lock on the stored job in the repository will clear the <em>event.application</em> when sending the event locally. All other application nodes will use the <em>event.application</em> stored in the repository when broadcasting the event locally.</p>
 <h2 id="usage-patterns">Usage Patterns</h2>
-<p>Based on some usage patterns, we discuss the functionality of the eventing
-mechanism.</p>
-<p><a name="ApacheSlingEventingandJobHandling-SendingUserGeneratedEvents"></a></p>
+<p>Based on some usage patterns, we discuss the functionality of the eventing mechanism.</p>
 <h3 id="sending-user-generated-events">Sending User Generated Events</h3>
-<p>If a user action results in an event, the event is only created on one
-single node in the cluster. The event object is generated and delivered to
-the OSGi event admin. If the <em>event.distribute</em> is not explicitly set, the
-event is only distributed localled.</p>
-<p>If the <em>event.distribute</em> is the, the cluster event handler will write the
-event into the repository. All nodes in the cluster observe the repository
-area where all events are stored. If a new event is written into that area,
-each application node will get notified. It will create the event based on
-the information in the repository, clear the <em>event.distribute</em> and publish
-the event.</p>
+<p>If a user action results in an event, the event is only created on one single node in the cluster. The event object is generated and delivered to the OSGi event admin. If the <em>event.distribute</em> is not explicitly set, the event is only distributed localled.</p>
+<p>If the <em>event.distribute</em> is the, the cluster event handler will write the event into the repository. All nodes in the cluster observe the repository area where all events are stored. If a new event is written into that area, each application node will get notified. It will create the event based on the information in the repository, clear the <em>event.distribute</em> and publish the event.</p>
 <p>The flow can be described as follows:
-1. Client code generates event using OSGi API, if the <em>event.distribute</em>
-should be set, it is using the ~EventUtil.
+1. Client code generates event using OSGi API, if the <em>event.distribute</em> should be set, it is using the ~EventUtil.
 1. Client code sends the event to the (local) event admin.
 1. Event admin delivers the event locally.
-1. Clustering event handler receives the event if <em>event.distribute</em> is
-present
-1. # Event handler adds <em>event.application</em> and writes the event to the
-repository
-1. # Remote repository observers get notified through JCR observation about
-the new event. They distribute the event locally with the
-<em>event.application</em> (from the node where the event occured first) and
-cleared <em>event.distribute</em>.</p>
-<p><a name="ApacheSlingEventingandJobHandling-ProcessingJCREvents"></a></p>
+1. Clustering event handler receives the event if <em>event.distribute</em> is present
+1. # Event handler adds <em>event.application</em> and writes the event to the repository
+1. # Remote repository observers get notified through JCR observation about the new event. They distribute the event locally with the <em>event.application</em> (from the node where the event occured first) and cleared <em>event.distribute</em>.</p>
 <h3 id="processing-jcr-events">Processing JCR Events</h3>
-<p>JCR events are environment generated events and therefore are sent by the
-repository to each node in the cluster. In general, it is advisable to not
-built the application on the low level repository events but to use
-application events. Therefore the observer of the JCR event should create
-an OSGi event based on the changes in the repository. A decision has to be
-made if the event should be a job or a plain event.</p>
+<p>JCR events are environment generated events and therefore are sent by the repository to each node in the cluster. In general, it is advisable to not built the application on the low level repository events but to use application events. Therefore the observer of the JCR event should create an OSGi event based on the changes in the repository. A decision has to be made if the event should be a job or a plain event.</p>
 <p>The flow can be described as follows:
 1. Client registers for JCR observation
 1. JCR notifies the client for changes
-1. Client generates OSGi event based on the JCR events (the
-<em>event.distribute</em> will not be set), it decides if it sends this event as a
-job.
+1. Client generates OSGi event based on the JCR events (the <em>event.distribute</em> will not be set), it decides if it sends this event as a job.
 1. Client code sends the event to the (local) event admin
 1. Event admin publishes the event locally
-1. The distribution event handler does not set see the event as the
-<em>event.distribute</em> is not set.
+1. The distribution event handler does not set see the event as the <em>event.distribute</em> is not set.
 1. The job event handler gets the event if it has the job topic
-1. # The job event handler adds the <em>event.application</em> property and tries to
-write the job to the repository
-1. ## If no job with the topic and <em>id</em> property is in the repository, the
-event will be written and locked.
+1. # The job event handler adds the <em>event.application</em> property and tries to write the job to the repository
+1. ## If no job with the topic and <em>id</em> property is in the repository, the event will be written and locked.
 1. ## If an event with the topic and <em>id</em> property is in the repository then:
-1. ### If the <em>event.application</em> equals the current application node, the
-event is set to active (<em>event:active</em>) in the repository again and locked
-1. ### If the <em>event.application</em> does not equal the current application
-node, the event is not distributed locally.
-1. ## If the job could be locked in the repository, the job event handler
-delivers the job locally and synchronously and it unlocks the job and sets
-<em>event:active</em> to false afterwards.</p>
-<p><a name="ApacheSlingEventingandJobHandling-SendingScheduledEvents"></a></p>
+1. ### If the <em>event.application</em> equals the current application node, the event is set to active (<em>event:active</em>) in the repository again and locked
+1. ### If the <em>event.application</em> does not equal the current application node, the event is not distributed locally.
+1. ## If the job could be locked in the repository, the job event handler delivers the job locally and synchronously and it unlocks the job and sets <em>event:active</em> to false afterwards.</p>
 <h3 id="sending-scheduled-events">Sending Scheduled Events</h3>
-<p>Scheduled events are OSGi events that have been created by the environemnt.
-They are generated on each application node of the cluster through an own
-scheduler instance. Sending these events works the same as sending events
-based on JCR events (see above).</p>
-<p>In most use cases a scheduler will send job events to ensure that exactly
-one application node is processing the event.</p>
-<p><a name="ApacheSlingEventingandJobHandling-ReceivingOSGiEvents"></a></p>
+<p>Scheduled events are OSGi events that have been created by the environemnt. They are generated on each application node of the cluster through an own scheduler instance. Sending these events works the same as sending events based on JCR events (see above).</p>
+<p>In most use cases a scheduler will send job events to ensure that exactly one application node is processing the event.</p>
 <h3 id="receiving-osgi-events">Receiving OSGi Events</h3>
-<p>If you want to receive OSGi events, you can just follow the specification:
-receive it via a custom event handler which is registered on bundle start -
-a filter can be specified as a configuration property of the handler. </p>
-<p>As we follow the principle of distributing each event to every registered
-handler, the handler has to decide if it will process the event. In order
-to avoid multiple processing of this event in a clustered environment, the
-event handler should check the <em>event.application</em> property. If it is not
-set, it's a local event and the handler should process the event. If the
-<em>event.application</em> is set, it's a remote event and the handler should not
-process the event. This is a general rule of thumb - however, it's up to
-the handler to make its decision either on <em>event.application</em> or any other
-information.</p>
-<p>It is advisable to perform the local event check even in a non clustered
-environment as it makes the migration to a cluster later on much easier and
-there is nearly no performance overhead caused by the check.</p>
-<p>The ~EventUtil class provides an utility method <em>isLocalEvent(Event)</em> which
-checks the existance of the <em>event.application</em> property and returns <em>true</em>
-if it is absend.</p>
-<p>{anchor:distributed}
-<a name="ApacheSlingEventingandJobHandling-DistributedEvents"></a></p>
+<p>If you want to receive OSGi events, you can just follow the specification: receive it via a custom event handler which is registered on bundle start - a filter can be specified as a configuration property of the handler. </p>
+<p>As we follow the principle of distributing each event to every registered handler, the handler has to decide if it will process the event. In order to avoid multiple processing of this event in a clustered environment, the event handler should check the <em>event.application</em> property. If it is not set, it's a local event and the handler should process the event. If the <em>event.application</em> is set, it's a remote event and the handler should not process the event. This is a general rule of thumb - however, it's up to the handler to make its decision either on <em>event.application</em> or any other information.</p>
+<p>It is advisable to perform the local event check even in a non clustered environment as it makes the migration to a cluster later on much easier and there is nearly no performance overhead caused by the check.</p>
+<p>The ~EventUtil class provides an utility method <em>isLocalEvent(Event)</em> which checks the existance of the <em>event.application</em> property and returns <em>true</em> if it is absend.</p>
+<p>{anchor:distributed}</p>
 <h2 id="distributed-events">Distributed Events</h2>
-<p>In addition to the job handling, the Sling Event support adds handling for
-distributed events. A distributed event is an OSGi event which is sent
-across JVM boundaries to a different VM. A potential use case is to
-broadcast information in a clustered environment.</p>
-<p><a name="ApacheSlingEventingandJobHandling-SourcesofEvents"></a></p>
+<p>In addition to the job handling, the Sling Event support adds handling for distributed events. A distributed event is an OSGi event which is sent across JVM boundaries to a different VM. A potential use case is to broadcast information in a clustered environment.</p>
 <h3 id="sources-of-events">Sources of Events</h3>
-<p>When it comes to application based on Sling, there is a variety of sources
-from which OSGi events can be send:
+<p>When it comes to application based on Sling, there is a variety of sources from which OSGi events can be send:
 <em> JCR observation events
 </em> Application generated events
 <em> Events from messaging systems (~JMS)
 </em> "External events"</p>
-<p>The events can eiter be generated inside a current user context, e.g. when
-the user performs an action through the UI, or they can be out of a user
-context, e.g. for schedulded events. This leads to different weights of
-events.</p>
-<p><a name="ApacheSlingEventingandJobHandling-WeightsofEvents"></a></p>
+<p>The events can eiter be generated inside a current user context, e.g. when the user performs an action through the UI, or they can be out of a user context, e.g. for schedulded events. This leads to different weights of events.</p>
 <h3 id="weights-of-events">Weights of Events</h3>
-<p>We can distinguish two different weights of events, depending how they are
-distributed in a clustered environment:</p>
+<p>We can distinguish two different weights of events, depending how they are distributed in a clustered environment:</p>
 <ul>
-<li>User generated events - these events are generated directly by some user
-action and are therefore started on one single node.</li>
-<li>Environment generated events (JCR events, scheduler events etc.) - these
-events are generated "simultanously" on all nodes.</li>
+<li>User generated events - these events are generated directly by some user action and are therefore started on one single node.</li>
+<li>Environment generated events (JCR events, scheduler events etc.) - these events are generated "simultanously" on all nodes.</li>
 </ul>
-<p>External events, like incoming JMS events etc. might fall either into the
-first or the second category. The receiver of such events must have the
-knowledge about the weight of the event.</p>
-<p><a name="ApacheSlingEventingandJobHandling-BasicPrinciples"></a></p>
+<p>External events, like incoming JMS events etc. might fall either into the first or the second category. The receiver of such events must have the knowledge about the weight of the event.</p>
 <h3 id="basic-principles">Basic Principles</h3>
-<p>The foundation of the distributed event mechanism is to distribute each
-event to every node in a clustered environment. The event distribution
-mechanism has no knowledge about the intent of the event and therefore is
-not able to make delivery decisions by itself. It is up to the sender to
-decide what should happen, however the sender must explicitly declare an
-event to be distributed. There are exceptions to "distributing everything
-to everywhere" as for example framework related events (bundle stopped,
-installed etc.) should not be distributed.</p>
-<p>The event mechanism will provide additional functionality making it easier
-for event receivers to decide if they should process an event. The event
-receiver can determine if the event is a local event or comming from a
-remote application node. Therefore a general rule of thumb is to process
-events only if they're local and just regard remote events as a FYI.</p>
-<p>The event mechanism is an <em>event</em> mechanism which should not be confused
-with a <em>messaging</em> mechanism. Events are received by the event mechanism
-and distributed to registered listeners. Concepts like durable listeners,
-guarantee of processing etc. are not part of the event mechanism itself.
-However, there is additional support for such things, like job handling.</p>
-<p>The application should try to use application events instead of low level
-JCR events whereever possible. Therefore a bridging between JCR events and
-the event mechanism is required. However, a general "automatic" mapping
-will not be provided. It is up to the application to develop such a mapping
-on a per use case base. There might be some support to make the mapping
-easier.</p>
-<p>The event handling should be made as transparent to the developer as
-possible. Therefore the additional code for a developer to make the
-eventing working in a clustered environment etc. should be kept to a
-minimum (which will hopefully reduce possible user errors).</p>
-<p><a name="ApacheSlingEventingandJobHandling-DistributedEvents"></a></p>
+<p>The foundation of the distributed event mechanism is to distribute each event to every node in a clustered environment. The event distribution mechanism has no knowledge about the intent of the event and therefore is not able to make delivery decisions by itself. It is up to the sender to decide what should happen, however the sender must explicitly declare an event to be distributed. There are exceptions to "distributing everything to everywhere" as for example framework related events (bundle stopped, installed etc.) should not be distributed.</p>
+<p>The event mechanism will provide additional functionality making it easier for event receivers to decide if they should process an event. The event receiver can determine if the event is a local event or comming from a remote application node. Therefore a general rule of thumb is to process events only if they're local and just regard remote events as a FYI.</p>
+<p>The event mechanism is an <em>event</em> mechanism which should not be confused with a <em>messaging</em> mechanism. Events are received by the event mechanism and distributed to registered listeners. Concepts like durable listeners, guarantee of processing etc. are not part of the event mechanism itself. However, there is additional support for such things, like job handling.</p>
+<p>The application should try to use application events instead of low level JCR events whereever possible. Therefore a bridging between JCR events and the event mechanism is required. However, a general "automatic" mapping will not be provided. It is up to the application to develop such a mapping on a per use case base. There might be some support to make the mapping easier.</p>
+<p>The event handling should be made as transparent to the developer as possible. Therefore the additional code for a developer to make the eventing working in a clustered environment etc. should be kept to a minimum (which will hopefully reduce possible user errors).</p>
 <h3 id="distributed-events_1">Distributed Events</h3>
-<p>For distributed events two properties are defined (check the <em>EventUtil</em>
-class):
-<em> <em>event.distribute</em> - this flag is set by the sender of an event to give a
-hint if the event should be distributed across instances. For example JCR
-observation based events are already distributed on all instances, so there
-is no further need to distribute them. If the flag is present, the event
-will be distributed. The value has currently no meaning, however the
-EventUtil method should be used to add this property. If the flag is absent
-the event is distributed locally only.</em> <em>event.application</em> - An identifier for the current application node in
-the cluster. This information will be used to detect if an event has been
-created on different nodes. If the event has been created on the same node,
-the <em>event.application</em> is missing, if it is a remote event, the
-<em>event.application</em> contains the ID of the node, the event has been
-initially created. Use the <em>EventUtil.isLocal(Event)</em> method to detect if
-the event is a local or a distributed event.</p>
-<p>While the <em>event.distribute</em> must be set by the sender of an event (if the
-event should be distributed), the <em>event.application</em> property is
-maintained by the event mechanism. Therefore a client sending an event
-should <em>never</em> set this information by itself. This will confuse the local
-event handlers and result in unexpected behaviour. On remote events the
-<em>event.application</em> is set by the event distribution mechanism.</p>
-<p><a name="ApacheSlingEventingandJobHandling-EventDistributionAcrossApplicationNodes(Cluster)"></a></p>
+<p>For distributed events two properties are defined (check the <em>EventUtil</em> class):
+<em> </em>event.distribute<em> - this flag is set by the sender of an event to give a hint if the event should be distributed across instances. For example JCR observation based events are already distributed on all instances, so there is no further need to distribute them. If the flag is present, the event will be distributed. The value has currently no meaning, however the EventUtil method should be used to add this property. If the flag is absent the event is distributed locally only.
+</em> <em>event.application</em> - An identifier for the current application node in the cluster. This information will be used to detect if an event has been created on different nodes. If the event has been created on the same node, the <em>event.application</em> is missing, if it is a remote event, the <em>event.application</em> contains the ID of the node, the event has been initially created. Use the <em>EventUtil.isLocal(Event)</em> method to detect if the event is a local or a distributed event.</p>
+<p>While the <em>event.distribute</em> must be set by the sender of an event (if the event should be distributed), the <em>event.application</em> property is maintained by the event mechanism. Therefore a client sending an event should <em>never</em> set this information by itself. This will confuse the local event handlers and result in unexpected behaviour. On remote events the <em>event.application</em> is set by the event distribution mechanism.</p>
 <h3 id="event-distribution-across-application-nodes-cluster">Event Distribution Across Application Nodes (Cluster)</h3>
-<p>The (local) event admin is the service distributing events locally. The
-Sling Distributing Event Handler is a registered event handler that is
-listening for events to be distributed. It distributes the events to remote
-application notes, the JCR repository is used for distribution. The
-distributing event handler writes the events into the repository, the
-distributing event handlers on other application nodes get notified through
-observation and then distribute the read events locally.</p>
-<p>As mentioned above, the client sending an event has to mark an event to be
-distributed in a cluster by setting the <em>event.distribute</em> in the event
-properties (through <em>EventUtil</em>). This distribution mechanism has the
-advantage that the application nodes do not need to know each other and the
-distribution mechanism is independent from the used event admin
-implementation.</p>
-<p><a name="ApacheSlingEventingandJobHandling-StoringEventsintheRepository"></a></p>
+<p>The (local) event admin is the service distributing events locally. The Sling Distributing Event Handler is a registered event handler that is listening for events to be distributed. It distributes the events to remote application notes, the JCR repository is used for distribution. The distributing event handler writes the events into the repository, the distributing event handlers on other application nodes get notified through observation and then distribute the read events locally.</p>
+<p>As mentioned above, the client sending an event has to mark an event to be distributed in a cluster by setting the <em>event.distribute</em> in the event properties (through <em>EventUtil</em>). This distribution mechanism has the advantage that the application nodes do not need to know each other and the distribution mechanism is independent from the used event admin implementation.</p>
 <h3 id="storing-events-in-the-repository">Storing Events in the Repository</h3>
-<p>Distributable events are stored in the repository, the repository will have
-a specific area (path) where all events are stored. </p>
+<p>Distributable events are stored in the repository, the repository will have a specific area (path) where all events are stored. </p>
 <p>Each event is stored as a separate node with the following properties:
-<table>
-<tr><td> <em>Property Name</em>     </td><td> <em>Description</em> </td></tr>
-<tr><td> <em>event:topic</em>       </td><td> The topic of the event </td></tr>
-<tr><td> <em>event:application</em> </td><td> The identifier of the application node where the
-event was created </td></tr>
-<tr><td> <em>event:created</em>     </td><td> The date and time when the event has been created
-(stored in the repository)
-</tr>
-<tr><td> <em>event:properties</em>  </td><td> Serialized properties (except the
-<em>event.distribute</em>, but including the <em>event.application</em>) </td></tr>
-</table></p>
-<p>Each application is periodically removing old events from the repository
-(using the scheduler).</p>
-<p>{anchor:timed}
-<a name="ApacheSlingEventingandJobHandling-SendingScheduledEvents"></a></p>
+| <em>Property Name</em>     | <em>Description</em> |
+| <em>event:topic</em>       | The topic of the event |
+| <em>event:application</em> | The identifier of the application node where the event was created |
+| <em>event:created</em>     | The date and time when the event has been created (stored in the repository)
+| <em>event:properties</em>  | Serialized properties (except the <em>event.distribute</em>, but including the <em>event.application</em>) |</p>
+<p>Each application is periodically removing old events from the repository (using the scheduler).</p>
+<p>{anchor:timed}</p>
 <h3 id="sending-scheduled-events_1">Sending Scheduled Events</h3>
-<p>Scheduled events are OSGi events that have been created by the environemnt.
-They are generated on each application node of the cluster through an own
-scheduler instance. Sending these events works the same as sending events
-based on JCR events (see above).</p>
-<p>In most use cases a scheduler will send job events to ensure that exactly
-one application node is processing the event.</p>
-<p><a name="ApacheSlingEventingandJobHandling-ReceivingOSGiEvents"></a></p>
+<p>Scheduled events are OSGi events that have been created by the environemnt. They are generated on each application node of the cluster through an own scheduler instance. Sending these events works the same as sending events based on JCR events (see above).</p>
+<p>In most use cases a scheduler will send job events to ensure that exactly one application node is processing the event.</p>
 <h3 id="receiving-osgi-events_1">Receiving OSGi Events</h3>
-<p>If you want to receive OSGi events, you can just follow the specification:
-receive it via a custom event handler which is registered on bundle start -
-a filter can be specified as a configuration property of the handler. </p>
-<p>As we follow the principle of distributing each event to every registered
-handler, the handler has to decide if it will process the event. In order
-to avoid multiple processing of this event in a clustered environment, the
-event handler should check the <em>event.application</em> property. If it is not
-set, it's a local event and the handler should process the event. If the
-<em>event.application</em> is set, it's a remote event and the handler should not
-process the event. This is a general rule of thumb - however, it's up to
-the handler to make its decision either on <em>event.application</em> or any other
-information.</p>
-<p>It is advisable to perform the local event check even in a non clustered
-environment as it makes the migration to a cluster later on much easier and
-there is nearly no performance overhead caused by the check.</p>
-<p>The ~EventUtil class provides an utility method <em>isLocalEvent(Event)</em> which
-checks the existance of the <em>event.application</em> property and returns <em>true</em>
-if it is absend.</p>
-<p><a name="ApacheSlingEventingandJobHandling-Scheduler"></a></p>
+<p>If you want to receive OSGi events, you can just follow the specification: receive it via a custom event handler which is registered on bundle start - a filter can be specified as a configuration property of the handler. </p>
+<p>As we follow the principle of distributing each event to every registered handler, the handler has to decide if it will process the event. In order to avoid multiple processing of this event in a clustered environment, the event handler should check the <em>event.application</em> property. If it is not set, it's a local event and the handler should process the event. If the <em>event.application</em> is set, it's a remote event and the handler should not process the event. This is a general rule of thumb - however, it's up to the handler to make its decision either on <em>event.application</em> or any other information.</p>
+<p>It is advisable to perform the local event check even in a non clustered environment as it makes the migration to a cluster later on much easier and there is nearly no performance overhead caused by the check.</p>
+<p>The ~EventUtil class provides an utility method <em>isLocalEvent(Event)</em> which checks the existance of the <em>event.application</em> property and returns <em>true</em> if it is absend.</p>
 <h2 id="scheduler">Scheduler</h2>
-<p>Each Sling based application will contain a scheduler service (which is
-based on the Quartz open source project).</p>
-<p><a name="ApacheSlingEventingandJobHandling-UseCases"></a></p>
+<p>Each Sling based application will contain a scheduler service (which is based on the Quartz open source project).</p>
 <h2 id="use-cases">Use Cases</h2>
-<p><a name="ApacheSlingEventingandJobHandling-PostProcessing(BusinessProcesses)"></a></p>
 <h3 id="post-processing-business-processes">Post Processing (Business Processes)</h3>
-<p>A typical example for post processing (or running a business process) is
-sending an email or creating thumbnails and extracting meta data from the
-content (like we do in DAM), which we will discuss here.</p>
-<p>An appropriate JCR observer will be registered. This observer detects when
-new content is put into the repository or when content is changed. In these
-cases it creates appropriate <em>CONTENT_ADDED</em>, <em>CONTENT_UPDATED</em> OSGi events
-from the JCR events. In order to ensure that these actions get processed
-accordingly, the event is send as a job (with the special job topic, the
-<em>topic</em> and <em>id</em> property).</p>
-<p>The event admin now delivers these jobs to the registered handlers. The job
-event handler gets notified and (simplified version) sends the contained
-event synchronously. One of the handlers for these events is the post
-processing service in DAM. The job mechanism ensures that exactly one
-application node is post processing and that the process has to be finished
-even if the application node dies during execution.</p>
-<p><a name="ApacheSlingEventingandJobHandling-Scheduling"></a></p>
+<p>A typical example for post processing (or running a business process) is sending an email or creating thumbnails and extracting meta data from the content (like we do in DAM), which we will discuss here.</p>
+<p>An appropriate JCR observer will be registered. This observer detects when new content is put into the repository or when content is changed. In these cases it creates appropriate <em>CONTENT</em>ADDED<em>, </em>CONTENT<em>UPDATED</em> OSGi events from the JCR events. In order to ensure that these actions get processed accordingly, the event is send as a job (with the special job topic, the <em>topic</em> and <em>id</em> property).</p>
+<p>The event admin now delivers these jobs to the registered handlers. The job event handler gets notified and (simplified version) sends the contained event synchronously. One of the handlers for these events is the post processing service in DAM. The job mechanism ensures that exactly one application node is post processing and that the process has to be finished even if the application node dies during execution.</p>
 <h2 id="scheduling">Scheduling</h2>
-<p>The scheduler is a service which uses the open source Quartz library. The
-scheduler has methods to start jobs periodically or with a cron definition.
-In addition, a service either implementing <em>java.lang.Runnable</em> or
-<em>org.quartz.job</em> is started through the whiteboard pattern <em>if</em> it either
-contains a configuration property <em>scheduler.expression</em> or
-<em>scheduler.period</em>. The job is started with the ~PID of the service - if
-the service has no PID, the configuration property <em>scheduler.name</em> must be
-set.</p>
+<p>The scheduler is a service which uses the open source Quartz library. The scheduler has methods to start jobs periodically or with a cron definition. In addition, a service either implementing <em>java.lang.Runnable</em> or <em>org.quartz.job</em> is started through the whiteboard pattern <em>if</em> it either contains a configuration property <em>scheduler.expression</em> or <em>scheduler.period</em>. The job is started with the ~PID of the service - if the service has no PID, the configuration property <em>scheduler.name</em> must be set.</p>
       <div class="timestamp" style="margin-top: 30px; font-size: 80%; text-align: right;">
-        Rev. 1328899 by fmeschbe on Sun, 22 Apr 2012 16:52:13 +0000
+        Rev. 1341347 by fmeschbe on Tue, 22 May 2012 08:25:18 +0000
       </div>
       <div class="trademarkFooter"> 
         Apache Sling, Sling, Apache, the Apache feather logo, and the Apache Sling project

Modified: websites/staging/sling/trunk/content/apache-sling.html
==============================================================================
--- websites/staging/sling/trunk/content/apache-sling.html (original)
+++ websites/staging/sling/trunk/content/apache-sling.html Tue May 22 08:25:32 2012
@@ -82,139 +82,66 @@
         <a href="/">Home</a>
       </div>
       <h1>Apache Sling</h1>
-      <p><a name="ApacheSling-ApacheSling-BringingBacktheFun"></a></p>
-<h1 id="apache-sling-bringing-back-the-fun">Apache Sling - Bringing Back the Fun</h1>
-<p>{tm}Apache Sling{tm} is an innovative web framework that is intended to
-bring back the fun to web development.</p>
-<p>Discussions about Sling happen on our mailing lists, see the <a href="project-information.html">Project Information</a>
- page for more info.</p>
-<p><a name="ApacheSling-ApacheSlinginfivebulletspoints"></a></p>
+      <h1 id="apache-sling-bringing-back-the-fun">Apache Sling - Bringing Back the Fun</h1>
+<p>{tm}Apache Sling{tm} is an innovative web framework that is intended to bring back the fun to web development.</p>
+<p>Discussions about Sling happen on our mailing lists, see the <a href="/project-information.html">Project Information</a> page for more info.</p>
 <h1 id="apache-sling-in-five-bullets-points">Apache Sling in five bullets points</h1>
 <ul>
 <li>REST based web framework</li>
 <li>Content-driven, using a JCR content repository</li>
 <li>Powered by OSGi</li>
-<li>Scripting inside, multiple languages (JSP, server-side javascript, Scala,
-etc.)</li>
+<li>Scripting inside, multiple languages (JSP, server-side javascript, Scala, etc.)</li>
 <li>Apache Open Source project</li>
 </ul>
-<p><a name="ApacheSling-ApacheSlinginahundredwords"></a></p>
 <h1 id="apache-sling-in-a-hundred-words">Apache Sling in a hundred words</h1>
-<p>Apache Sling is a web framework that uses a <a href="http://en.wikipedia.org/wiki/JSR-170">Java Content Repository</a>
-, such as [Apache Jackrabbit|http://jackrabbit.apache.org/]
-, to store and manage content.</p>
-<p>Sling applications use either scripts or Java servlets, selected based on
-simple name conventions, to process HTTP requests in a RESTful way.</p>
-<p>The embedded <a href="http://felix.apache.org/">Apache Felix</a>
- OSGi framework and console provide a dynamic runtime environment, where
-code and content bundles can be loaded, unloaded and reconfigured at
-runtime.</p>
-<p>As the first web framework dedicated to <a href="http://jcp.org/en/jsr/detail?id=170">JSR-170</a>
- Java Content Repositories, Sling makes it very simple to implement simple
-applications, while providing an enterprise-level framework for more
-complex applications. </p>
-<p><a name="ApacheSling-News"></a></p>
+<p>Apache Sling is a web framework that uses a <a href="">Java Content Repository</a>, such as [Apache Jackrabbit|http://jackrabbit.apache.org/], to store and manage content.</p>
+<p>Sling applications use either scripts or Java servlets, selected based on simple name conventions, to process HTTP requests in a RESTful way.</p>
+<p>The embedded <a href="">Apache Felix</a> OSGi framework and console provide a dynamic runtime environment, where code and content bundles can be loaded, unloaded and reconfigured at runtime.</p>
+<p>As the first web framework dedicated to <a href="">JSR-170</a> Java Content Repositories, Sling makes it very simple to implement simple applications, while providing an enterprise-level framework for more complex applications. </p>
 <h2 id="news">News</h2>
-<p>{excerpt-include:News|nopanel=true}
-* <a href="news.html">all news...</a></p>
-<p><a name="ApacheSling-History"></a></p>
+<ul>
+<li>New Releases: Apache Sling Commons Testing 2.0.10, Apache Sling Commons Scheduler 2.3.4, Apache Sling Commons Log 3.0.0, Apache Sling Commons Log Service 1.0.0, Apache Sling Adapter 2.0.12, Apache Sling Installer Core 3.3.4, Apache Sling Launchpad API 1.1.0, Apache Sling Launchpad Installer 1.1.0, and Apache Sling Maven JSPC Plugin 2.0.6 (February 7th, 2012) * New Releases: Apache Sling API 2.2.4, Apache Sling Adapter 2.0.10, Apache Sling Scripting JSP Taglib 2.1.6, Apache Sling Rewriter 1.0.2, Apache Sling JCR ContentLoader 2.1.4, Apache Sling JCR Base 2.1.2, Apache Sling Servlet Resolver 2.1.2, and Apache Sling Security 1.0.0 (January 30th, 2012) * New Releases: Apache Sling Scripting API 2.1.4, Apache Sling Scripting Core 2.0.20, Apache Sling i18n 2.2.0, Apache Sling Installer Core 3.3.2, Apache Sling Scripting Java 2.0.2, and Apache Sling Scripting JSP 2.0.20 (January 16th, 2012) * New Releases: Apache Adapter Annotations 1.0.0 and Apache Sling Maven Sling Plugin 2.1
 .0 (January 14th, 2012) * New Releases: Apache Sling Settings 1.1.0, Apache Sling Commons ClassLoader 1.2.4, Apache Sling Commons Scheduler 2.3.2, Apache Sling Event 3.1.2, Apache Sling Installer Core 3.3.0, Apache Sling Installer Configuration Factory 1.0.4, Apache Sling Launchpad Installer 1.0.6, Apache Sling JCR Installer 3.1.2, and Apache Sling Thread Dumper 0.2.2 (January 6th, 2012) * New Release: Apache Sling Jackrabbit User Manager 2.2.0 (November 15th, 2011) * New Release: Apache Sling Maven Sling Plugin 2.0.6 (October 21st, 2011) * New Release: Apache Sling Maven Launchpad Plugin 2.1.0 (September 9th, 20111) * New Releases: Apache Sling Resource Bundle 1.0.0 and Parent POM 12 * New Releases: Apache Sling API 2.2.2, Apache Sling Commons Scheduler 2.3.0, Apache Sling Commons OSGi 2.1.0, Apache Sling Scripting Core 2.0.18, Apache Sling Installer Core 3.2.2, Apache Sling Installer Configuration Factory 1.0.2, Apache Sling Launchpad Installer 1.0.4, Apache Sling File Ins
 taller 1.0.2 (August 16th, 2011) * New Release: Apache Sling Scripting JSP Support 2.0.18 (August 15th, 2011) * Released new Apache Sling Parent POM 11 (August 8, 2011) * New Release: Apache Sling Internationalization 2.1.2 (July 15, 2011) * New Releases: Apache Sling Event 3.1.0, Apache Sling OSGi Installer 3.2.0, Apache Sling JCR Installer 3.1.0, Apache Sling Installer Configuration Factory 1.0.0, Apache Sling Launchpad Installer 1.0.2 (July 13th, 2011) * New Release: Apache Sling Engine 2.2.4 (June 22nd, 2011) * New Releases: Apache Sling Launchpad Standalone Archetype 1.0.0, Launchpad Webapp Archetype 1.0.0 (May 13th, 2011) * New Releases: Apache Sling Scripting JSP Support 2.0.16, JSP Taglib 2.1.2 (May 3rd, 2011) * New releases: Apache Sling Test Tools 1.0.2, JUnit Core 1.0.6, JUnit Remote Tests Runners 1.0.6, JUnit Scriptable Tests Provider 1.0.6, Sample Integration Tests 1.0.6, Sample Server-Side Tests 1.0.6, Failing Server-Side Tests 1.0.6 (April 26th, 2011) * New re
 leases: Apache Sling I18N 2.1.0 (April 12, 2011) * New releases: [Apache Sling 6|http://markmail.org/thread/hv5vd5774ofwqu6j], Apache Sling Launchpad Content 2.0.6 (March 28, 2011) * New releases: Apache Sling Launchpad Integration Tests 1.0.0, Apache Sling Launchpad Testing Services 2.0.8, Apache Sling Launchpad Testing Services WAR 2.0.8 (March 04, 2011) * New releases: Apache Sling Javascript 2.0.12 (February 26, 2011) * New releases: Apache Sling Explorer 1.0.2, Apache Sling JCR Resource 2.0.10, Apache Sling Engine 2.2.2, Apache Sling Installer IT Testing 3.1.2 (February 24, 2011) * New releases: Apache Sling Launchpad API 1.0.0, Launchpad Installer 1.0.0 Launchpad Base 2.3.0, Maven Launchpad Plugin 2.0.10, Apache Sling Commons Testing 2.0.8 (February 20, 2011) * New release: Apache Sling Servlets Get 2.1.2 (February 18, 2011)</li>
+<li><a href="/news.html">all news...</a></li>
+</ul>
 <h2 id="history">History</h2>
-<p>Sling started as an internal project at <a href="http://www.day.com">Day Software</a>
-, and entered the Apache Incubator in September 2007. As of June, 17th,
-2009 Apache Sling is a top level project of the Apache Software Foundation.</p>
-<p>The name "Sling" has been proposed by Roy Fielding who explained it like
-this:</p>
+<p>Sling started as an internal project at <a href="">Day Software</a>, and entered the Apache Incubator in September 2007. As of June, 17th, 2009 Apache Sling is a top level project of the Apache Software Foundation.</p>
+<p>The name "Sling" has been proposed by Roy Fielding who explained it like this:</p>
 <p>{quote}
-[The name is](the-name-is.html)
- Biblical in nature.  The story of David: the weapon he uses to slay the
-giant Goliath is a sling.  Hence, our David's [David Nuescheler, CTO of
-Day Software] favorite weapon.</p>
+[The name is]() Biblical in nature.  The story of David: the weapon he uses to slay the giant Goliath is a sling.  Hence, our David's [David Nuescheler, CTO of Day Software] favorite weapon.</p>
 <p>It is also the simplest device for delivering content very fast.
 {quote}</p>
-<p><a name="ApacheSling-WhousesSling?"></a></p>
 <h2 id="who-uses-sling">Who uses Sling?</h2>
-<p>See <a href="http://cwiki.apache.org/SLING/who-is-using-sling-.html">Who is using Sling</a>
- on our public wiki.</p>
-<p><a name="ApacheSling-Gettingstarted"></a></p>
+<p>See <a href="">Who is using Sling</a> on our public wiki.</p>
 <h2 id="getting-started">Getting started</h2>
-<p>If you prefer doing rather than reading, please proceed to <a href="discover-sling-in-15-minutes.html">Discover Sling in 15 minutes</a>
- or read through the recommended links in the [Getting Started]
- section, where you can quickly get started on your own instance of Sling.</p>
-<p><a name="ApacheSling-Contents"></a></p>
+<p>If you prefer doing rather than reading, please proceed to <a href="/discover-sling-in-15-minutes.html">Discover Sling in 15 minutes</a> or read through the recommended links in the [Getting Started] section, where you can quickly get started on your own instance of Sling.</p>
 <h2 id="contents">Contents</h2>
 <ul>
-<li><a href="documentation.html">Documentation</a>
- - Here you will find the documentation on Sling</li>
-<li><a href="development.html">Development</a>
- -- Documentation on how to develop web applications with Sling and what
-tools you have at your disposal</li>
-<li><a href="links.html">Links</a></li>
-<li><a href="http://cwiki.apache.org/SLING/">Wiki</a></li>
-<li><a href="http://cwiki.apache.org/SLING/faq.html">FAQ</a></li>
-<li><a href="project-information.html">Project Information</a></li>
+<li><a href="/documentation.html">Documentation</a> - Here you will find the documentation on Sling</li>
+<li><a href="/development.html">Development</a> -- Documentation on how to develop web applications with Sling and what tools you have at your disposal</li>
+<li><a href="/links.html">Links</a></li>
+<li><a href="">Wiki</a></li>
+<li><a href="">FAQ</a></li>
+<li><a href="/project-information.html">Project Information</a></li>
 </ul>
-<p><a name="ApacheSling-UseCasesforSling"></a></p>
 <h2 id="use-cases-for-sling">Use Cases for Sling</h2>
-<p><a name="ApacheSling-Wiki"></a></p>
 <h4 id="wiki">Wiki</h4>
-<p>Day built a Wiki system on Sling. Each Wiki page is a node (with optional
-child nodes) in the repository. As a page is requested, the respective node
-is accessed and through the applying Component is rendered.</p>
-<p>Thanks to the JCR Mapping and the resolution of the Component from the
-mapped Content, the system does not care for what actual node is addressed
-as long as there is a Content mapping and a Component capable of handling
-the Content.</p>
-<p>Thus in the tradition of REST, the attachement of a Wiki page, which
-happens to be in a node nested below the wiki page node is easily accessed
-using the URL of the wiki page attaching the relative path of the
-attachement  ode. The system resolves the URL to the attachement Content
-and just calls the attachement's Component to spool the attachement.</p>
-<p><a name="ApacheSling-DigitalAssetManagement"></a></p>
+<p>Day built a Wiki system on Sling. Each Wiki page is a node (with optional child nodes) in the repository. As a page is requested, the respective node is accessed and through the applying Component is rendered.</p>
+<p>Thanks to the JCR Mapping and the resolution of the Component from the mapped Content, the system does not care for what actual node is addressed as long as there is a Content mapping and a Component capable of handling the Content.</p>
+<p>Thus in the tradition of REST, the attachement of a Wiki page, which happens to be in a node nested below the wiki page node is easily accessed using the URL of the wiki page attaching the relative path of the attachement  ode. The system resolves the URL to the attachement Content and just calls the attachement's Component to spool the attachement.</p>
 <h4 id="digital-asset-management">Digital Asset Management</h4>
-<p>Day has implemented a Digital Asset Management (DAM) Application based on
-Sling. Thanks to the flexibility of the Content/Component combo as well as
-the service registration/access functionality offered by OSGi, extending
-DAM for new content type is merely a matter of implementing one or two
-interfaces and registering the respective service(s).</p>
+<p>Day has implemented a Digital Asset Management (DAM) Application based on Sling. Thanks to the flexibility of the Content/Component combo as well as the service registration/access functionality offered by OSGi, extending DAM for new content type is merely a matter of implementing one or two interfaces and registering the respective service(s).</p>
 <p>Again, the managed assets may be easily spooled by directly accessing them.</p>
-<p><a name="ApacheSling-WebContentManagement"></a></p>
 <h4 id="web-content-management">Web Content Management</h4>
-<p>Last but not least, Sling offers itself very well to implementing a Web
-Content Management system. Thanks to the flexibility of rendering the
-output - remember: the system does not care what to render, as long as the
-URL resolves to a Content object for which a Component exists, which is
-called to render the Content - providing support for Web Content authors
-(not PHP programmers but users out in the field) to build pages to their
-likings can easily be done.</p>
-<p><a name="ApacheSling-References"></a></p>
+<p>Last but not least, Sling offers itself very well to implementing a Web Content Management system. Thanks to the flexibility of rendering the output - remember: the system does not care what to render, as long as the URL resolves to a Content object for which a Component exists, which is called to render the Content - providing support for Web Content authors (not PHP programmers but users out in the field) to build pages to their likings can easily be done.</p>
 <h2 id="references">References</h2>
-<p><a name="ApacheSling-ApacheJackrabbit"></a></p>
 <h4 id="apache-jackrabbit">Apache Jackrabbit</h4>
-<p>The main purpose of Sling is to develop a content-centric Web Application
-framework for Java Content Repository (JCR) based data stores. Sling is
-implemented - with the notable exception of JCR Node Type management -
-purely in terms of the JCR API and as such may use any JCR compliant
-repository. The default implementation for <a href="http://jackrabbit.apache.org">Apache Jackrabbit</a>
- is provided out of the box.</p>
-<p><a name="ApacheSling-OSGi"></a></p>
+<p>The main purpose of Sling is to develop a content-centric Web Application framework for Java Content Repository (JCR) based data stores. Sling is implemented - with the notable exception of JCR Node Type management - purely in terms of the JCR API and as such may use any JCR compliant repository. The default implementation for <a href="">Apache Jackrabbit</a> is provided out of the box.</p>
 <h4 id="osgi">OSGi</h4>
-<p>Sling is implemented as a series of <a href="http://www.osgi.org">OSGi</a>
- Bundles and makes extensive use of the OSGi functionality, such as
-lifecycle management and the service layer. In addition, Sling requires
-several OSGi compendium services to be available, such as the Log Service,
-Http Service, Configuration Admin Service, Metatype Service, and
-Declarative Services.</p>
-<p><a name="ApacheSling-ApacheFelix"></a></p>
+<p>Sling is implemented as a series of <a href="">OSGi</a> Bundles and makes extensive use of the OSGi functionality, such as lifecycle management and the service layer. In addition, Sling requires several OSGi compendium services to be available, such as the Log Service, Http Service, Configuration Admin Service, Metatype Service, and Declarative Services.</p>
 <h4 id="apache-felix">Apache Felix</h4>
-<p>While Sling does not require a specific OSGi framework implementation to
-run in, Sling is being developed using <a href="http://felix.apache.org">Apache Felix</a>
- as the OSGi framework implementation. It has not been tested yet, but it
-is expected that Sling also operates perfectly inside other OSGi frameworks
-such as [Equinox|http://www.eclipse.org/equinox]
- and [Knopflerfish|http://www.knopflerfish.org]
-.</p>
+<p>While Sling does not require a specific OSGi framework implementation to run in, Sling is being developed using <a href="">Apache Felix</a> as the OSGi framework implementation. It has not been tested yet, but it is expected that Sling also operates perfectly inside other OSGi frameworks such as [Equinox|http://www.eclipse.org/equinox] and [Knopflerfish|http://www.knopflerfish.org].</p>
       <div class="timestamp" style="margin-top: 30px; font-size: 80%; text-align: right;">
-        Rev. 1328899 by fmeschbe on Sun, 22 Apr 2012 16:52:13 +0000
+        Rev. 1341347 by fmeschbe on Tue, 22 May 2012 08:25:18 +0000
       </div>
       <div class="trademarkFooter"> 
         Apache Sling, Sling, Apache, the Apache feather logo, and the Apache Sling project