You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by ma...@apache.org on 2012/11/07 09:13:24 UTC

svn commit: r1406489 [13/19] - in /incubator/ambari/branches/AMBARI-666: ./ ambari-agent/ ambari-agent/conf/ ambari-agent/conf/unix/ ambari-agent/src/main/puppet/manifestloader/ ambari-agent/src/main/puppet/modules/configgenerator/manifests/ ambari-age...

Added: incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/OOZIE/configuration/oozie-site.xml
URL: http://svn.apache.org/viewvc/incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/OOZIE/configuration/oozie-site.xml?rev=1406489&view=auto
==============================================================================
--- incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/OOZIE/configuration/oozie-site.xml (added)
+++ incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/OOZIE/configuration/oozie-site.xml Wed Nov  7 08:13:12 2012
@@ -0,0 +1,1601 @@
+<?xml version="1.0"?>
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one
+  or more contributor license agreements.  See the NOTICE file
+  distributed with this work for additional information
+  regarding copyright ownership.  The ASF licenses this file
+  to you under the Apache License, Version 2.0 (the
+  "License"); you may not use this file except in compliance
+  with the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
+<configuration>
+
+    <!-- ************************** VERY IMPORTANT  ************************** -->
+    <!-- This file is in the Oozie configuration directory only for reference. -->
+    <!-- It is not loaded by Oozie, Oozie uses its own privatecopy.            -->
+    <!-- ************************** VERY IMPORTANT  ************************** -->
+
+    <!-- Base Oozie URL: <SCHEME>://<HOST>:<PORT>/<CONTEXT> -->
+
+    <property>
+        <name>oozie.base.url</name>
+        <value>http://localhost:8080/oozie</value>
+        <description>
+             Base Oozie URL.
+        </description>
+    </property>
+
+    <!-- Services -->
+
+    <property>
+        <name>oozie.system.id</name>
+        <value>oozie-${user.name}</value>
+        <description>
+            The Oozie system ID.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.systemmode</name>
+        <value>NORMAL</value>
+        <description>
+            System mode for  Oozie at startup.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.delete.runtime.dir.on.shutdown</name>
+        <value>true</value>
+        <description>
+            If the runtime directory should be kept after Oozie shutdowns down.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.services</name>
+        <value>
+            org.apache.oozie.service.SchedulerService,
+            org.apache.oozie.service.InstrumentationService,
+            org.apache.oozie.service.CallableQueueService,
+            org.apache.oozie.service.UUIDService,
+            org.apache.oozie.service.ELService,
+            org.apache.oozie.service.AuthorizationService,
+            org.apache.oozie.service.HadoopAccessorService,
+            org.apache.oozie.service.MemoryLocksService,
+            org.apache.oozie.service.DagXLogInfoService,
+            org.apache.oozie.service.SchemaService,
+            org.apache.oozie.service.LiteWorkflowAppService,
+            org.apache.oozie.service.JPAService,
+            org.apache.oozie.service.StoreService,
+            org.apache.oozie.service.CoordinatorStoreService,
+            org.apache.oozie.service.SLAStoreService,
+            org.apache.oozie.service.DBLiteWorkflowStoreService,
+            org.apache.oozie.service.CallbackService,
+            org.apache.oozie.service.ActionService,
+            org.apache.oozie.service.ActionCheckerService,
+            org.apache.oozie.service.RecoveryService,
+            org.apache.oozie.service.PurgeService,
+            org.apache.oozie.service.CoordinatorEngineService,
+            org.apache.oozie.service.BundleEngineService,
+            org.apache.oozie.service.DagEngineService,
+            org.apache.oozie.service.CoordMaterializeTriggerService,
+            org.apache.oozie.service.StatusTransitService,
+            org.apache.oozie.service.PauseTransitService,
+            org.apache.oozie.service.GroupsService,
+            org.apache.oozie.service.ProxyUserService
+        </value>
+        <description>
+            All services to be created and managed by Oozie Services singleton.
+            Class names must be separated by commas.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.services.ext</name>
+        <value> </value>
+        <description>
+            To add/replace services defined in 'oozie.services' with custom implementations.
+            Class names must be separated by commas.
+        </description>
+    </property>
+
+    <!-- ConfigurationService -->
+
+    <property>
+        <name>oozie.service.ConfigurationService.ignore.system.properties</name>
+        <value>
+            oozie.service.AuthorizationService.security.enabled
+        </value>
+        <description>
+            Specifies "oozie.*" properties to cannot be overriden via Java system properties.
+            Property names must be separted by commas.
+        </description>
+    </property>
+
+    <!-- SchedulerService -->
+
+    <property>
+        <name>oozie.service.SchedulerService.threads</name>
+        <value>5</value>
+        <description>
+            The number of threads to be used by the SchedulerService to run deamon tasks.
+            If maxed out, scheduled daemon tasks will be queued up and delayed until threads become available.
+        </description>
+    </property>
+
+    <!--  AuthorizationService -->
+
+    <property>
+        <name>oozie.service.AuthorizationService.authorization.enabled</name>
+        <value>false</value>
+        <description>
+            Specifies whether security (user name/admin role) is enabled or not.
+            If disabled any user can manage Oozie system and manage any job.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.AuthorizationService.default.group.as.acl</name>
+        <value>false</value>
+        <description>
+            Enables old behavior where the User's default group is the job's ACL.
+        </description>
+    </property>
+
+    <!-- InstrumentationService -->
+
+    <property>
+        <name>oozie.service.InstrumentationService.logging.interval</name>
+        <value>60</value>
+        <description>
+            Interval, in seconds, at which instrumentation should be logged by the InstrumentationService.
+            If set to 0 it will not log instrumentation data.
+        </description>
+    </property>
+
+    <!-- PurgeService -->
+    <property>
+        <name>oozie.service.PurgeService.older.than</name>
+        <value>30</value>
+        <description>
+            Completed workflow jobs older than this value, in days, will be purged by the PurgeService.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.PurgeService.coord.older.than</name>
+        <value>7</value>
+        <description>
+            Completed coordinator jobs older than this value, in days, will be purged by the PurgeService.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.PurgeService.bundle.older.than</name>
+        <value>7</value>
+        <description>
+            Completed bundle jobs older than this value, in days, will be purged by the PurgeService.
+        </description>
+    </property>
+
+    <property>
+		<name>oozie.service.PurgeService.purge.limit</name>
+		<value>100</value>
+		<description>
+			Completed Actions purge - limit each purge to this value
+        </description>
+	</property>
+	
+    <property>
+        <name>oozie.service.PurgeService.purge.interval</name>
+        <value>3600</value>
+        <description>
+            Interval at which the purge service will run, in seconds.
+        </description>
+    </property>
+
+    <!-- RecoveryService -->
+
+    <property>
+        <name>oozie.service.RecoveryService.wf.actions.older.than</name>
+        <value>120</value>
+        <description>
+            Age of the actions which are eligible to be queued for recovery, in seconds.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.RecoveryService.callable.batch.size</name>
+        <value>10</value>
+        <description>
+            This value determines the number of callable which will be batched together
+            to be executed by a single thread.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.RecoveryService.interval</name>
+        <value>60</value>
+        <description>
+            Interval at which the RecoverService will run, in seconds.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.RecoveryService.coord.older.than</name>
+        <value>600</value>
+        <description>
+            Age of the Coordinator jobs or actions which are eligible to be queued for recovery, in seconds.
+        </description>
+    </property>
+
+	<property>
+        <name>oozie.service.RecoveryService.bundle.older.than</name>
+        <value>600</value>
+        <description>
+            Age of the Bundle jobs which are eligible to be queued for recovery, in seconds.
+        </description>
+    </property>
+
+    <!-- CallableQueueService -->
+
+    <property>
+        <name>oozie.service.CallableQueueService.queue.size</name>
+        <value>10000</value>
+        <description>Max callable queue size</description>
+    </property>
+
+    <property>
+        <name>oozie.service.CallableQueueService.threads</name>
+        <value>10</value>
+        <description>Number of threads used for executing callables</description>
+    </property>
+
+    <property>
+        <name>oozie.service.CallableQueueService.callable.concurrency</name>
+        <value>3</value>
+        <description>
+            Maximum concurrency for a given callable type.
+            Each command is a callable type (submit, start, run, signal, job, jobs, suspend,resume, etc).
+            Each action type is a callable type (Map-Reduce, Pig, SSH, FS, sub-workflow, etc).
+            All commands that use action executors (action-start, action-end, action-kill and action-check) use
+            the action type as the callable type.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.CallableQueueService.callable.next.eligible</name>
+        <value>true</value>
+        <description>
+            If true, when a callable in the queue has already reached max concurrency,
+            Oozie continuously find next one which has not yet reach max concurrency.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.CallableQueueService.InterruptMapMaxSize</name>
+        <value>500</value>
+        <description>
+            Maximum Size of the Interrupt Map, the interrupt element will not be inserted in the map if exceeded the size.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.CallableQueueService.InterruptTypes</name>
+        <value>kill,resume,suspend,bundle_kill,bundle_resume,bundle_suspend,coord_kill,coord_change,coord_resume,coord_suspend</value>
+        <description>
+            Getting the types of XCommands that are considered to be of Interrupt type
+        </description>
+    </property>
+
+    <!--  CoordMaterializeTriggerService -->
+
+	<property>
+		<name>oozie.service.CoordMaterializeTriggerService.lookup.interval
+		</name>
+		<value>300</value>
+		<description> Coordinator Job Lookup trigger command is scheduled at
+			this "interval" (in seconds).</description>
+	</property>
+
+	<property>
+		<name>oozie.service.CoordMaterializeTriggerService.materialization.window
+		</name>
+		<value>3600</value>
+		<description> Coordinator Job Lookup command materialized each job for
+			this next "window" duration</description>
+	</property>
+
+    <property>
+        <name>oozie.service.CoordMaterializeTriggerService.callable.batch.size</name>
+        <value>10</value>
+        <description>
+            This value determines the number of callable which will be batched together
+            to be executed by a single thread.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.CoordMaterializeTriggerService.materialization.system.limit</name>
+        <value>50</value>
+        <description>
+            This value determines the number of coordinator jobs to be materialized at a given time.
+        </description>
+    </property>
+
+    <property>
+		<name>oozie.service.coord.normal.default.timeout
+		</name>
+		<value>10080</value>
+		<description>Default timeout for a coordinator action input check (in minutes) for normal job.
+            </description>
+	</property>
+
+	<property>
+		<name>oozie.service.coord.default.max.timeout
+		</name>
+		<value>86400</value>
+		<description>Default maximum timeout for a coordinator action input check (in minutes). 86400= 60days
+        </description>
+	</property>
+
+	<property>
+		<name>oozie.service.coord.input.check.requeue.interval
+		</name>
+		<value>60000</value>
+		<description>Command re-queue interval for coordinator data input check (in millisecond).
+        </description>
+	</property>
+
+	<property>
+		<name>oozie.service.coord.default.concurrency
+		</name>
+		<value>1</value>
+		<description>Default concurrency for a coordinator job to determine how many maximum action should
+		be executed at the same time. -1 means infinite concurrency.</description>
+	</property>
+
+    <property>
+		<name>oozie.service.coord.default.throttle
+		</name>
+		<value>12</value>
+		<description>Default throttle for a coordinator job to determine how many maximum action should
+		be in WAITING state at the same time.</description>
+	</property>
+
+	<property>
+		<name>oozie.service.coord.materialization.throttling.factor
+		</name>
+		<value>0.05</value>
+		<description>Determine how many maximum actions should be in WAITING state for a single job at any time. The value is calculated by
+		this factor X the total queue size.</description>
+	</property>
+
+	<!-- ELService -->
+    <!--  List of supported groups for ELService -->
+	<property>
+        <name>oozie.service.ELService.groups</name>
+        <value>workflow,wf-sla-submit,coord-job-submit-freq,coord-job-submit-nofuncs,coord-job-submit-data,coord-job-submit-instances,coord-sla-submit,coord-action-create,coord-action-create-inst,coord-sla-create,coord-action-start</value>
+        <description>List of groups for different ELServices</description>
+    </property>
+
+<!-- Workflow specifics -->
+    <property>
+        <name>oozie.service.ELService.constants.workflow</name>
+        <value>
+            KB=org.apache.oozie.util.ELConstantsFunctions#KB,
+            MB=org.apache.oozie.util.ELConstantsFunctions#MB,
+            GB=org.apache.oozie.util.ELConstantsFunctions#GB,
+            TB=org.apache.oozie.util.ELConstantsFunctions#TB,
+            PB=org.apache.oozie.util.ELConstantsFunctions#PB,
+            RECORDS=org.apache.oozie.action.hadoop.HadoopELFunctions#RECORDS,
+            MAP_IN=org.apache.oozie.action.hadoop.HadoopELFunctions#MAP_IN,
+            MAP_OUT=org.apache.oozie.action.hadoop.HadoopELFunctions#MAP_OUT,
+            REDUCE_IN=org.apache.oozie.action.hadoop.HadoopELFunctions#REDUCE_IN,
+            REDUCE_OUT=org.apache.oozie.action.hadoop.HadoopELFunctions#REDUCE_OUT,
+            GROUPS=org.apache.oozie.action.hadoop.HadoopELFunctions#GROUPS
+        </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.constants.workflow</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.functions.workflow</name>
+        <value>
+            firstNotNull=org.apache.oozie.util.ELConstantsFunctions#firstNotNull,
+            concat=org.apache.oozie.util.ELConstantsFunctions#concat,
+            trim=org.apache.oozie.util.ELConstantsFunctions#trim,
+            timestamp=org.apache.oozie.util.ELConstantsFunctions#timestamp,
+            urlEncode=org.apache.oozie.util.ELConstantsFunctions#urlEncode,
+            toJsonStr=org.apache.oozie.util.ELConstantsFunctions#toJsonStr,
+            toPropertiesStr=org.apache.oozie.util.ELConstantsFunctions#toPropertiesStr,
+            toConfigurationStr=org.apache.oozie.util.ELConstantsFunctions#toConfigurationStr,
+            wf:id=org.apache.oozie.DagELFunctions#wf_id,
+            wf:name=org.apache.oozie.DagELFunctions#wf_name,
+            wf:appPath=org.apache.oozie.DagELFunctions#wf_appPath,
+            wf:conf=org.apache.oozie.DagELFunctions#wf_conf,
+            wf:user=org.apache.oozie.DagELFunctions#wf_user,
+            wf:group=org.apache.oozie.DagELFunctions#wf_group,
+            wf:callback=org.apache.oozie.DagELFunctions#wf_callback,
+            wf:transition=org.apache.oozie.DagELFunctions#wf_transition,
+            wf:lastErrorNode=org.apache.oozie.DagELFunctions#wf_lastErrorNode,
+            wf:errorCode=org.apache.oozie.DagELFunctions#wf_errorCode,
+            wf:errorMessage=org.apache.oozie.DagELFunctions#wf_errorMessage,
+            wf:run=org.apache.oozie.DagELFunctions#wf_run,
+            wf:actionData=org.apache.oozie.DagELFunctions#wf_actionData,
+            wf:actionExternalId=org.apache.oozie.DagELFunctions#wf_actionExternalId,
+            wf:actionTrackerUri=org.apache.oozie.DagELFunctions#wf_actionTrackerUri,
+            wf:actionExternalStatus=org.apache.oozie.DagELFunctions#wf_actionExternalStatus,
+            hadoop:counters=org.apache.oozie.action.hadoop.HadoopELFunctions#hadoop_counters,
+            fs:exists=org.apache.oozie.action.hadoop.FsELFunctions#fs_exists,
+            fs:isDir=org.apache.oozie.action.hadoop.FsELFunctions#fs_isDir,
+            fs:dirSize=org.apache.oozie.action.hadoop.FsELFunctions#fs_dirSize,
+            fs:fileSize=org.apache.oozie.action.hadoop.FsELFunctions#fs_fileSize,
+            fs:blockSize=org.apache.oozie.action.hadoop.FsELFunctions#fs_blockSize
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.WorkflowAppService.WorkflowDefinitionMaxLength</name>
+        <value>100000</value>
+        <description>
+            The maximum length of the workflow definition in bytes
+            An error will be reported if the length exceeds the given maximum
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.functions.workflow</name>
+        <value>
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <!-- Resolve SLA information during Workflow job submission -->
+	<property>
+        <name>oozie.service.ELService.constants.wf-sla-submit</name>
+        <value>
+            MINUTES=org.apache.oozie.util.ELConstantsFunctions#SUBMIT_MINUTES,
+            HOURS=org.apache.oozie.util.ELConstantsFunctions#SUBMIT_HOURS,
+            DAYS=org.apache.oozie.util.ELConstantsFunctions#SUBMIT_DAYS
+            </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.constants.wf-sla-submit</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.functions.wf-sla-submit</name>
+        <value> </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+        </description>
+    </property>
+    <property>
+        <name>oozie.service.ELService.ext.functions.wf-sla-submit</name>
+        <value>
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+<!-- Coordinator specifics -->l
+<!-- Phase 1 resolution during job submission -->
+<!-- EL Evalautor setup to resolve mainly frequency tags -->
+    <property>
+        <name>oozie.service.ELService.constants.coord-job-submit-freq</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.constants.coord-job-submit-freq</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.functions.coord-job-submit-freq</name>
+        <value>
+            coord:days=org.apache.oozie.coord.CoordELFunctions#ph1_coord_days,
+            coord:months=org.apache.oozie.coord.CoordELFunctions#ph1_coord_months,
+            coord:hours=org.apache.oozie.coord.CoordELFunctions#ph1_coord_hours,
+            coord:minutes=org.apache.oozie.coord.CoordELFunctions#ph1_coord_minutes,
+            coord:endOfDays=org.apache.oozie.coord.CoordELFunctions#ph1_coord_endOfDays,
+            coord:endOfMonths=org.apache.oozie.coord.CoordELFunctions#ph1_coord_endOfMonths,
+            coord:conf=org.apache.oozie.coord.CoordELFunctions#coord_conf,
+            coord:user=org.apache.oozie.coord.CoordELFunctions#coord_user
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.functions.coord-job-submit-freq</name>
+        <value>
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+<!-- EL Evalautor setup to resolve mainly all constants/variables - no EL functions is resolved -->
+    <property>
+        <name>oozie.service.ELService.constants.coord-job-submit-nofuncs</name>
+        <value>
+            MINUTE=org.apache.oozie.coord.CoordELConstants#SUBMIT_MINUTE,
+            HOUR=org.apache.oozie.coord.CoordELConstants#SUBMIT_HOUR,
+            DAY=org.apache.oozie.coord.CoordELConstants#SUBMIT_DAY,
+            MONTH=org.apache.oozie.coord.CoordELConstants#SUBMIT_MONTH,
+            YEAR=org.apache.oozie.coord.CoordELConstants#SUBMIT_YEAR
+        </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.constants.coord-job-submit-nofuncs</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.functions.coord-job-submit-nofuncs</name>
+        <value>
+            coord:conf=org.apache.oozie.coord.CoordELFunctions#coord_conf,
+            coord:user=org.apache.oozie.coord.CoordELFunctions#coord_user
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.functions.coord-job-submit-nofuncs</name>
+        <value> </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+<!-- EL Evalautor setup to **check** whether instances/start-instance/end-instances are valid
+ no EL functions will be resolved -->
+    <property>
+        <name>oozie.service.ELService.constants.coord-job-submit-instances</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.constants.coord-job-submit-instances</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.functions.coord-job-submit-instances</name>
+        <value>
+            coord:hoursInDay=org.apache.oozie.coord.CoordELFunctions#ph1_coord_hoursInDay_echo,
+            coord:daysInMonth=org.apache.oozie.coord.CoordELFunctions#ph1_coord_daysInMonth_echo,
+            coord:tzOffset=org.apache.oozie.coord.CoordELFunctions#ph1_coord_tzOffset_echo,
+            coord:current=org.apache.oozie.coord.CoordELFunctions#ph1_coord_current_echo,
+            coord:latest=org.apache.oozie.coord.CoordELFunctions#ph1_coord_latest_echo,
+            coord:future=org.apache.oozie.coord.CoordELFunctions#ph1_coord_future_echo,
+            coord:formatTime=org.apache.oozie.coord.CoordELFunctions#ph1_coord_formatTime_echo,
+            coord:conf=org.apache.oozie.coord.CoordELFunctions#coord_conf,
+            coord:user=org.apache.oozie.coord.CoordELFunctions#coord_user
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.functions.coord-job-submit-instances</name>
+        <value>
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+<!-- EL Evalautor setup to **check** whether dataIn and dataOut are valid
+ no EL functions will be resolved -->
+
+    <property>
+        <name>oozie.service.ELService.constants.coord-job-submit-data</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.constants.coord-job-submit-data</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.functions.coord-job-submit-data</name>
+        <value>
+            coord:dataIn=org.apache.oozie.coord.CoordELFunctions#ph1_coord_dataIn_echo,
+            coord:dataOut=org.apache.oozie.coord.CoordELFunctions#ph1_coord_dataOut_echo,
+            coord:nominalTime=org.apache.oozie.coord.CoordELFunctions#ph1_coord_nominalTime_echo_wrap,
+            coord:actualTime=org.apache.oozie.coord.CoordELFunctions#ph1_coord_actualTime_echo_wrap,
+            coord:dateOffset=org.apache.oozie.coord.CoordELFunctions#ph1_coord_dateOffset_echo,
+            coord:formatTime=org.apache.oozie.coord.CoordELFunctions#ph1_coord_formatTime_echo,
+            coord:actionId=org.apache.oozie.coord.CoordELFunctions#ph1_coord_actionId_echo,
+            coord:name=org.apache.oozie.coord.CoordELFunctions#ph1_coord_name_echo,
+            coord:conf=org.apache.oozie.coord.CoordELFunctions#coord_conf,
+            coord:user=org.apache.oozie.coord.CoordELFunctions#coord_user
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.functions.coord-job-submit-data</name>
+        <value>
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <!-- Resolve SLA information during Coordinator job submission -->
+	<property>
+        <name>oozie.service.ELService.constants.coord-sla-submit</name>
+        <value>
+            MINUTES=org.apache.oozie.coord.CoordELConstants#SUBMIT_MINUTES,
+            HOURS=org.apache.oozie.coord.CoordELConstants#SUBMIT_HOURS,
+            DAYS=org.apache.oozie.coord.CoordELConstants#SUBMIT_DAYS
+            </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.constants.coord-sla-submit</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.functions.coord-sla-submit</name>
+        <value>
+            coord:nominalTime=org.apache.oozie.coord.CoordELFunctions#ph1_coord_nominalTime_echo_fixed,
+            coord:conf=org.apache.oozie.coord.CoordELFunctions#coord_conf,
+            coord:user=org.apache.oozie.coord.CoordELFunctions#coord_user
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+        </description>
+    </property>
+    <property>
+        <name>oozie.service.ELService.ext.functions.coord-sla-submit</name>
+        <value>
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+ <!--  Action creation for coordinator -->
+<property>
+        <name>oozie.service.ELService.constants.coord-action-create</name>
+        <value>
+        </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.constants.coord-action-create</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.functions.coord-action-create</name>
+        <value>
+            coord:hoursInDay=org.apache.oozie.coord.CoordELFunctions#ph2_coord_hoursInDay,
+            coord:daysInMonth=org.apache.oozie.coord.CoordELFunctions#ph2_coord_daysInMonth,
+            coord:tzOffset=org.apache.oozie.coord.CoordELFunctions#ph2_coord_tzOffset,
+            coord:current=org.apache.oozie.coord.CoordELFunctions#ph2_coord_current,
+            coord:latest=org.apache.oozie.coord.CoordELFunctions#ph2_coord_latest_echo,
+            coord:future=org.apache.oozie.coord.CoordELFunctions#ph2_coord_future_echo,
+            coord:actionId=org.apache.oozie.coord.CoordELFunctions#ph2_coord_actionId,
+            coord:name=org.apache.oozie.coord.CoordELFunctions#ph2_coord_name,
+            coord:formatTime=org.apache.oozie.coord.CoordELFunctions#ph2_coord_formatTime,
+            coord:conf=org.apache.oozie.coord.CoordELFunctions#coord_conf,
+            coord:user=org.apache.oozie.coord.CoordELFunctions#coord_user
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.functions.coord-action-create</name>
+        <value>
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+
+ <!--  Action creation for coordinator used to only evaluate instance number like ${current (daysInMonth())}. current will be echo-ed -->
+<property>
+        <name>oozie.service.ELService.constants.coord-action-create-inst</name>
+        <value>
+        </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.constants.coord-action-create-inst</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.functions.coord-action-create-inst</name>
+        <value>
+            coord:hoursInDay=org.apache.oozie.coord.CoordELFunctions#ph2_coord_hoursInDay,
+            coord:daysInMonth=org.apache.oozie.coord.CoordELFunctions#ph2_coord_daysInMonth,
+            coord:tzOffset=org.apache.oozie.coord.CoordELFunctions#ph2_coord_tzOffset,
+            coord:current=org.apache.oozie.coord.CoordELFunctions#ph2_coord_current_echo,
+            coord:latest=org.apache.oozie.coord.CoordELFunctions#ph2_coord_latest_echo,
+            coord:future=org.apache.oozie.coord.CoordELFunctions#ph2_coord_future_echo,
+            coord:formatTime=org.apache.oozie.coord.CoordELFunctions#ph2_coord_formatTime,
+            coord:conf=org.apache.oozie.coord.CoordELFunctions#coord_conf,
+            coord:user=org.apache.oozie.coord.CoordELFunctions#coord_user
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.functions.coord-action-create-inst</name>
+        <value>
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+        <!-- Resolve SLA information during Action creation/materialization -->
+	<property>
+        <name>oozie.service.ELService.constants.coord-sla-create</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.constants.coord-sla-create</name>
+        <value>
+            MINUTES=org.apache.oozie.coord.CoordELConstants#SUBMIT_MINUTES,
+            HOURS=org.apache.oozie.coord.CoordELConstants#SUBMIT_HOURS,
+            DAYS=org.apache.oozie.coord.CoordELConstants#SUBMIT_DAYS</value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.functions.coord-sla-create</name>
+        <value>
+            coord:nominalTime=org.apache.oozie.coord.CoordELFunctions#ph2_coord_nominalTime,
+            coord:conf=org.apache.oozie.coord.CoordELFunctions#coord_conf,
+            coord:user=org.apache.oozie.coord.CoordELFunctions#coord_user
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+        </description>
+    </property>
+    <property>
+        <name>oozie.service.ELService.ext.functions.coord-sla-create</name>
+        <value>
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+<!--  Action start for coordinator -->
+<property>
+        <name>oozie.service.ELService.constants.coord-action-start</name>
+        <value>
+        </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.constants.coord-action-start</name>
+        <value> </value>
+        <description>
+            EL constant declarations, separated by commas, format is [PREFIX:]NAME=CLASS#CONSTANT.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.functions.coord-action-start</name>
+        <value>
+            coord:hoursInDay=org.apache.oozie.coord.CoordELFunctions#ph3_coord_hoursInDay,
+            coord:daysInMonth=org.apache.oozie.coord.CoordELFunctions#ph3_coord_daysInMonth,
+            coord:tzOffset=org.apache.oozie.coord.CoordELFunctions#ph3_coord_tzOffset,
+            coord:latest=org.apache.oozie.coord.CoordELFunctions#ph3_coord_latest,
+            coord:future=org.apache.oozie.coord.CoordELFunctions#ph3_coord_future,
+            coord:dataIn=org.apache.oozie.coord.CoordELFunctions#ph3_coord_dataIn,
+            coord:dataOut=org.apache.oozie.coord.CoordELFunctions#ph3_coord_dataOut,
+            coord:nominalTime=org.apache.oozie.coord.CoordELFunctions#ph3_coord_nominalTime,
+            coord:actualTime=org.apache.oozie.coord.CoordELFunctions#ph3_coord_actualTime,
+            coord:dateOffset=org.apache.oozie.coord.CoordELFunctions#ph3_coord_dateOffset,
+            coord:formatTime=org.apache.oozie.coord.CoordELFunctions#ph3_coord_formatTime,
+            coord:actionId=org.apache.oozie.coord.CoordELFunctions#ph3_coord_actionId,
+            coord:name=org.apache.oozie.coord.CoordELFunctions#ph3_coord_name,
+            coord:conf=org.apache.oozie.coord.CoordELFunctions#coord_conf,
+            coord:user=org.apache.oozie.coord.CoordELFunctions#coord_user
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ELService.ext.functions.coord-action-start</name>
+        <value>
+        </value>
+        <description>
+            EL functions declarations, separated by commas, format is [PREFIX:]NAME=CLASS#METHOD.
+            This property is a convenience property to add extensions to the built in executors without having to
+            include all the built in ones.
+        </description>
+    </property>
+
+
+    <!-- UUIDService -->
+
+    <property>
+        <name>oozie.service.UUIDService.generator</name>
+        <value>counter</value>
+        <description>
+            random : generated UUIDs will be random strings.
+            counter: generated UUIDs generated will be a counter postfixed with the system startup time.
+        </description>
+    </property>
+
+    <!-- DBLiteWorkflowStoreService -->
+
+    <property>
+        <name>oozie.service.DBLiteWorkflowStoreService.status.metrics.collection.interval</name>
+        <value>5</value>
+        <description> Workflow Status metrics collection interval in minutes.</description>
+    </property>
+
+    <property>
+        <name>oozie.service.DBLiteWorkflowStoreService.status.metrics.window</name>
+        <value>3600</value>
+        <description>
+            Workflow Status metrics collection window in seconds. Workflow status will be instrumented for the window.
+        </description>
+    </property>
+
+    <!-- DB Schema Info, used by DBLiteWorkflowStoreService -->
+
+    <property>
+        <name>oozie.db.schema.name</name>
+        <value>oozie</value>
+        <description>
+            Oozie DataBase Name
+        </description>
+    </property>
+
+   <!-- StoreService -->
+
+    <property>
+        <name>oozie.service.JPAService.create.db.schema</name>
+        <value>true</value>
+        <description>
+            Creates Oozie DB.
+
+            If set to true, it creates the DB schema if it does not exist. If the DB schema exists is a NOP.
+            If set to false, it does not create the DB schema. If the DB schema does not exist it fails start up.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.JPAService.validate.db.connection</name>
+        <value>false</value>
+        <description>
+            Validates DB connections from the DB connection pool.
+            If the 'oozie.service.JPAService.create.db.schema' property is set to true, this property is ignored.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.JPAService.validate.db.connection.eviction.interval</name>
+        <value>300000</value>
+        <description>
+            Validates DB connections from the DB connection pool.
+            When validate db connection 'TestWhileIdle' is true, the number of milliseconds to sleep
+            between runs of the idle object evictor thread.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.JPAService.validate.db.connection.eviction.num</name>
+        <value>10</value>
+        <description>
+            Validates DB connections from the DB connection pool.
+            When validate db connection 'TestWhileIdle' is true, the number of objects to examine during
+            each run of the idle object evictor thread.
+        </description>
+    </property>
+
+
+    <property>
+        <name>oozie.service.JPAService.connection.data.source</name>
+        <value>org.apache.commons.dbcp.BasicDataSource</value>
+        <description>
+            DataSource to be used for connection pooling.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.JPAService.jdbc.driver</name>
+        <value>org.apache.derby.jdbc.EmbeddedDriver</value>
+        <description>
+            JDBC driver class.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.JPAService.jdbc.url</name>
+        <value>jdbc:derby:${oozie.data.dir}/${oozie.db.schema.name}-db;create=true</value>
+        <description>
+            JDBC URL.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.JPAService.jdbc.username</name>
+        <value>sa</value>
+        <description>
+            DB user name.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.JPAService.jdbc.password</name>
+        <value> </value>
+        <description>
+            DB user password.
+
+            IMPORTANT: if password is emtpy leave a 1 space string, the service trims the value,
+                       if empty Configuration assumes it is NULL.
+
+            IMPORTANT: if the StoreServicePasswordService is active, it will reset this value with the value given in
+                       the console.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.JPAService.pool.max.active.conn</name>
+        <value>10</value>
+        <description>
+             Max number of connections.
+        </description>
+    </property>
+
+   <!-- SchemaService -->
+
+    <property>
+        <name>oozie.service.SchemaService.wf.ext.schemas</name>
+        <value>oozie-sla-0.1.xsd</value>
+        <description>
+            Schemas for additional actions types.
+
+            IMPORTANT: if there are no schemas leave a 1 space string, the service trims the value,
+                       if empty Configuration assumes it is NULL.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.SchemaService.coord.ext.schemas</name>
+        <value>oozie-sla-0.1.xsd</value>
+        <description>
+            Schemas for additional actions types.
+
+            IMPORTANT: if there are no schemas leave a 1 space string, the service trims the value,
+                       if empty Configuration assumes it is NULL.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.SchemaService.sla.ext.schemas</name>
+        <value> </value>
+        <description>
+            Schemas for semantic validation for GMS SLA.
+
+            IMPORTANT: if there are no schemas leave a 1 space string, the service trims the value,
+                       if empty Configuration assumes it is NULL.
+        </description>
+    </property>
+    <!-- CallbackService -->
+
+    <property>
+        <name>oozie.service.CallbackService.base.url</name>
+        <value>${oozie.base.url}/callback</value>
+        <description>
+             Base callback URL used by ActionExecutors.
+        </description>
+    </property>
+
+    <!-- CallbackServlet -->
+
+    <property>
+        <name>oozie.servlet.CallbackServlet.max.data.len</name>
+        <value>2048</value>
+        <description>
+            Max size in characters for the action completion data output.
+        </description>
+    </property>
+
+    <!-- External stats-->
+
+    <property>
+        <name>oozie.external.stats.max.size</name>
+        <value>-1</value>
+        <description>
+            Max size in bytes for action stats. -1 means infinite value.
+        </description>
+    </property>
+
+    <!-- JobCommand -->
+
+    <property>
+        <name>oozie.JobCommand.job.console.url</name>
+        <value>${oozie.base.url}?job=</value>
+        <description>
+             Base console URL for a workflow job.
+        </description>
+    </property>
+
+
+    <!-- ActionService -->
+
+    <property>
+        <name>oozie.service.ActionService.executor.classes</name>
+        <value>
+            org.apache.oozie.action.decision.DecisionActionExecutor,
+            org.apache.oozie.action.hadoop.JavaActionExecutor,
+            org.apache.oozie.action.hadoop.FsActionExecutor,
+            org.apache.oozie.action.hadoop.MapReduceActionExecutor,
+            org.apache.oozie.action.hadoop.PigActionExecutor,
+            org.apache.oozie.action.ssh.SshActionExecutor,
+            org.apache.oozie.action.oozie.SubWorkflowActionExecutor
+        </value>
+        <description>
+            List of ActionExecutors classes (separated by commas).
+            Only action types with associated executors can be used in workflows.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ActionService.executor.ext.classes</name>
+        <value> </value>
+        <description>
+            List of ActionExecutors extension classes (separated by commas). Only action types with associated
+            executors can be used in workflows. This property is a convenience property to add extensions to the built
+            in executors without having to include all the built in ones.
+        </description>
+    </property>
+
+    <!-- ActionCheckerService -->
+
+    <property>
+        <name>oozie.service.ActionCheckerService.action.check.interval</name>
+        <value>60</value>
+        <description>
+            The frequency at which the ActionCheckService will run.
+        </description>
+    </property>
+
+     <property>
+        <name>oozie.service.ActionCheckerService.action.check.delay</name>
+        <value>600</value>
+        <description>
+            The time, in seconds, between an ActionCheck for the same action.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.ActionCheckerService.callable.batch.size</name>
+        <value>10</value>
+        <description>
+            This value determines the number of actions which will be batched together
+            to be executed by a single thread.
+        </description>
+    </property>
+
+    <!-- StatusTransitService -->
+    <property>
+        <name>oozie.service.StatusTransitService.statusTransit.interval</name>
+        <value>60</value>
+        <description>
+            The frequency in seconds at which the StatusTransitService will run.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.StatusTransitService.backward.support.for.coord.status</name>
+        <value>false</value>
+        <description>
+            true, if coordinator job submits using 'uri:oozie:coordinator:0.1' namespace and wants to keep Oozie 2.x status transit.
+            if set true,
+            1. SUCCEEDED state in coordinator job means materialization done.
+            2. No DONEWITHERROR state in coordinator job
+            3. No PAUSED or PREPPAUSED state in coordinator job
+            4. PREPSUSPENDED becomes SUSPENDED in coordinator job
+        </description>
+    </property>
+
+    <!-- PauseTransitService -->
+    <property>
+        <name>oozie.service.PauseTransitService.PauseTransit.interval</name>
+        <value>60</value>
+        <description>
+            The frequency in seconds at which the PauseTransitService will run.
+        </description>
+    </property>
+
+    <!-- HadoopActionExecutor -->
+    <!-- This is common to the subclasses action executors for map-reduce and pig -->
+
+    <property>
+        <name>oozie.action.retries.max</name>
+        <value>3</value>
+        <description>
+           The number of retries for executing an action in case of failure
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.action.hadoop.delete.hdfs.tmp.dir</name>
+        <value>false</value>
+        <description>
+            If set to true, it will delete temporary directory at the end of execution of map reduce action.
+        </description>
+    </property>
+
+    <!-- PigActionExecutor -->
+
+    <property>
+        <name>oozie.action.pig.delete.hdfs.tmp.dir</name>
+        <value>false</value>
+        <description>
+            If set to true, it will delete temporary directory at the end of execution of pig action.
+        </description>
+    </property>
+
+    <!-- SshActionExecutor -->
+
+    <property>
+        <name>oozie.action.ssh.delete.remote.tmp.dir</name>
+        <value>false</value>
+        <description>
+            If set to true, it will delete temporary directory at the end of execution of ssh action.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.action.ssh.http.command</name>
+        <value>curl</value>
+        <description>
+            Command to use for callback to oozie, normally is 'curl' or 'wget'.
+            The command must available in PATH environment variable of the USER@HOST box shell.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.action.ssh.http.command.post.options</name>
+        <value>--data-binary @#stdout --request POST --header "content-type:text/plain"</value>
+        <description>
+            The callback command POST options.
+            Used when the ouptut of the ssh action is captured.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.action.ssh.allow.user.at.host</name>
+        <value>true</value>
+        <description>
+            Specifies whether the user specified by the ssh action is allowed or is to be replaced
+            by the Job user
+        </description>
+    </property>
+
+    <!-- HadoopAccessorService -->
+
+    <property>
+        <name>oozie.service.HadoopAccessorService.kerberos.enabled</name>
+        <value>false</value>
+        <description>
+            Indicates if Oozie is configured to use Kerberos.
+        </description>
+    </property>
+
+    <property>
+        <name>local.realm</name>
+        <value>LOCALHOST</value>
+        <description>
+            Kerberos Realm used by Oozie and Hadoop. Using 'local.realm' to be aligned with Hadoop configuration
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.HadoopAccessorService.keytab.file</name>
+        <value>${user.home}/oozie.keytab</value>
+        <description>
+            Location of the Oozie user keytab file.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.HadoopAccessorService.kerberos.principal</name>
+        <value>${user.name}/localhost@${local.realm}</value>
+        <description>
+            Kerberos principal for Oozie service.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.HadoopAccessorService.jobTracker.whitelist</name>
+        <value> </value>
+        <description>
+            Whitelisted job tracker for Oozie service.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.HadoopAccessorService.nameNode.whitelist</name>
+        <value> </value>
+        <description>
+            Whitelisted job tracker for Oozie service.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.HadoopAccessorService.hadoop.configurations</name>
+        <value>*=hadoop-conf</value>
+        <description>
+            Comma separated AUTHORITY=HADOOP_CONF_DIR, where AUTHORITY is the HOST:PORT of
+            the Hadoop service (JobTracker, YARN, HDFS). The wildcard '*' configuration is
+            used when there is no exact match for an authority. The HADOOP_CONF_DIR contains
+            the relevant Hadoop *-site.xml files. If the path is relative is looked within
+            the Oozie configuration directory; though the path can be absolute (i.e. to point
+            to Hadoop client conf/ directories in the local filesystem.
+        </description>
+    </property>
+
+
+    <property>
+        <name>oozie.service.HadoopAccessorService.action.configurations</name>
+        <value>*=action-conf</value>
+        <description>
+            Comma separated AUTHORITY=ACTION_CONF_DIR, where AUTHORITY is the HOST:PORT of
+            the Hadoop MapReduce service (JobTracker, YARN). The wildcard '*' configuration is
+            used when there is no exact match for an authority. The ACTION_CONF_DIR may contain
+            ACTION.xml files where ACTION is the action type ('java', 'map-reduce', 'pig',
+            'hive', 'sqoop', etc.). If the ACTION.xml file exists, its properties will be used
+            as defaults properties for the action. If the path is relative is looked within
+            the Oozie configuration directory; though the path can be absolute (i.e. to point
+            to Hadoop client conf/ directories in the local filesystem.
+        </description>
+    </property>
+
+    <!-- Credentials -->
+    <property>
+        <name>oozie.credentials.credentialclasses</name>
+        <value> </value>
+        <description>
+            A list of credential class mapping for CredentialsProvider
+        </description>
+    </property>
+
+	<property>
+        <name>oozie.actions.main.classnames</name>
+        <value>distcp=org.apache.hadoop.tools.DistCp</value>
+        <description>
+            A list of class name mapping for Action classes
+        </description>
+    </property>
+	
+	
+    <property>
+        <name>oozie.service.WorkflowAppService.system.libpath</name>
+        <value>/user/${user.name}/share/lib</value>
+        <description>
+            System library path to use for workflow applications.
+            This path is added to workflow application if their job properties sets
+            the property 'oozie.use.system.libpath' to true.
+        </description>
+    </property>
+
+    <property>
+        <name>use.system.libpath.for.mapreduce.and.pig.jobs</name>
+        <value>false</value>
+        <description>
+            If set to true, submissions of MapReduce and Pig jobs will include
+            automatically the system library path, thus not requiring users to
+            specify where the Pig JAR files are. Instead, the ones from the system
+            library path are used.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.command.default.lock.timeout</name>
+        <value>5000</value>
+        <description>
+            Default timeout (in milliseconds) for commands for acquiring an exclusive lock on an entity.
+        </description>
+    </property>
+
+   <!-- LiteWorkflowStoreService, Workflow Action Automatic Retry -->
+
+    <property>
+        <name>oozie.service.LiteWorkflowStoreService.user.retry.max</name>
+        <value>3</value>
+        <description>
+            Automatic retry max count for workflow action is 3 in default.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.LiteWorkflowStoreService.user.retry.inteval</name>
+        <value>10</value>
+        <description>
+            Automatic retry interval for workflow action is in minutes and the default value is 10 minutes.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.LiteWorkflowStoreService.user.retry.error.code</name>
+        <value>JA008,JA009,JA017,JA018,JA019,FS009,FS008</value>
+        <description>
+            Automatic retry interval for workflow action is handled for these specified error code:
+            FS009, FS008 is file exists error when using chmod in fs action.
+            JA018 is output directory exists error in workflow map-reduce action.
+            JA019 is error while executing distcp action.
+            JA017 is job not exists error in action executor.
+            JA008 is FileNotFoundException in action executor.
+            JA009 is IOException in action executor.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.LiteWorkflowStoreService.user.retry.error.code.ext</name>
+        <value> </value>
+        <description>
+            Automatic retry interval for workflow action is handled for these specified extra error code.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.service.LiteWorkflowStoreService.node.def.version</name>
+        <value>_oozie_inst_v_1</value>
+        <description>
+            NodeDef default version, _oozie_inst_v_0 or _oozie_inst_v_1
+        </description>
+    </property>
+
+    <!-- Oozie Authentication -->
+
+    <property>
+        <name>oozie.authentication.type</name>
+        <value>simple</value>
+        <description>
+            Defines authentication used for Oozie HTTP endpoint.
+            Supported values are: simple | kerberos | #AUTHENTICATION_HANDLER_CLASSNAME#
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.authentication.token.validity</name>
+        <value>36000</value>
+        <description>
+            Indicates how long (in seconds) an authentication token is valid before it has
+            to be renewed.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.authentication.signature.secret</name>
+        <value>oozie</value>
+        <description>
+            The signature secret for signing the authentication tokens.
+            If not set a random secret is generated at startup time.
+            In order to authentiation to work correctly across multiple hosts
+            the secret must be the same across al the hosts.
+        </description>
+    </property>
+
+    <property>
+      <name>oozie.authentication.cookie.domain</name>
+      <value></value>
+      <description>
+        The domain to use for the HTTP cookie that stores the authentication token.
+        In order to authentiation to work correctly across multiple hosts
+        the domain must be correctly set.
+      </description>
+    </property>
+
+    <property>
+        <name>oozie.authentication.simple.anonymous.allowed</name>
+        <value>true</value>
+        <description>
+            Indicates if anonymous requests are allowed when using 'simple' authentication.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.authentication.kerberos.principal</name>
+        <value>HTTP/localhost@${local.realm}</value>
+        <description>
+            Indicates the Kerberos principal to be used for HTTP endpoint.
+            The principal MUST start with 'HTTP/' as per Kerberos HTTP SPNEGO specification.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.authentication.kerberos.keytab</name>
+        <value>${oozie.service.HadoopAccessorService.keytab.file}</value>
+        <description>
+            Location of the keytab file with the credentials for the principal.
+            Referring to the same keytab file Oozie uses for its Kerberos credentials for Hadoop.
+        </description>
+    </property>
+
+    <property>
+        <name>oozie.authentication.kerberos.name.rules</name>
+        <value>DEFAULT</value>
+        <description>
+            The kerberos names rules is to resolve kerberos principal names, refer to Hadoop's
+            KerberosName for more details.
+        </description>
+    </property>
+
+	<!-- Coordinator Actions default length -->
+	<property>
+		<name>oozie.coord.actions.default.length</name>
+		<value>1000</value>
+		<description>
+			Default number of coordinator actions to be retrieved by the info command
+		</description>
+	</property>
+
+	<!-- ForkJoin validation -->
+	<property>
+		<name>oozie.validate.ForkJoin</name>
+		<value>true</value>
+		<description>
+			If true, fork and join should be validated at wf submission time.
+		</description>
+	</property>
+
+	<property>
+		<name>oozie.coord.action.get.all.attributes</name>
+		<value>false</value>
+		<description>
+			Setting to true is not recommended as coord job/action info will bring all columns of the action in memory.
+			Set it true only if backward compatibility for action/job info is required.
+		</description>
+	</property>
+</configuration>

Added: incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/OOZIE/metainfo.xml
URL: http://svn.apache.org/viewvc/incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/OOZIE/metainfo.xml?rev=1406489&view=auto
==============================================================================
--- incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/OOZIE/metainfo.xml (added)
+++ incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/OOZIE/metainfo.xml Wed Nov  7 08:13:12 2012
@@ -0,0 +1,35 @@
+<?xml version="1.0"?>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one or more
+   contributor license agreements.  See the NOTICE file distributed with
+   this work for additional information regarding copyright ownership.
+   The ASF licenses this file to You under the Apache License, Version 2.0
+   (the "License"); you may not use this file except in compliance with
+   the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing, software
+   distributed under the License is distributed on an "AS IS" BASIS,
+   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+   See the License for the specific language governing permissions and
+   limitations under the License.
+-->
+<metainfo>
+    <user>root</user>
+    <comment>This is comment for OOZIE service</comment>
+    <version>1.0</version>
+
+    <components>
+        <component>
+            <name>OOZIE_SERVER</name>
+            <category>MASTER</category>
+        </component>
+
+        <component>
+            <name>OOZIE_CLIENT</name>
+            <category>CLIENT</category>
+        </component>
+    </components>
+
+</metainfo>

Added: incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/PIG/configuration/pig.properties
URL: http://svn.apache.org/viewvc/incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/PIG/configuration/pig.properties?rev=1406489&view=auto
==============================================================================
--- incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/PIG/configuration/pig.properties (added)
+++ incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/PIG/configuration/pig.properties Wed Nov  7 08:13:12 2012
@@ -0,0 +1,52 @@
+# 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.
+
+# Pig default configuration file. All values can be overwritten by pig.properties and command line arguments.
+# see bin/pig -help
+
+# brief logging (no timestamps)
+brief=false
+
+#debug level, INFO is default
+debug=INFO
+
+#verbose print all log messages to screen (default to print only INFO and above to screen)
+verbose=false
+
+#exectype local|mapreduce, mapreduce is default
+exectype=mapreduce
+
+#Enable insertion of information about script into hadoop job conf 
+pig.script.info.enabled=true
+
+#Do not spill temp files smaller than this size (bytes)
+pig.spill.size.threshold=5000000
+#EXPERIMENT: Activate garbage collection when spilling a file bigger than this size (bytes)
+#This should help reduce the number of files being spilled.
+pig.spill.gc.activation.size=40000000
+
+#the following two parameters are to help estimate the reducer number
+pig.exec.reducers.bytes.per.reducer=1000000000
+pig.exec.reducers.max=999
+
+#Temporary location to store the intermediate data.
+pig.temp.dir=/tmp/
+
+#Threshold for merging FRJoin fragment files
+pig.files.concatenation.threshold=100
+pig.optimistic.files.concatenation=false;
+
+pig.disable.counter=false

Added: incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/PIG/metainfo.xml
URL: http://svn.apache.org/viewvc/incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/PIG/metainfo.xml?rev=1406489&view=auto
==============================================================================
--- incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/PIG/metainfo.xml (added)
+++ incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/PIG/metainfo.xml Wed Nov  7 08:13:12 2012
@@ -0,0 +1,30 @@
+<?xml version="1.0"?>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one or more
+   contributor license agreements.  See the NOTICE file distributed with
+   this work for additional information regarding copyright ownership.
+   The ASF licenses this file to You under the Apache License, Version 2.0
+   (the "License"); you may not use this file except in compliance with
+   the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing, software
+   distributed under the License is distributed on an "AS IS" BASIS,
+   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+   See the License for the specific language governing permissions and
+   limitations under the License.
+-->
+<metainfo>
+    <user>root</user>
+    <comment>This is comment for PIG service</comment>
+    <version>1.0</version>
+
+    <components>
+        <component>
+            <name>PIG</name>
+            <category>CLIENT</category>
+        </component>
+    </components>
+
+</metainfo>

Added: incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/SQOOP/metainfo.xml
URL: http://svn.apache.org/viewvc/incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/SQOOP/metainfo.xml?rev=1406489&view=auto
==============================================================================
--- incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/SQOOP/metainfo.xml (added)
+++ incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/SQOOP/metainfo.xml Wed Nov  7 08:13:12 2012
@@ -0,0 +1,30 @@
+<?xml version="1.0"?>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one or more
+   contributor license agreements.  See the NOTICE file distributed with
+   this work for additional information regarding copyright ownership.
+   The ASF licenses this file to You under the Apache License, Version 2.0
+   (the "License"); you may not use this file except in compliance with
+   the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing, software
+   distributed under the License is distributed on an "AS IS" BASIS,
+   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+   See the License for the specific language governing permissions and
+   limitations under the License.
+-->
+<metainfo>
+    <user>root</user>
+    <comment>This is comment for SQOOP service</comment>
+    <version>1.0</version>
+
+    <components>
+        <component>
+            <name>SQOOP</name>
+            <category>CLIENT</category>
+        </component>
+    </components>
+
+</metainfo>

Added: incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/TEMPLETON/configuration/templeton-site.xml
URL: http://svn.apache.org/viewvc/incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/TEMPLETON/configuration/templeton-site.xml?rev=1406489&view=auto
==============================================================================
--- incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/TEMPLETON/configuration/templeton-site.xml (added)
+++ incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/TEMPLETON/configuration/templeton-site.xml Wed Nov  7 08:13:12 2012
@@ -0,0 +1,217 @@
+<?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.
+-->
+
+<!-- The default settings for Templeton. -->
+<!-- Edit templeton-site.xml to change settings for your local -->
+<!-- install. -->
+
+<configuration>
+
+  <property>
+    <name>templeton.port</name>
+    <value>50111</value>
+    <description>The HTTP port for the main server.</description>
+  </property>
+
+  <property>
+    <name>templeton.hadoop.conf.dir</name>
+    <value>${env.HADOOP_CONF_DIR}</value>
+    <description>The path to the Hadoop configuration.</description>
+  </property>
+
+  <property>
+    <name>templeton.jar</name>
+    <value>${env.TEMPLETON_HOME}/templeton-0.1.0-dev.jar</value>
+    <description>The path to the Templeton jar file.</description>
+  </property>
+
+  <property>
+    <name>templeton.libjars</name>
+    <value>${env.TEMPLETON_HOME}/lib/zookeeper-3.3.4.jar</value>
+    <description>Jars to add to the classpath.</description>
+  </property>
+
+  <property>
+    <name>templeton.override.jars</name>
+    <value>hdfs:///user/templeton/ugi.jar</value>
+    <description>
+        Jars to add the the HADOOP_CLASSPATH for all Map Reduce jobs.
+        This is a list of jars that must exist on hdfs that are added
+        to the Distributed Cache.
+    </description>
+  </property>
+
+  <property>
+    <name>templeton.override.enabled</name>
+    <value>true</value>
+    <description>
+      Enable the override path in templeton.override.jars
+    </description>
+  </property>
+
+  <property>
+    <name>templeton.streaming.jar</name>
+    <value>hdfs:///user/templeton/hadoop-streaming.jar</value>
+    <description>The hdfs path to the Hadoop streaming jar file.</description>
+  </property>
+
+  <property>
+    <name>templeton.hadoop</name>
+    <value>${env.HADOOP_PREFIX}/bin/hadoop</value>
+    <description>The path to the Hadoop executable.</description>
+  </property>
+
+  <property>
+    <name>templeton.python</name>
+    <value>${env.PYTHON_CMD}</value>
+    <description>The path to the python executable.</description>
+  </property>
+
+  <property>
+    <name>templeton.pig.archive</name>
+    <value>hdfs:///user/templeton/pig-0.9.2.tar.gz</value>
+    <description>The path to the Pig archive.</description>
+  </property>
+
+  <property>
+    <name>templeton.pig.path</name>
+    <value>pig-0.9.2.tar.gz/pig-0.9.2/bin/pig</value>
+    <description>The path to the Pig executable.</description>
+  </property>
+
+  <property>
+    <name>templeton.hcat</name>
+    <value>${env.HCAT_PREFIX}/bin/hcat</value>
+    <description>The path to the hcatalog executable.</description>
+  </property>
+
+  <property>
+    <name>templeton.hive.archive</name>
+    <value>hdfs:///user/templeton/hcatalog-0.3.0.tar.gz</value>
+    <description>The path to the Hive archive.</description>
+  </property>
+
+  <property>
+    <name>templeton.hive.path</name>
+    <value>hcatalog-0.3.0.tar.gz/hcatalog-0.3.0/bin/hive</value>
+    <description>The path to the Hive executable.</description>
+  </property>
+
+  <property>
+    <name>templeton.hive.properties</name>
+    <value>hive.metastore.local=false,hive.metastore.uris=thrift://localhost:9933,hive.metastore.sasl.enabled=false</value>
+    <description>Properties to set when running hive.</description>
+  </property>
+
+  <property>
+    <name>templeton.exec.encoding</name>
+    <value>UTF-8</value>
+    <description>The encoding of the stdout and stderr data.</description>
+  </property>
+
+  <property>
+    <name>templeton.exec.timeout</name>
+    <value>10000</value>
+    <description>
+      How long in milliseconds a program is allowed to run on the
+      Templeton box.
+    </description>
+  </property>
+
+  <property>
+    <name>templeton.exec.max-procs</name>
+    <value>16</value>
+    <description>The maximum number of processes allowed to run at once.</description>
+  </property>
+
+  <property>
+    <name>templeton.exec.max-output-bytes</name>
+    <value>1048576</value>
+    <description>
+      The maximum number of bytes from stdout or stderr stored in ram.
+    </description>
+  </property>
+
+  <property>
+    <name>templeton.exec.envs</name>
+    <value>HADOOP_PREFIX,HADOOP_HOME,JAVA_HOME</value>
+    <description>The environment variables passed through to exec.</description>
+  </property>
+
+  <property>
+    <name>templeton.zookeeper.hosts</name>
+    <value>127.0.0.1:2181</value>
+    <description>ZooKeeper servers, as comma separated host:port pairs</description>
+  </property>
+
+  <property>
+    <name>templeton.zookeeper.session-timeout</name>
+    <value>30000</value>
+    <description>ZooKeeper session timeout in milliseconds</description>
+  </property>
+
+  <property>
+    <name>templeton.callback.retry.interval</name>
+    <value>10000</value>
+    <description>How long to wait between callback retry attempts in milliseconds</description>
+  </property>
+
+  <property>
+    <name>templeton.callback.retry.attempts</name>
+    <value>5</value>
+    <description>How many times to retry the callback</description>
+  </property>
+
+  <property>
+    <name>templeton.storage.class</name>
+    <value>org.apache.hcatalog.templeton.tool.HDFSStorage</value>
+    <description>The class to use as storage</description>
+  </property>
+
+  <property>
+    <name>templeton.storage.root</name>
+    <value>/templeton-hadoop</value>
+    <description>The path to the directory to use for storage</description>
+  </property>
+
+  <property>
+    <name>templeton.hdfs.cleanup.interval</name>
+    <value>43200000</value>
+    <description>The maximum delay between a thread's cleanup checks</description>
+  </property>
+
+  <property>
+    <name>templeton.hdfs.cleanup.maxage</name>
+    <value>604800000</value>
+    <description>The maximum age of a templeton job</description>
+  </property>
+
+  <property>
+    <name>templeton.zookeeper.cleanup.interval</name>
+    <value>43200000</value>
+    <description>The maximum delay between a thread's cleanup checks</description>
+  </property>
+
+  <property>
+    <name>templeton.zookeeper.cleanup.maxage</name>
+    <value>604800000</value>
+    <description>The maximum age of a templeton job</description>
+  </property>
+
+</configuration>

Added: incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/TEMPLETON/metainfo.xml
URL: http://svn.apache.org/viewvc/incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/TEMPLETON/metainfo.xml?rev=1406489&view=auto
==============================================================================
--- incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/TEMPLETON/metainfo.xml (added)
+++ incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/TEMPLETON/metainfo.xml Wed Nov  7 08:13:12 2012
@@ -0,0 +1,37 @@
+<?xml version="1.0"?>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one or more
+   contributor license agreements.  See the NOTICE file distributed with
+   this work for additional information regarding copyright ownership.
+   The ASF licenses this file to You under the Apache License, Version 2.0
+   (the "License"); you may not use this file except in compliance with
+   the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing, software
+   distributed under the License is distributed on an "AS IS" BASIS,
+   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+   See the License for the specific language governing permissions and
+   limitations under the License.
+-->
+<metainfo>
+    <user>root</user>
+    <comment>This is comment for TEMPLETON service</comment>
+    <version>1.0</version>
+
+
+    <components>
+        <component>
+            <name>TEMPLETON_SERVER</name>
+            <category>MASTER</category>
+        </component>
+
+        <component>
+            <name>TEMPLETON_CLIENT</name>
+            <category>CLIENT</category>
+        </component>
+    </components>
+
+
+</metainfo>

Added: incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/ZOOKEEPER/metainfo.xml
URL: http://svn.apache.org/viewvc/incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/ZOOKEEPER/metainfo.xml?rev=1406489&view=auto
==============================================================================
--- incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/ZOOKEEPER/metainfo.xml (added)
+++ incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/stacks/HDP/0.1/services/ZOOKEEPER/metainfo.xml Wed Nov  7 08:13:12 2012
@@ -0,0 +1,37 @@
+<?xml version="1.0"?>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one or more
+   contributor license agreements.  See the NOTICE file distributed with
+   this work for additional information regarding copyright ownership.
+   The ASF licenses this file to You under the Apache License, Version 2.0
+   (the "License"); you may not use this file except in compliance with
+   the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing, software
+   distributed under the License is distributed on an "AS IS" BASIS,
+   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+   See the License for the specific language governing permissions and
+   limitations under the License.
+-->
+<metainfo>
+    <user>root</user>
+    <comment>This is comment for ZOOKEEPER service</comment>
+    <version>1.0</version>
+
+
+    <components>
+        <component>
+            <name>ZOOKEEPER_SERVER</name>
+            <category>MASTER</category>
+        </component>
+
+        <component>
+            <name>ZOOKEEPER_CLIENT</name>
+            <category>CLIENT</category>
+        </component>
+    </components>
+
+
+</metainfo>

Modified: incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/webapp/WEB-INF/spring-security.xml
URL: http://svn.apache.org/viewvc/incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/webapp/WEB-INF/spring-security.xml?rev=1406489&r1=1406488&r2=1406489&view=diff
==============================================================================
--- incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/webapp/WEB-INF/spring-security.xml (original)
+++ incubator/ambari/branches/AMBARI-666/ambari-server/src/main/resources/webapp/WEB-INF/spring-security.xml Wed Nov  7 08:13:12 2012
@@ -25,8 +25,8 @@
   <http use-expressions="true" auto-config="true"
         disable-url-rewriting="true">
     <http-basic/>
-    <intercept-url pattern="/api/*" access="hasRole('ADMIN')"/>
-    <intercept-url pattern="/**" access="isAuthenticated()"/>
+    <intercept-url pattern="/**" access="isAuthenticated()" method="GET"/>
+    <intercept-url pattern="/**" access="hasRole('ADMIN')"/>
   </http>
 
   <!--<ldap-server id="ldapServer" root="dc=ambari,dc=apache,dc=org"/>-->
@@ -34,29 +34,11 @@
   <authentication-manager>
 
     <authentication-provider user-service-ref="ambariLocalUserService">
-      <password-encoder ref="standardPasswordEncoder"/>
+      <password-encoder ref="passwordEncoder"/>
     </authentication-provider>
 
     <authentication-provider ref="ambariLdapAuthenticationProvider"/>
 
   </authentication-manager>
 
-  <beans:bean id="ambariLocalUserService"
-              class="org.apache.ambari.server.security.authorization.AmbariLocalUserDetailsService"
-              factory-bean="guiceInjector"
-              factory-method="getInstance">
-    <beans:constructor-arg type="java.lang.Class"
-                           value="org.apache.ambari.server.security.authorization.AmbariLocalUserDetailsService"/>
-  </beans:bean>
-
-  <beans:bean id="ambariLdapAuthenticationProvider"
-              class="org.apache.ambari.server.security.authorization.AmbariLdapAuthenticationProvider"
-              factory-bean="guiceInjector"
-              factory-method="getInstance">
-    <beans:constructor-arg type="java.lang.Class"
-                           value="org.apache.ambari.server.security.authorization.AmbariLdapAuthenticationProvider"/>
-  </beans:bean>
-
-  <beans:bean id="standardPasswordEncoder"
-              class="org.springframework.security.crypto.password.StandardPasswordEncoder"/>
 </beans:beans>
\ No newline at end of file