From 5963a2d3d6860fe57afc138f095bf2d2eb5a7b80 Mon Sep 17 00:00:00 2001 From: lresende Date: Mon, 7 Oct 2013 22:23:21 +0000 Subject: Official Tuscany 2.0.1 Release git-svn-id: http://svn.us.apache.org/repos/asf/tuscany@1530096 13f79535-47bb-0310-9956-ffa450edef68 --- .../org/apache/tuscany/sca/sample/comet/Event.java | 51 ---------- .../tuscany/sca/sample/comet/EventProcessor.java | 107 --------------------- .../comet/EventProcessorConsumerService.java | 37 ------- .../comet/EventProcessorProducerService.java | 28 ------ .../apache/tuscany/sca/sample/comet/Producer.java | 76 --------------- 5 files changed, 299 deletions(-) delete mode 100644 sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Event.java delete mode 100644 sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessor.java delete mode 100644 sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorConsumerService.java delete mode 100644 sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorProducerService.java delete mode 100644 sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Producer.java (limited to 'sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java') diff --git a/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Event.java b/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Event.java deleted file mode 100644 index bcc6bea7af..0000000000 --- a/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Event.java +++ /dev/null @@ -1,51 +0,0 @@ -/* - * 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; - -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; - } - -} diff --git a/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessor.java b/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessor.java deleted file mode 100644 index 838d2f317c..0000000000 --- a/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessor.java +++ /dev/null @@ -1,107 +0,0 @@ -/* - * 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.UUID; -import java.util.concurrent.ConcurrentHashMap; -import java.util.concurrent.ConcurrentMap; - -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 ConcurrentMap clients = new ConcurrentHashMap(); - private Multimap eventListeners = Multimaps.synchronizedMultimap(HashMultimap - . create()); - - @Override - public void onEvent(String eventName, String eventData) { - // System.out.println("EventProcessor: Received event " + eventName + - // "..."); - List destinations = new ArrayList(); - 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; - } -} diff --git a/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorConsumerService.java b/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorConsumerService.java deleted file mode 100644 index c8208e862c..0000000000 --- a/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorConsumerService.java +++ /dev/null @@ -1,37 +0,0 @@ -/* - * 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); - -} diff --git a/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorProducerService.java b/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorProducerService.java deleted file mode 100644 index 49d760d171..0000000000 --- a/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/EventProcessorProducerService.java +++ /dev/null @@ -1,28 +0,0 @@ -/* - * 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); - -} diff --git a/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Producer.java b/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Producer.java deleted file mode 100644 index 59307824ce..0000000000 --- a/sca-java-2.x/tags/2.0.1-RC1/samples/learning-more/binding-comet/pubsub-webapp/src/main/java/org/apache/tuscany/sca/sample/comet/Producer.java +++ /dev/null @@ -1,76 +0,0 @@ -/* - * 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; - } - -} -- cgit v1.2.3