You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@river.apache.org by th...@apache.org on 2012/04/16 16:57:08 UTC

svn commit: r1326638 - in /river/jtsk/skunk/easystart: src-extra-examples/ src-extra-examples/org/ src-extra-examples/org/apache/ src-extra-examples/org/apache/river/ src-extra-examples/org/apache/river/extra/ src-extra-examples/org/apache/river/extra/...

Author: thobbs
Date: Mon Apr 16 14:57:07 2012
New Revision: 1326638

URL: http://svn.apache.org/viewvc?rev=1326638&view=rev
Log:
Added missing license headers.  Started worked example.

Added:
    river/jtsk/skunk/easystart/src-extra-examples/
    river/jtsk/skunk/easystart/src-extra-examples/build.xml
    river/jtsk/skunk/easystart/src-extra-examples/org/
    river/jtsk/skunk/easystart/src-extra-examples/org/apache/
    river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/
    river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/
    river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/
    river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/
    river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ApplicationConfigurationFactory.java
    river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ExampleService.java
    river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ExampleServiceImpl.java
    river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/LookupServices.java
    river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/StartServices.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/InitialLookupAttributesSetting.java
Removed:
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/EasyConfiguration.java
Modified:
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/StartAll.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/AbstractEasyConfiguration.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/ApplicationOptions.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/ConfigurationFactory.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/DefaultOptions.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/JavaSpaceConfiguration.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/LookupServiceConfiguration.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/TransactionServiceConfiguration.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/ClasspathSetting.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/CodebaseSetting.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/GroupedSetting.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/PolicySetting.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/ServerExporterSetting.java
    river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/Setting.java
    river/jtsk/skunk/easystart/src-extra/policy.all

Added: river/jtsk/skunk/easystart/src-extra-examples/build.xml
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra-examples/build.xml?rev=1326638&view=auto
==============================================================================
--- river/jtsk/skunk/easystart/src-extra-examples/build.xml (added)
+++ river/jtsk/skunk/easystart/src-extra-examples/build.xml Mon Apr 16 14:57:07 2012
@@ -0,0 +1,63 @@
+<?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 name="river-extras-examples" basedir="." default="build"
+        xmlns:artifact="antlib:org.apache.maven.artifact.ant">
+	
+	<property name="example.classes" value="./classes"/>
+	<property name="river.jars" value="../lib"/>
+	<property name="example.jar" value="${river.jars}/extra-examples.jar"/>
+	
+	<path id="river.lib">
+		<pathelement path="../lib/jsk-platform.jar"/>
+		<pathelement path="../lib/jsk-lib.jar"/>
+		<pathelement path="../lib/tools.jar"/>
+		<pathelement path="../lib/reggie.jar"/>
+		<pathelement path="../lib/extra.jar"/>
+		<pathelement path="../velocity/velocity-1.7.jar"/>
+	</path>
+	
+	<target name="clean">
+		<delete dir="${example.classes}"/>
+	</target>
+	
+	<target name="init" depends="clean">
+		<mkdir dir="${example.classes}"/>
+	</target>
+	
+	<target name="compile" depends="init">
+		<javac srcdir="." 
+			   destdir="${example.classes}"
+			   source="6"
+			   target="6"
+			   debug="true">
+			<classpath refid="river.lib"/>
+		</javac>
+	</target>
+	
+	<target name="jar" depends="compile">
+		<jar destfile="${example.jar}">
+			<fileset dir="${example.classes}" includes="**/*.class"/>
+		</jar>
+	</target>
+	
+	<target name="build" depends="init,compile,jar,clean">
+		<antcall target="clean"/>
+	</target>
+</project>
\ No newline at end of file

Added: river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ApplicationConfigurationFactory.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ApplicationConfigurationFactory.java?rev=1326638&view=auto
==============================================================================
--- river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ApplicationConfigurationFactory.java (added)
+++ river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ApplicationConfigurationFactory.java Mon Apr 16 14:57:07 2012
@@ -0,0 +1,39 @@
+/*
+ * 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.river.extra.examples.easystart;
+
+import net.jini.lookup.entry.Name;
+
+import org.apache.river.extra.easystart.config.AbstractEasyConfiguration;
+import org.apache.river.extra.easystart.config.ApplicationOptions;
+import org.apache.river.extra.easystart.config.ConfigurationFactory;
+
+public class ApplicationConfigurationFactory extends ConfigurationFactory {
+
+	public ApplicationConfigurationFactory(ApplicationOptions options) {
+		super(options);
+	}
+
+	public AbstractEasyConfiguration exampleService(Name name) {
+		ApplicationOptions exampleOptions = getDefaultOptions();
+		exampleOptions.setImplementationClass(ExampleServiceImpl.class);
+		exampleOptions.addInitialLookupAttribute(new Name("Jeff"));
+		return new AbstractEasyConfiguration(exampleOptions) {};
+	}
+
+}

Added: river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ExampleService.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ExampleService.java?rev=1326638&view=auto
==============================================================================
--- river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ExampleService.java (added)
+++ river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ExampleService.java Mon Apr 16 14:57:07 2012
@@ -0,0 +1,35 @@
+/*
+ * 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.river.extra.examples.easystart;
+
+import java.io.Serializable;
+import java.rmi.Remote;
+import java.rmi.RemoteException;
+
+import net.jini.admin.Administrable;
+
+import com.sun.jini.admin.DestroyAdmin;
+
+public interface ExampleService extends Remote, 
+										Administrable,
+										DestroyAdmin,
+										Serializable  {
+	
+	String doSomething() throws RemoteException;
+
+}

Added: river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ExampleServiceImpl.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ExampleServiceImpl.java?rev=1326638&view=auto
==============================================================================
--- river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ExampleServiceImpl.java (added)
+++ river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/ExampleServiceImpl.java Mon Apr 16 14:57:07 2012
@@ -0,0 +1,149 @@
+/*
+ * 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.river.extra.examples.easystart;
+
+import java.io.IOException;
+import java.rmi.RemoteException;
+import java.util.logging.Level;
+import java.util.logging.Logger;
+
+import net.jini.config.Configuration;
+import net.jini.config.ConfigurationException;
+import net.jini.config.ConfigurationProvider;
+import net.jini.core.discovery.LookupLocator;
+import net.jini.core.entry.Entry;
+import net.jini.core.lookup.ServiceID;
+import net.jini.discovery.LookupDiscovery;
+import net.jini.discovery.LookupDiscoveryManager;
+import net.jini.export.Exporter;
+import net.jini.jrmp.JrmpExporter;
+import net.jini.lookup.JoinManager;
+import net.jini.lookup.ServiceIDListener;
+import net.jini.security.BasicProxyPreparer;
+import net.jini.security.ProxyPreparer;
+
+import com.sun.jini.config.Config;
+import com.sun.jini.start.LifeCycle;
+
+public class ExampleServiceImpl implements ExampleService {
+
+	private static final long serialVersionUID = -3388051367238615846L;
+	private static final Logger log = Logger.getLogger(ExampleServiceImpl.class.getName());
+
+	private static final String PACKAGE = "org.apache.river.extra.examples.easystart";
+	
+	private Object proxy;
+    private Exporter exporter;
+    private JoinManager joinManager;
+    
+	public ExampleServiceImpl(String[] configArgs, LifeCycle lifeCycle) throws RemoteException {
+		try {
+			init(configArgs);
+		} catch (IOException ioe) {
+			throw new RemoteException("Unable to start service because: "+ioe.getMessage(), ioe);
+		} catch (ConfigurationException ce) {
+			throw new RemoteException("Invalid configuration: "+ce.getMessage(), ce);
+		}
+	}
+	
+	private void init(String[] configArgs) throws RemoteException, IOException, ConfigurationException {
+		Configuration config = ConfigurationProvider.getInstance(configArgs);
+		
+		Exporter defaultExporter = new JrmpExporter();
+		
+		exporter = defaultExporter;
+
+		java.rmi.Remote stub = exporter.export(this);
+
+		ProxyPreparer proxyPreparer = (ProxyPreparer) Config.getNonNullEntry(
+				config,
+				PACKAGE,
+                "proxyPreparer",
+                ProxyPreparer.class,
+                new BasicProxyPreparer());
+
+		proxy = proxyPreparer.prepareProxy(stub);
+		
+		Entry[] atts = (Entry[]) Config.getNonNullEntry(config,
+                										PACKAGE, 
+                										"initialLookupAttributes", 
+                										Entry[].class, 
+                										new Entry[]{});
+
+		
+		final String[] groups = (String[]) config.getEntry(PACKAGE,
+														   "initialLookupGroups",
+														   String[].class, 
+														   LookupDiscovery.ALL_GROUPS);
+		
+		LookupLocator[] lookupLocators = (LookupLocator[]) Config.getNonNullEntry(config,
+                PACKAGE, "initialLookupLocators", LookupLocator[].class, new LookupLocator[0]);
+
+		
+		ServiceIDListener serviceIdListener = new ServiceIDListener() {
+			
+			@Override
+			public void serviceIDNotify(ServiceID serviceID) {
+				log.warning("Allocated serviceId: "+serviceID);
+			}
+		};
+		
+		LookupDiscoveryManager mgr = new LookupDiscoveryManager(groups,lookupLocators, null); // DiscoveryListener
+		
+        joinManager = new JoinManager(proxy, 
+        						      atts, 
+        						      serviceIdListener, 
+        						      mgr, 
+        						      null,
+        						      config);
+        
+        Runtime.getRuntime().addShutdownHook(new Thread(new Runnable() {
+
+			@Override
+			public void run() {
+				try {
+					ExampleServiceImpl.this.destroy();
+				} catch (RemoteException re) {
+					log.log(Level.SEVERE, "Failed to cleanly destroy service", re);
+				}
+			}
+        	
+        }));
+        
+	}
+	
+	@Override
+	public Object getAdmin() throws RemoteException {
+		return this;
+	}
+
+	@Override
+	public String doSomething() throws RemoteException {
+		log.warning("Doing something");
+		return "Something done";
+	}
+
+	@Override
+	public void destroy() throws RemoteException {
+		joinManager.getDiscoveryManager().terminate();
+        joinManager.terminate();
+        exporter.unexport(true);
+	}
+
+	
+}

Added: river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/LookupServices.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/LookupServices.java?rev=1326638&view=auto
==============================================================================
--- river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/LookupServices.java (added)
+++ river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/LookupServices.java Mon Apr 16 14:57:07 2012
@@ -0,0 +1,63 @@
+/*
+ * 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.river.extra.examples.easystart;
+
+import java.io.IOException;
+import java.util.Arrays;
+import java.util.List;
+import java.util.logging.Logger;
+
+import net.jini.core.lookup.ServiceItem;
+import net.jini.core.lookup.ServiceTemplate;
+
+import org.apache.river.extra.discovery.EasyDiscovery;
+import org.apache.river.extra.discovery.MulticastDiscovery;
+import org.apache.river.extra.easystart.config.ApplicationOptions;
+
+public class LookupServices {
+
+	private static final Logger log = Logger.getLogger(LookupServices.class.getName());
+	
+	/**
+	 * @param args
+	 * @throws IOException 
+	 * @throws InterruptedException 
+	 */
+	public static void main(String[] args) throws IOException, InterruptedException {
+		ApplicationOptions options = new ApplicationOptions();
+		options.setJiniPort(4162);
+		options.setHttpOptions("localhost", 8080, true);
+		options.addLookupGroup("extra").addLookupGroup("example");
+		options.setPackageName("org.apache.river.extra.examples");
+
+		EasyDiscovery disco = new MulticastDiscovery(new String[] {"extra", "example"});
+		
+		Thread.sleep(3000);
+		
+		ServiceTemplate template = new ServiceTemplate(null,
+													   new Class<?>[] { ExampleService.class },
+													   null);
+		
+		List<ServiceItem> serviceItems = disco.lookupAll(template);
+		log.severe("Found "+serviceItems.size()+" services");
+		for(ServiceItem si : serviceItems) {
+			log.severe("\tAttributes: "+Arrays.toString(si.attributeSets));
+		}
+	}
+
+}

Added: river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/StartServices.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/StartServices.java?rev=1326638&view=auto
==============================================================================
--- river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/StartServices.java (added)
+++ river/jtsk/skunk/easystart/src-extra-examples/org/apache/river/extra/examples/easystart/StartServices.java Mon Apr 16 14:57:07 2012
@@ -0,0 +1,51 @@
+/*
+ * 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.river.extra.examples.easystart;
+
+import java.io.IOException;
+
+import net.jini.config.ConfigurationException;
+import net.jini.lookup.entry.Name;
+
+import org.apache.river.extra.easystart.config.AbstractEasyConfiguration;
+import org.apache.river.extra.easystart.config.ApplicationOptions;
+import org.apache.river.extra.easystart.config.LookupServiceConfiguration;
+
+import com.sun.jini.start.ServiceStarter;
+
+public class StartServices {
+
+	public static void main(String[] args) throws ConfigurationException, IOException {
+		
+		ApplicationOptions options = new ApplicationOptions();
+		options.setJiniPort(4162);
+		options.setHttpOptions("localhost", 8080, true);
+		options.addLookupGroup("extra").addLookupGroup("example");
+		options.setPackageName("org.apache.river.extra.examples");
+		
+		ApplicationConfigurationFactory configFac = new ApplicationConfigurationFactory(options);
+		
+		LookupServiceConfiguration lusConfig = configFac.lookupServiceConfig();
+		lusConfig.addMemberGroup("extra").addMemberGroup("extra");
+		ServiceStarter.main(lusConfig.riverConfig());
+		
+		AbstractEasyConfiguration config = configFac.exampleService(new Name("Jeff"));
+		ServiceStarter.main(config.riverConfig());
+	}
+	
+}

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/StartAll.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/StartAll.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/StartAll.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/StartAll.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart;
 
 import java.io.File;

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/AbstractEasyConfiguration.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/AbstractEasyConfiguration.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/AbstractEasyConfiguration.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/AbstractEasyConfiguration.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart.config;
 
 import java.io.IOException;

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/ApplicationOptions.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/ApplicationOptions.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/ApplicationOptions.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/ApplicationOptions.java Mon Apr 16 14:57:07 2012
@@ -1,5 +1,29 @@
+/*
+ * 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.river.extra.easystart.config;
 
+import java.util.Collection;
+
+import net.jini.lookup.entry.Name;
+
+import org.apache.river.extra.easystart.config.settings.Setting;
+
+
 
 public class ApplicationOptions extends DefaultOptions {
 
@@ -22,5 +46,40 @@ public class ApplicationOptions extends 
 		super.getGrouped(DefaultOptions.LOOKUP_GROUP).add(group);
 		return this;
 	}
+
+	public ApplicationOptions setRiverHome(String riverHome) {
+		super.get(DefaultOptions.RIVER_HOME).setOverride(riverHome);
+		return this;
+	}
+
+	public ApplicationOptions setPackageName(String packageName) {
+		super.get(DefaultOptions.PACKAGE_NAME).setOverride(packageName);
+		return this;
+	}
+
+	public ApplicationOptions setImplementationClass(Class<?> class1) {
+		return setImplementationClass(class1.getName());
+	}
+	
+	public ApplicationOptions setImplementationClass(String implClass) {
+		super.get(DefaultOptions.SERVICE_IMPL).setOverride(implClass);
+		return this;
+	}
 	
+	public ApplicationOptions addInitialLookupAttribute(Name name) {
+		super.getInitialLookupAttributes().add(name);
+		return this;
+	}
+	
+	@Override
+	public Object clone() {
+		ApplicationOptions clone = new ApplicationOptions();
+		
+		Collection<Setting> options = super.getOptions();
+		for(Setting option : options) {
+			clone.add((Setting)option.clone());
+		}
+		
+		return clone;
+	}
 }

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/ConfigurationFactory.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/ConfigurationFactory.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/ConfigurationFactory.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/ConfigurationFactory.java Mon Apr 16 14:57:07 2012
@@ -1,12 +1,29 @@
+/*
+ * 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.river.extra.easystart.config;
 
 
 public class ConfigurationFactory {
 
-	private final DefaultOptions options;
+	private final ApplicationOptions options;
 	
-	public ConfigurationFactory(DefaultOptions options) {
-		this.options = (DefaultOptions) options.clone();
+	public ConfigurationFactory(ApplicationOptions options) {
+		this.options = (ApplicationOptions) options.clone();
 	}
 
 	public LookupServiceConfiguration lookupServiceConfig() {
@@ -21,4 +38,8 @@ public class ConfigurationFactory {
 		return new TransactionServiceConfiguration(options);
 	}
 	
+	protected ApplicationOptions getDefaultOptions() {
+		return (ApplicationOptions) this.options.clone();
+	}
+	
 }

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/DefaultOptions.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/DefaultOptions.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/DefaultOptions.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/DefaultOptions.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart.config;
 
 import java.util.Collection;
@@ -10,6 +27,7 @@ import java.util.logging.Logger;
 import org.apache.river.extra.easystart.config.settings.ClasspathSetting;
 import org.apache.river.extra.easystart.config.settings.CodebaseSetting;
 import org.apache.river.extra.easystart.config.settings.GroupedSetting;
+import org.apache.river.extra.easystart.config.settings.InitialLookupAttributesSetting;
 import org.apache.river.extra.easystart.config.settings.PolicySetting;
 import org.apache.river.extra.easystart.config.settings.ServerExporterSetting;
 import org.apache.river.extra.easystart.config.settings.Setting;
@@ -35,6 +53,8 @@ public class DefaultOptions implements C
 	public static final String RIVER_HOME = "riverHome";
 	public static final String HTTP_PORT = "httpPort";
 	public static final String HTTP_SERVER = "httpServer";
+	public static final String SERVICE_NAME = "serviceName";
+	public static final String INITIAL_ATTRIBS = "initialLookupAttributes";
 
 	
 	private static String RIVER_HOME_DIR;
@@ -89,6 +109,7 @@ public class DefaultOptions implements C
 												  STRING_FORMAT,
 												  false));
 		options.put("serverExporter", new ServerExporterSetting());
+		options.put(INITIAL_ATTRIBS, new InitialLookupAttributesSetting());
 	}
 	
 	private DefaultOptions(Map<String, Setting> opts) {
@@ -105,6 +126,10 @@ public class DefaultOptions implements C
 		return (GroupedSetting) get(key);
 	}
 	
+	protected InitialLookupAttributesSetting getInitialLookupAttributes() {
+		return (InitialLookupAttributesSetting) get(INITIAL_ATTRIBS);
+	}
+	
 	public Collection<Setting> getOptions() {
 		return options.values();
 	}
@@ -120,5 +145,9 @@ public class DefaultOptions implements C
 		}
 		return new DefaultOptions(clonedOptions);
 	}
+
+	public void add(Setting n) {
+		options.put(n.getName(), n);
+	}
 	
 }

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/JavaSpaceConfiguration.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/JavaSpaceConfiguration.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/JavaSpaceConfiguration.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/JavaSpaceConfiguration.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart.config;
 
 
@@ -11,6 +28,7 @@ public class JavaSpaceConfiguration exte
 		getDefaultOptions().getGrouped(DefaultOptions.CODEBASE).add("outrigger-dl.jar").add("jsk-dl.jar");
 		getDefaultOptions().getGrouped(DefaultOptions.CLASSPATH).add(opts.get(DefaultOptions.RIVER_HOME).getOverride()+"/lib/outrigger.jar");
 		getDefaultOptions().getGrouped(DefaultOptions.CLASSPATH).add(opts.get(DefaultOptions.RIVER_HOME).getOverride()+"/lib/jini-ext.jar");
+		getDefaultOptions().getGrouped(DefaultOptions.CLASSPATH).add(opts.get(DefaultOptions.RIVER_HOME).getOverride()+"/lib/jsk-platform.jar");
 	}
 
 }

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/LookupServiceConfiguration.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/LookupServiceConfiguration.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/LookupServiceConfiguration.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/LookupServiceConfiguration.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart.config;
 
 
@@ -11,6 +28,7 @@ public class LookupServiceConfiguration 
 		getDefaultOptions().getGrouped(DefaultOptions.CODEBASE).add("reggie-dl.jar").add("jsk-dl.jar");
 		getDefaultOptions().getGrouped(DefaultOptions.CLASSPATH).add(opts.get(DefaultOptions.RIVER_HOME).getOverride()+"/lib/reggie.jar");
 		getDefaultOptions().getGrouped(DefaultOptions.CLASSPATH).add(opts.get(DefaultOptions.RIVER_HOME).getOverride()+"/lib/jini-ext.jar");
+		getDefaultOptions().getGrouped(DefaultOptions.CLASSPATH).add(opts.get(DefaultOptions.RIVER_HOME).getOverride()+"/lib/jsk-platform.jar");
 	}
 
 	public LookupServiceConfiguration addMemberGroup(String grp) {

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/TransactionServiceConfiguration.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/TransactionServiceConfiguration.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/TransactionServiceConfiguration.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/TransactionServiceConfiguration.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart.config;
 
 
@@ -11,6 +28,7 @@ public class TransactionServiceConfigura
 		getDefaultOptions().getGrouped(DefaultOptions.CODEBASE).add("mahalo-dl.jar").add("jsk-dl.jar");
 		getDefaultOptions().getGrouped(DefaultOptions.CLASSPATH).add(opts.get(DefaultOptions.RIVER_HOME).getOverride()+"/lib/mahalo.jar");
 		getDefaultOptions().getGrouped(DefaultOptions.CLASSPATH).add(opts.get(DefaultOptions.RIVER_HOME).getOverride()+"/lib/jini-ext.jar");
+		getDefaultOptions().getGrouped(DefaultOptions.CLASSPATH).add(opts.get(DefaultOptions.RIVER_HOME).getOverride()+"/lib/jsk-platform.jar");
 	}
 
 ////	public static TransactionServiceConfiguration config() throws IOException, ConfigurationException {

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/ClasspathSetting.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/ClasspathSetting.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/ClasspathSetting.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/ClasspathSetting.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart.config.settings;
 
 import java.util.List;

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/CodebaseSetting.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/CodebaseSetting.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/CodebaseSetting.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/CodebaseSetting.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart.config.settings;
 
 import java.util.List;

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/GroupedSetting.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/GroupedSetting.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/GroupedSetting.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/GroupedSetting.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart.config.settings;
 
 import java.util.LinkedList;

Added: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/InitialLookupAttributesSetting.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/InitialLookupAttributesSetting.java?rev=1326638&view=auto
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/InitialLookupAttributesSetting.java (added)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/InitialLookupAttributesSetting.java Mon Apr 16 14:57:07 2012
@@ -0,0 +1,64 @@
+/*
+ * 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.river.extra.easystart.config.settings;
+
+import java.util.LinkedList;
+import java.util.List;
+
+import net.jini.lookup.entry.Name;
+
+import org.apache.river.extra.easystart.config.DefaultOptions;
+
+public class InitialLookupAttributesSetting extends GroupedSetting {
+
+	public InitialLookupAttributesSetting() {
+		super(DefaultOptions.INITIAL_ATTRIBS, 
+			  new LinkedList<String>(), 
+			  DefaultOptions.NO_FORMAT, 
+			  DefaultOptions.NO_FORMAT, 
+			  true);
+	}
+
+	public void add(Name name) {
+		super.add("new net.jini.lookup.entry.Name(\\\""+name.name+"\\\")");
+	}
+
+	@Override
+	protected String formatAsArray(List<String> items) {
+		StringBuilder sb = new StringBuilder();
+		sb.append("new net.jini.core.entry.Entry[] { ");
+		for(int i=0 ; i<items.size() ; i++) {
+			String item = items.get(i);
+			sb.append(String.format(this.elementFormat, item));
+			if(i < items.size()-1) {
+				sb.append(", ");
+			}
+		}
+		sb.append(" }");
+		
+		return sb.toString();
+	}
+	@Override
+	public Object clone() {
+		InitialLookupAttributesSetting clone = new InitialLookupAttributesSetting();
+		for(String override : this.overrides) {
+			clone.add(override);
+		}
+		return clone;
+	}
+}

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/PolicySetting.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/PolicySetting.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/PolicySetting.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/PolicySetting.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart.config.settings;
 
 import java.io.File;

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/ServerExporterSetting.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/ServerExporterSetting.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/ServerExporterSetting.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/ServerExporterSetting.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart.config.settings;
 
 import org.apache.river.extra.easystart.config.DefaultOptions;

Modified: river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/Setting.java
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/Setting.java?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/Setting.java (original)
+++ river/jtsk/skunk/easystart/src-extra/org/apache/river/extra/easystart/config/settings/Setting.java Mon Apr 16 14:57:07 2012
@@ -1,3 +1,20 @@
+/*
+ * 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.river.extra.easystart.config.settings;
 
 

Modified: river/jtsk/skunk/easystart/src-extra/policy.all
URL: http://svn.apache.org/viewvc/river/jtsk/skunk/easystart/src-extra/policy.all?rev=1326638&r1=1326637&r2=1326638&view=diff
==============================================================================
--- river/jtsk/skunk/easystart/src-extra/policy.all (original)
+++ river/jtsk/skunk/easystart/src-extra/policy.all Mon Apr 16 14:57:07 2012
@@ -1,3 +1,21 @@
+/*
+ * 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.
+ */
+ 
 grant {
     permission java.security.AllPermission "", "";
 };