You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@oodt.apache.org by sm...@apache.org on 2010/06/11 22:38:59 UTC

svn commit: r953864 [1/5] - in /incubator/oodt/trunk: resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/ resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/ resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/ resour...

Author: smcclees
Date: Fri Jun 11 20:38:55 2010
New Revision: 953864

URL: http://svn.apache.org/viewvc?rev=953864&view=rev
Log:
OODT-3 Progress: *.java files are finished 

Modified:
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/Batchmgr.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/BatchmgrFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgr.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgrFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgrProxy.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/HelloWorldJob.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/LongJob.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/TestResmgr.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobQueue.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobQueueFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobStack.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobStackJobQueueFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/JobRepository.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/JobRepositoryFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/MemoryJobRepository.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/MemoryJobRepositoryFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/metadata/JobMetadata.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/AssignmentMonitor.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/AssignmentMonitorFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/Monitor.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/MonitorFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/LRUScheduler.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/LRUSchedulerFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/Scheduler.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/SchedulerFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/Job.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobInput.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobInstance.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobSpec.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobStatus.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/NameValueJobInput.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/ResourceNode.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobException.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobExecutionException.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobInputException.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobQueueException.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobRepositoryException.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/MonitorException.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/SchedulerException.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/system/XmlRpcResourceManager.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/system/XmlRpcResourceManagerClient.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/system/extern/XmlRpcBatchStub.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/tools/JobSubmitter.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/tools/RunDirJobSubmitter.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/util/Configurable.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/util/GenericResourceManagerObjectFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/util/JobBuilder.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/util/Ulimit.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/util/UlimitMetKeys.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/util/UlimitProperty.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/util/XmlRpcStructFactory.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/util/XmlRpcWriteable.java
    incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/util/XmlStructFactory.java
    incubator/oodt/trunk/resource/src/test/gov/nasa/jpl/oodt/cas/resource/jobqueue/TestJobStack.java
    incubator/oodt/trunk/resource/src/test/gov/nasa/jpl/oodt/cas/resource/monitor/TestAssignmentMonitor.java
    incubator/oodt/trunk/resource/src/test/gov/nasa/jpl/oodt/cas/resource/util/TestUlimit.java
    incubator/oodt/trunk/sso/src/main/java/gov/nasa/jpl/oodt/cas/security/sso/AbstractWebBasedSingleSignOn.java
    incubator/oodt/trunk/sso/src/main/java/gov/nasa/jpl/oodt/cas/security/sso/DummyImpl.java
    incubator/oodt/trunk/sso/src/main/java/gov/nasa/jpl/oodt/cas/security/sso/SingleSignOn.java
    incubator/oodt/trunk/sso/src/main/java/gov/nasa/jpl/oodt/cas/security/sso/SingleSignOnFactory.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/CASProductHandler.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/CASProductHandlerMetKeys.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/data/DataDeliveryKeys.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/data/DataDeliveryServlet.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/data/DataUtils.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/data/DatasetDeliveryServlet.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rdf/ProductTypeFilter.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rdf/RDFConfig.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rdf/RDFConfigMetKeys.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rdf/RDFConfigReader.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rdf/RDFConfigReaderMetKeys.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rdf/RDFDatasetServlet.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rdf/RDFProductServlet.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rdf/RDFUtils.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rss/RSSConfig.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rss/RSSConfigMetKeys.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rss/RSSConfigReader.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rss/RSSConfigReaderMetKeys.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rss/RSSProductServlet.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rss/RSSProductTransferServlet.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rss/RSSTag.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rss/RSSTagAttribute.java
    incubator/oodt/trunk/webapp/fmprod/src/main/java/gov/nasa/jpl/oodt/cas/product/rss/RSSUtils.java
    incubator/oodt/trunk/webapp/fmprod/src/test/gov/nasa/jpl/oodt/cas/product/rdf/TestRDFConfigReader.java
    incubator/oodt/trunk/webapp/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/webapp/util/JspUtility.java
    incubator/oodt/trunk/webapp/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/webapp/util/WorkflowInstanceMetMap.java
    incubator/oodt/trunk/webapp/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/webapp/util/WorkflowInstanceMetMapKeys.java
    incubator/oodt/trunk/webapp/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/webapp/util/WorkflowInstanceMetadataReader.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/engine/IterativeWorkflowProcessorThread.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/engine/NonBlockingIterativeWorkflowProcessorThread.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/engine/NonBlockingShepardThread.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/engine/NonBlockingThreadPoolWorkflowEngine.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/engine/NonBlockingThreadPoolWorkflowEngineFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/engine/ThreadPoolWorkflowEngine.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/engine/ThreadPoolWorkflowEngineFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/engine/WorkflowEngine.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/engine/WorkflowEngineFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/engine/WorkflowProcessorThread.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/examples/CheckForMetadataKeys.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/examples/ExternScriptTaskInstance.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/examples/FalseCondition.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/examples/GoodbyeWorld.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/examples/HelloWorld.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/examples/LongCondition.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/examples/LongTask.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/examples/MailTask.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/examples/NumIncrementTask.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/examples/RandomStatusUpdateTask.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/examples/TrueCondition.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/instrepo/AbstractPaginatibleInstanceRepository.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/instrepo/DataSourceWorkflowInstanceRepository.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/instrepo/DataSourceWorkflowInstanceRepositoryFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/instrepo/LuceneWorkflowInstanceRepository.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/instrepo/LuceneWorkflowInstanceRepositoryFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/instrepo/MemoryWorkflowInstanceRepository.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/instrepo/MemoryWorkflowInstanceRepositoryFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/instrepo/WorkflowInstanceRepository.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/instrepo/WorkflowInstanceRepositoryFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/lifecycle/WorkflowLifecycle.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/lifecycle/WorkflowLifecycleManager.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/lifecycle/WorkflowLifecycleMetKeys.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/lifecycle/WorkflowLifecycleStage.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/lifecycle/WorkflowLifecyclesReader.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/metadata/CoreMetKeys.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/repository/DataSourceWorkflowRepository.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/repository/DataSourceWorkflowRepositoryFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/repository/WorkflowRepository.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/repository/WorkflowRepositoryFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/repository/XMLWorkflowRepository.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/repository/XMLWorkflowRepositoryFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/TaskJob.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/TaskJobInput.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/Workflow.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/WorkflowCondition.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/WorkflowConditionConfiguration.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/WorkflowConditionInstance.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/WorkflowInstance.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/WorkflowInstancePage.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/WorkflowStatus.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/WorkflowTask.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/WorkflowTaskConfiguration.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/WorkflowTaskInstance.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/exceptions/EngineException.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/exceptions/InstanceRepositoryException.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/exceptions/RepositoryException.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/structs/exceptions/WorkflowTaskInstanceException.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/system/XmlRpcWorkflowManager.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/system/XmlRpcWorkflowManagerClient.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/util/DbStructFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/util/GenericWorkflowObjectFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/util/Pagination.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/util/ScriptFile.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/util/XmlRpcStructFactory.java
    incubator/oodt/trunk/workflow/src/main/java/gov/nasa/jpl/oodt/cas/workflow/util/XmlStructFactory.java
    incubator/oodt/trunk/workflow/src/test/gov/nasa/jpl/oodt/cas/workflow/engine/TestThreadPoolWorkflowEngine.java
    incubator/oodt/trunk/workflow/src/test/gov/nasa/jpl/oodt/cas/workflow/examples/TestExternScriptTaskInstance.java
    incubator/oodt/trunk/workflow/src/test/gov/nasa/jpl/oodt/cas/workflow/instrepo/TestLuceneWorkflowInstanceRepository.java
    incubator/oodt/trunk/workflow/src/test/gov/nasa/jpl/oodt/cas/workflow/repository/TestWorkflowDataSourceRepository.java
    incubator/oodt/trunk/workflow/src/test/gov/nasa/jpl/oodt/cas/workflow/repository/TestWorkflowRepository.java
    incubator/oodt/trunk/workflow/src/test/gov/nasa/jpl/oodt/cas/workflow/util/TestGenericWorkflowObjectFactory.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/product/ProductException.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/product/Retriever.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/ByteArrayCodec.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/Codec.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/CodecFactory.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/CompressedObjectCodec.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/CompressedStringCodec.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/Header.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/ObjectCodec.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/QueryElement.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/QueryException.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/QueryHeader.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/QueryResult.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/Result.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/Results.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/Statistic.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/StringCodec.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/UnsupportedMimeTypeCodec.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/XMLQuery.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/activity/QueryConstructed.java
    incubator/oodt/trunk/xmlquery/src/main/java/jpl/eda/xmlquery/activity/ResultsReceived.java
    incubator/oodt/trunk/xmlquery/src/test/jpl/eda/xmlquery/CodecFactoryTest.java
    incubator/oodt/trunk/xmlquery/src/test/jpl/eda/xmlquery/CodecTest.java
    incubator/oodt/trunk/xmlquery/src/test/jpl/eda/xmlquery/CompressedObjectCodecTest.java
    incubator/oodt/trunk/xmlquery/src/test/jpl/eda/xmlquery/CompressedStringCodecTest.java
    incubator/oodt/trunk/xmlquery/src/test/jpl/eda/xmlquery/EmptyByteArrayCodecTest.java
    incubator/oodt/trunk/xmlquery/src/test/jpl/eda/xmlquery/HeaderTest.java
    incubator/oodt/trunk/xmlquery/src/test/jpl/eda/xmlquery/ObjectCodecTest.java
    incubator/oodt/trunk/xmlquery/src/test/jpl/eda/xmlquery/QueryElementTest.java
    incubator/oodt/trunk/xmlquery/src/test/jpl/eda/xmlquery/ResultTest.java
    incubator/oodt/trunk/xmlquery/src/test/jpl/eda/xmlquery/StringCodecTest.java
    incubator/oodt/trunk/xmlquery/src/test/jpl/eda/xmlquery/XMLQueryTest.java

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/Batchmgr.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/Batchmgr.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/Batchmgr.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/Batchmgr.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.batchmgr;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/BatchmgrFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/BatchmgrFactory.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/BatchmgrFactory.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/BatchmgrFactory.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.batchmgr;
 
@@ -20,4 +33,4 @@ public interface BatchmgrFactory {
 	 * @return A new implementation of the {@link Batchmgr} interface.
 	 */
 	public Batchmgr createBatchmgr();
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgr.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgr.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgr.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgr.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.batchmgr;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgrFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgrFactory.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgrFactory.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgrFactory.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.batchmgr;
 
@@ -34,4 +47,4 @@ public class XmlRpcBatchMgrFactory imple
 		return new XmlRpcBatchMgr();
 	}
 
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgrProxy.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgrProxy.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgrProxy.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/batchmgr/XmlRpcBatchMgrProxy.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.batchmgr;
 
@@ -117,4 +130,4 @@ public class XmlRpcBatchMgrProxy extends
         parent.jobComplete(jobSpec);
     }
 
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/HelloWorldJob.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/HelloWorldJob.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/HelloWorldJob.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/HelloWorldJob.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.examples;
 
@@ -42,4 +55,4 @@ public class HelloWorldJob implements Jo
     return true;
   }
 
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/LongJob.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/LongJob.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/LongJob.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/LongJob.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.examples;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/TestResmgr.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/TestResmgr.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/TestResmgr.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/examples/TestResmgr.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.examples;
 
@@ -50,4 +63,4 @@ public class TestResmgr {
     }
 
   }
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobQueue.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobQueue.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobQueue.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobQueue.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.jobqueue;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobQueueFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobQueueFactory.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobQueueFactory.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobQueueFactory.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.jobqueue;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobStack.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobStack.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobStack.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobStack.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.jobqueue;
 
@@ -143,4 +156,4 @@ public class JobStack implements JobQueu
 		return this.queue.size();
 	}
 
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobStackJobQueueFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobStackJobQueueFactory.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobStackJobQueueFactory.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobqueue/JobStackJobQueueFactory.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.jobqueue;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/JobRepository.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/JobRepository.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/JobRepository.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/JobRepository.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.jobrepo;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/JobRepositoryFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/JobRepositoryFactory.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/JobRepositoryFactory.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/JobRepositoryFactory.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.jobrepo;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/MemoryJobRepository.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/MemoryJobRepository.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/MemoryJobRepository.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/MemoryJobRepository.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.jobrepo;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/MemoryJobRepositoryFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/MemoryJobRepositoryFactory.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/MemoryJobRepositoryFactory.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/jobrepo/MemoryJobRepositoryFactory.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.jobrepo;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/metadata/JobMetadata.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/metadata/JobMetadata.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/metadata/JobMetadata.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/metadata/JobMetadata.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.metadata;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/AssignmentMonitor.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/AssignmentMonitor.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/AssignmentMonitor.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/AssignmentMonitor.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.monitor;
 
@@ -222,4 +235,4 @@ public class AssignmentMonitor implement
         return resources;
     }
 
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/AssignmentMonitorFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/AssignmentMonitorFactory.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/AssignmentMonitorFactory.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/AssignmentMonitorFactory.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.monitor;
 
@@ -48,4 +61,4 @@ public class AssignmentMonitorFactory im
 		}
 	}
 
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/Monitor.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/Monitor.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/Monitor.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/Monitor.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.monitor;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/MonitorFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/MonitorFactory.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/MonitorFactory.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/monitor/MonitorFactory.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.monitor;
 
@@ -20,4 +33,4 @@ public interface MonitorFactory {
 	 * @return A new implementation of the {@link Monitor} interface.
 	 */
 	public Monitor createMonitor();
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/LRUScheduler.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/LRUScheduler.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/LRUScheduler.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/LRUScheduler.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.scheduler;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/LRUSchedulerFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/LRUSchedulerFactory.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/LRUSchedulerFactory.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/LRUSchedulerFactory.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.scheduler;
 
@@ -86,4 +99,4 @@ public class LRUSchedulerFactory impleme
     }
   }
 
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/Scheduler.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/Scheduler.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/Scheduler.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/Scheduler.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.scheduler;
 
@@ -67,4 +80,4 @@ public interface Scheduler extends Runna
   */
  public JobQueue getJobQueue();
 
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/SchedulerFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/SchedulerFactory.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/SchedulerFactory.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/scheduler/SchedulerFactory.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.scheduler;
 
@@ -20,4 +33,4 @@ public interface SchedulerFactory {
 	 * @return A new implementation of the {@link Scheduler} interface.
 	 */
 	public Scheduler createScheduler();
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/Job.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/Job.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/Job.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/Job.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs;
 
@@ -157,4 +170,4 @@ public class Job {
         this.status = status;
     }
 
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobInput.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobInput.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobInput.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobInput.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobInstance.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobInstance.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobInstance.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobInstance.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs;
 
 import gov.nasa.jpl.oodt.cas.resource.structs.exceptions.JobInputException;

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobSpec.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobSpec.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobSpec.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobSpec.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobStatus.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobStatus.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobStatus.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/JobStatus.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/NameValueJobInput.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/NameValueJobInput.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/NameValueJobInput.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/NameValueJobInput.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/ResourceNode.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/ResourceNode.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/ResourceNode.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/ResourceNode.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs;
 
@@ -54,4 +67,4 @@ public class ResourceNode {
 	public void setCapacity(int capacity){
 		this.capacity = capacity;
 	}
-}
\ No newline at end of file
+}

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobException.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobException.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobException.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobException.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs.exceptions;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobExecutionException.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobExecutionException.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobExecutionException.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobExecutionException.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs.exceptions;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobInputException.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobInputException.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobInputException.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobInputException.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs.exceptions;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobQueueException.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobQueueException.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobQueueException.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobQueueException.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs.exceptions;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobRepositoryException.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobRepositoryException.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobRepositoryException.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/JobRepositoryException.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs.exceptions;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/MonitorException.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/MonitorException.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/MonitorException.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/MonitorException.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs.exceptions;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/SchedulerException.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/SchedulerException.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/SchedulerException.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/structs/exceptions/SchedulerException.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.structs.exceptions;
 

Modified: incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/system/XmlRpcResourceManager.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/system/XmlRpcResourceManager.java?rev=953864&r1=953863&r2=953864&view=diff
==============================================================================
--- incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/system/XmlRpcResourceManager.java (original)
+++ incubator/oodt/trunk/resource/src/main/java/gov/nasa/jpl/oodt/cas/resource/system/XmlRpcResourceManager.java Fri Jun 11 20:38:55 2010
@@ -1,7 +1,20 @@
-//Copyright (c) 2006, California Institute of Technology.
-//ALL RIGHTS RESERVED. U.S. Government sponsorship acknowledged.
-//
-//$Id$
+/*
+ * 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 gov.nasa.jpl.oodt.cas.resource.system;
 
@@ -340,4 +353,4 @@ public class XmlRpcResourceManager {
 
         return url;
     }
-}
\ No newline at end of file
+}