You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tuscany.apache.org by fm...@apache.org on 2011/05/26 01:27:47 UTC

svn commit: r1127725 - in /tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp: ./ src/ src/main/ src/main/java/ src/main/java/org/ src/main/java/org/apache/ src/main/java/org/apache/tuscany/ src/main/java/org/apache/tuscany/...

Author: fmoga
Date: Wed May 25 23:27:46 2011
New Revision: 1127725

URL: http://svn.apache.org/viewvc?rev=1127725&view=rev
Log:
Add pub/sub sample for binding.comet

Added:
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/pom.xml
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Event.java
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessor.java
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorConsumerService.java
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorProducerService.java
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Producer.java
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/META-INF/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/META-INF/MANIFEST.MF
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/lib/
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/web.composite
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/web.xml
    tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/index.html

Added: tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/pom.xml
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/pom.xml?rev=1127725&view=auto
==============================================================================
--- tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/pom.xml (added)
+++ tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/pom.xml Wed May 25 23:27:46 2011
@@ -0,0 +1,64 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
+	<modelVersion>4.0.0</modelVersion>
+	<parent>
+		<groupId>org.apache.tuscany.sca</groupId>
+		<artifactId>tuscany-samples</artifactId>
+		<version>2.0-SNAPSHOT</version>
+		<relativePath>../../../pom.xml</relativePath>
+	</parent>
+
+	<groupId>org.apache.tuscany.sca</groupId>
+	<artifactId>sample-binding-comet-pubsub-webapp</artifactId>
+	<packaging>war</packaging>
+	<version>1.0</version>
+	<name>Apache Tuscany SCA Sample binding.comet PubSub Webapp</name>
+
+	<dependencies>
+		<dependency>
+			<groupId>org.apache.tuscany.sca</groupId>
+			<artifactId>tuscany-binding-comet-runtime</artifactId>
+			<version>2.0-SNAPSHOT</version>
+		</dependency>
+		<dependency>
+			<groupId>javax</groupId>
+			<artifactId>javaee-web-api</artifactId>
+			<version>6.0</version>
+			<scope>provided</scope>
+		</dependency>
+		<dependency>
+			<groupId>org.apache.tuscany.sca</groupId>
+			<artifactId>tuscany-base-runtime-pom</artifactId>
+			<version>2.0-SNAPSHOT</version>
+			<type>pom</type>
+			<scope>compile</scope>
+		</dependency>
+		<dependency>
+			<groupId>com.google.guava</groupId>
+			<artifactId>guava</artifactId>
+			<version>r09</version>
+			<type>jar</type>
+			<scope>compile</scope>
+		</dependency>
+	</dependencies>
+	
+</project>
+

Added: tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Event.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Event.java?rev=1127725&view=auto
==============================================================================
--- tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Event.java (added)
+++ tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Event.java Wed May 25 23:27:46 2011
@@ -0,0 +1,33 @@
+package org.apache.tuscany.sca.sample.comet;
+
+public class Event {
+
+	private String id;
+	private String name;
+	private String data;
+
+	public String getId() {
+		return id;
+	}
+
+	public void setId(String id) {
+		this.id = id;
+	}
+
+	public String getName() {
+		return name;
+	}
+
+	public void setName(String name) {
+		this.name = name;
+	}
+
+	public String getData() {
+		return data;
+	}
+
+	public void setData(String data) {
+		this.data = data;
+	}
+
+}

Added: tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessor.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessor.java?rev=1127725&view=auto
==============================================================================
--- tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessor.java (added)
+++ tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessor.java Wed May 25 23:27:46 2011
@@ -0,0 +1,107 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.    
+ */
+
+package org.apache.tuscany.sca.sample.comet;
+
+import java.util.ArrayList;
+import java.util.Date;
+import java.util.List;
+import java.util.Map;
+import java.util.UUID;
+import java.util.concurrent.ConcurrentHashMap;
+
+import org.apache.tuscany.sca.binding.comet.runtime.callback.CometCallback;
+import org.apache.tuscany.sca.binding.comet.runtime.callback.Status;
+import org.oasisopen.sca.ComponentContext;
+import org.oasisopen.sca.annotation.Context;
+import org.oasisopen.sca.annotation.Destroy;
+import org.oasisopen.sca.annotation.Scope;
+import org.oasisopen.sca.annotation.Service;
+
+import com.google.common.collect.HashMultimap;
+import com.google.common.collect.Multimap;
+import com.google.common.collect.Multimaps;
+
+@Service({ EventProcessorConsumerService.class, EventProcessorProducerService.class })
+@Scope("COMPOSITE")
+public class EventProcessor implements EventProcessorConsumerService, EventProcessorProducerService {
+
+	@Context
+	protected ComponentContext componentContext;
+
+	private Map<String, CometCallback> clients = new ConcurrentHashMap<String, CometCallback>();
+	private Multimap<String, String> eventListeners = Multimaps.synchronizedMultimap(HashMultimap
+			.<String, String> create());
+
+	@Override
+	public void onEvent(String eventName, String eventData) {
+		// System.out.println("EventProcessor: Received event " + eventName +
+		// "...");
+		List<String> destinations = new ArrayList<String>();
+		synchronized (eventListeners) {
+			destinations.addAll(eventListeners.get(eventName));
+		}
+		Event event = new Event();
+		event.setName(eventName);
+		event.setData(eventData);
+		for (String registrationId : destinations) {
+			CometCallback client = clients.get(registrationId);
+			if (client == null) {
+				// client has unregistered from this event
+				synchronized (eventListeners) {
+					eventListeners.remove(eventName, registrationId);
+				}
+			} else {
+				Status status = client.sendMessage(event);
+				if (status == Status.CLIENT_DISCONNECTED) {
+					unregister(registrationId);
+				}
+			}
+		}
+	}
+
+	@Override
+	public void register(String eventName) {
+		String registrationId = UUID.randomUUID().toString();
+		CometCallback callback = componentContext.getRequestContext().getCallback();
+		clients.put(registrationId, callback);
+		synchronized (eventListeners) {
+			eventListeners.put(eventName, registrationId);
+		}
+		Event event = new Event();
+		event.setId(registrationId);
+		event.setName(eventName);
+		event.setData(new Date().toString());
+		callback.sendMessage(event);
+	}
+
+	@Override
+	public void unregister(String registrationId) {
+		clients.remove(registrationId);
+		// unregistration from eventListeners done during onEvent
+	}
+
+	@Destroy
+	public void shutdown() {
+		clients.clear();
+		eventListeners.clear();
+		clients = null;
+		eventListeners = null;
+	}
+}

Added: tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorConsumerService.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorConsumerService.java?rev=1127725&view=auto
==============================================================================
--- tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorConsumerService.java (added)
+++ tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorConsumerService.java Wed May 25 23:27:46 2011
@@ -0,0 +1,37 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.    
+ */
+
+package org.apache.tuscany.sca.sample.comet;
+
+import org.apache.tuscany.sca.binding.comet.runtime.callback.CometCallback;
+import org.oasisopen.sca.annotation.Callback;
+import org.oasisopen.sca.annotation.OneWay;
+import org.oasisopen.sca.annotation.Remotable;
+
+@Callback(CometCallback.class)
+@Remotable
+public interface EventProcessorConsumerService {
+
+	@OneWay
+	void register(String eventName);
+
+	@OneWay
+	void unregister(String registrationId);
+
+}

Added: tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorProducerService.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorProducerService.java?rev=1127725&view=auto
==============================================================================
--- tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorProducerService.java (added)
+++ tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorProducerService.java Wed May 25 23:27:46 2011
@@ -0,0 +1,28 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.    
+ */
+package org.apache.tuscany.sca.sample.comet;
+
+import org.oasisopen.sca.annotation.Remotable;
+
+@Remotable
+public interface EventProcessorProducerService {
+
+	void onEvent(String eventName, String eventData);
+
+}

Added: tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Producer.java
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Producer.java?rev=1127725&view=auto
==============================================================================
--- tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Producer.java (added)
+++ tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Producer.java Wed May 25 23:27:46 2011
@@ -0,0 +1,76 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.    
+ */
+package org.apache.tuscany.sca.sample.comet;
+
+import java.util.Date;
+import java.util.Timer;
+import java.util.TimerTask;
+
+import org.oasisopen.sca.annotation.Constructor;
+import org.oasisopen.sca.annotation.Destroy;
+import org.oasisopen.sca.annotation.EagerInit;
+import org.oasisopen.sca.annotation.Init;
+import org.oasisopen.sca.annotation.Property;
+import org.oasisopen.sca.annotation.Reference;
+import org.oasisopen.sca.annotation.Scope;
+
+@EagerInit
+@Scope("COMPOSITE")
+public class Producer {
+
+	@Reference
+	protected EventProcessorProducerService eventProcessor;
+
+	private String eventName;
+	private long frequency;
+
+	private Timer timer = new Timer();
+	private Object lock = new Object();
+
+	@Constructor
+	public Producer(@Property(name = "eventName") String eventName, @Property(name = "frequency") long frequency) {
+		System.out.println("Producer: In Constructor with eventName=" + eventName + " and frequency=" + frequency);
+		this.eventName = eventName;
+		this.frequency = frequency;
+	}
+
+	@Init
+	public void start() {
+		System.out.println("Producer: In Init...");
+		timer.schedule(new TimerTask() {
+
+			@Override
+			public void run() {
+//				System.out.println("Producer: Producing " + eventName + " event...");
+				synchronized (lock) {
+					eventProcessor.onEvent(Producer.this.eventName, "Event @ " + new Date());
+				}
+			}
+		}, 0L, this.frequency);
+	}
+
+	@Destroy
+	public void stop() {
+		synchronized (lock) {
+			timer.cancel();
+		}
+		timer = null;
+	}
+
+}

Added: tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/META-INF/MANIFEST.MF
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/META-INF/MANIFEST.MF?rev=1127725&view=auto
==============================================================================
--- tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/META-INF/MANIFEST.MF (added)
+++ tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/META-INF/MANIFEST.MF Wed May 25 23:27:46 2011
@@ -0,0 +1,2 @@
+Manifest-Version: 1.0
+

Added: tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/web.composite
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/web.composite?rev=1127725&view=auto
==============================================================================
--- tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/web.composite (added)
+++ tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/web.composite Wed May 25 23:27:46 2011
@@ -0,0 +1,56 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!-- * Licensed to the Apache Software Foundation (ASF) under one * or more 
+	contributor license agreements. See the NOTICE file * distributed with this 
+	work for additional information * regarding copyright ownership. The ASF 
+	licenses this file * to you under the Apache License, Version 2.0 (the * 
+	"License"); you may not use this file except in compliance * with the License. 
+	You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 
+	* * Unless required by applicable law or agreed to in writing, * software 
+	distributed under the License is distributed on an * "AS IS" BASIS, WITHOUT 
+	WARRANTIES OR CONDITIONS OF ANY * KIND, either express or implied. See the 
+	License for the * specific language governing permissions and limitations 
+	* under the License. -->
+<composite xmlns="http://docs.oasis-open.org/ns/opencsa/sca/200912"
+	xmlns:tuscany="http://tuscany.apache.org/xmlns/sca/1.1"
+	targetNamespace="http://samples" name="Event">
+
+	<component name="EventProcessorComponent">
+		<implementation.java
+			class="org.apache.tuscany.sca.sample.comet.EventProcessor" />
+		<service name="EventProcessorConsumerService">
+			<interface.java
+				interface="org.apache.tuscany.sca.sample.comet.EventProcessorConsumerService"
+				callbackInterface="org.apache.tuscany.sca.binding.comet.runtime.callback.CometCallback" />
+			<tuscany:binding.comet />
+			<callback>
+				<tuscany:binding.comet />
+			</callback>
+		</service>
+		<service name="EventProcessorProducerService">
+			<interface.java
+				interface="org.apache.tuscany.sca.sample.comet.EventProcessorProducerService" />
+		</service>
+	</component>
+
+	<component name="SLOWProducerComponent">
+		<implementation.java class="org.apache.tuscany.sca.sample.comet.Producer" />
+		<reference name="eventProcessor" target="EventProcessorComponent" />
+		<property name="eventName">SLOW</property>
+		<property name="frequency">6000</property>
+	</component>
+	
+	<component name="MODERATEProducerComponent">
+		<implementation.java class="org.apache.tuscany.sca.sample.comet.Producer" />
+		<reference name="eventProcessor" target="EventProcessorComponent" />
+		<property name="eventName">MODERATE</property>
+		<property name="frequency">3000</property>
+	</component>
+
+	<component name="FASTProducerComponent">
+		<implementation.java class="org.apache.tuscany.sca.sample.comet.Producer" />
+		<reference name="eventProcessor" target="EventProcessorComponent" />
+		<property name="eventName">FAST</property>
+		<property name="frequency">1000</property>
+	</component>
+
+</composite>
\ No newline at end of file

Added: tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/web.xml
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/web.xml?rev=1127725&view=auto
==============================================================================
--- tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/web.xml (added)
+++ tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/WEB-INF/web.xml Wed May 25 23:27:46 2011
@@ -0,0 +1,34 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+-->
+<web-app xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns="http://java.sun.com/xml/ns/javaee" xmlns:j2ee="http://java.sun.com/xml/ns/javaee" xmlns:web="http://java.sun.com/xml/ns/javaee/web-app_2_5.xsd" xsi:schemaLocation="http://java.sun.com/xml/ns/j2ee http://java.sun.com/xml/ns/j2ee/web-app_3.0.xsd" version="3.0">
+  <display-name>Apache Tuscany Stock Comet Sample</display-name>
+  <filter>
+    <filter-name>tuscany</filter-name>
+    <filter-class>org.apache.tuscany.sca.host.webapp.TuscanyServletFilter</filter-class>
+    <async-supported>true</async-supported>
+  </filter>
+  <filter-mapping>
+    <filter-name>tuscany</filter-name>
+    <url-pattern>/*</url-pattern>
+  </filter-mapping>
+  <welcome-file-list>
+    <welcome-file>index.html</welcome-file>
+  </welcome-file-list>
+</web-app>
\ No newline at end of file

Added: tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/index.html
URL: http://svn.apache.org/viewvc/tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/index.html?rev=1127725&view=auto
==============================================================================
--- tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/index.html (added)
+++ tuscany/sca-java-2.x/contrib/samples/learning-more/binding-comet/pubsub-webapp/src/main/webapp/index.html Wed May 25 23:27:46 2011
@@ -0,0 +1,114 @@
+<!--
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+-->
+<html>
+<head>
+<title>Apache Tuscany Comet Sample</title>
+<!-- Tuscany Comet Javascript Toolkit is dependent on jQuery -->
+<script type="text/javascript"
+	src="https://ajax.googleapis.com/ajax/libs/jquery/1.4.2/jquery.min.js"></script>
+<script type="text/javascript"
+	src="tuscany-comet-js/org.apache.tuscany.sca.CometComponentContext.js"></script>
+<script type="text/javascript">
+		$(document).ready(function()
+		{
+			document.getElementById('registerEventButton').onclick = function(event) {
+				document.getElementById('registerEventName').value;
+			}
+
+			// Tuscany Comet specific API
+			document.getElementById('connect').onclick = function(event) {
+                /* transport can be : long-polling or streaming */
+			 	SCA.TuscanyComet.connect(document.getElementById('transport').value);
+                document.getElementById('connect').disabled = true;
+                document.getElementById('transport').disabled = true;
+			}
+			
+
+			document.getElementById('registerEventButton').onclick = function(event) {
+				var eventName = document.getElementById('registerEventName').value;
+				if (registrationIds[eventName] != null) {
+					alert("Already registered for " + eventName + " events");
+				} else {
+					SCA.CometComponentContext.EventProcessorConsumerService.register(eventName, responseReceived);
+				}
+			}
+
+			document.getElementById('unregisterEventButton').onclick = function(event) {
+				var eventName = document.getElementById('unregisterEventName').value;
+				if (registrationIds[eventName] != null) {
+					SCA.CometComponentContext.EventProcessorConsumerService.unregister(registrationIds[eventName], responseReceived);
+					registrationIds[eventName] = null;
+				} else {
+					alert("Not registered for " + eventName + " events");
+				}
+			}
+
+		});
+		
+		var registrationIds = {};
+		
+		function responseReceived(event) {
+			var text = '';
+			if (event.id != null) {
+				// registration notification
+				registrationIds[event.name] = event.id;
+				text = "Registered to " + event.name + " with id " + event.id + " at " + event.data;
+			} else {
+				// event notification
+				text = event.name + ": " + event.data;
+			}
+			var textarea = document.getElementById('textarea'); 
+			textarea.value += text + "\n";
+			textarea.scrollTop = textarea.scrollHeight; 
+		}
+
+		</script>
+</head>
+<body>
+	<div id='sidebar'>
+		<h2>Apache Tuscany Comet Sample</h2>
+		<label>Select transport</label> <select id="transport">
+			<option id="streaming" value="streaming">http streaming</option>
+			<option id="long-polling" value="long-polling">long-polling</option>
+		</select> <input id='connect' type='submit' value='Connect' />
+		<h3>PubSub for FAST, MODERATE and SLOW events</h3>
+		<p />
+		<table>
+			<tr>
+				<td>Event name</td>
+				<td><input type="text" id='registerEventName' value='FAST' />
+				</td>
+				<td><input type="button" id='registerEventButton'
+					value='Register' />
+				</td>
+			</tr>
+			<tr>
+				<td>Event name</td>
+				<td><input type="text" id='unregisterEventName' value='FAST' />
+				</td>
+				<td><input type="button" id='unregisterEventButton'
+					value='Unregister' />
+				</td>
+			</tr>
+		</table>
+		<h3>Server notifications</h3>
+		<textarea id="textarea" rows="15" cols="80" readonly></textarea>
+	</div>
+</body>
+</html>