- CACHE_MANAGER_IMPL - Static variable in class org.apache.oozie.service.PartitionDependencyManagerService
-
- CACHE_PURGE_INTERVAL - Static variable in class org.apache.oozie.service.PartitionDependencyManagerService
-
- CACHE_PURGE_TTL - Static variable in class org.apache.oozie.service.PartitionDependencyManagerService
-
- calcMatdTime() - Method in class org.apache.oozie.command.coord.CoordMaterializeTransitionXCommand
-
Calculate startMatdTime and endMatdTime from job's start time if next materialized time is null
- calculateAndCheckDates(Date, Date) - Method in class org.apache.oozie.util.XLogFilter
-
Calculate scan date
- calculateAndValidateDateRange(Date, Date) - Method in class org.apache.oozie.util.XLogAuditStreamer
-
- calculateAndValidateDateRange(Date, Date) - Method in class org.apache.oozie.util.XLogErrorStreamer
-
- calculateAndValidateDateRange(Date, Date) - Method in class org.apache.oozie.util.XLogStreamer
-
- call() - Method in class org.apache.oozie.command.XCommand
-
Implements the XCommand life-cycle.
- call() - Method in class org.apache.oozie.service.CallableQueueService.CallableWrapper
-
- CallableQueueService - Class in org.apache.oozie.service
-
The callable queue service queues
XCallable
s for asynchronous execution.
- CallableQueueService() - Constructor for class org.apache.oozie.service.CallableQueueService
-
- CallableQueueService.CallableWrapper<E> - Class in org.apache.oozie.service
-
- CallableWrapper(XCallable<E>, long) - Constructor for class org.apache.oozie.service.CallableQueueService.CallableWrapper
-
- callActionEnd() - Method in class org.apache.oozie.command.wf.ActionStartXCommand
-
- callActionEnd() - Method in class org.apache.oozie.command.wf.ForkedActionStartXCommand
-
- CallbackService - Class in org.apache.oozie.service
-
Service that generates and parses callback URLs.
- CallbackService() - Constructor for class org.apache.oozie.service.CallbackService
-
- CallbackServlet - Class in org.apache.oozie.servlet
-
- CallbackServlet() - Constructor for class org.apache.oozie.servlet.CallbackServlet
-
- callServer(String) - Static method in class org.apache.oozie.util.AuthUrlClient
-
Calls other Oozie server over HTTP.
- cancel(boolean) - Method in class org.apache.oozie.service.AsyncXCommandExecutor.AccessibleRunnableScheduledFuture
-
- canonicalizeHostname(String) - Method in class org.apache.oozie.dependency.hcat.EhcacheHCatDependencyCache
-
- canonicalizeHostname(String) - Method in class org.apache.oozie.dependency.hcat.SimpleHCatDependencyCache
-
- canonicalizeHostname(String, boolean) - Static method in class org.apache.oozie.dependency.hcat.SimpleHCatDependencyCache
-
- canSubmitCallable(XCallable<?>) - Method in class org.apache.oozie.service.CallableQueueService
-
- change(String, String) - Method in class org.apache.oozie.BaseEngine
-
Change a coordinator job.
- change(String, String) - Method in class org.apache.oozie.BundleEngine
-
- change(String, String) - Method in class org.apache.oozie.CoordinatorEngine
-
- change(String, String) - Method in class org.apache.oozie.DagEngine
-
- changeDefinition(List<Pair<String, Map<String, String>>>) - Method in class org.apache.oozie.sla.service.SLAService
-
Change jobs Sla definitions
It takes list of pairs of jobid and key/value pairs of el evaluated sla definition.
- changeDefinition(List<Pair<String, Map<String, String>>>) - Method in interface org.apache.oozie.sla.SLACalculator
-
Change jobs Sla definitions
It takes list of pairs of jobid and key/value pairs of el evaluated sla definition.
- changeDefinition(List<Pair<String, Map<String, String>>>) - Method in class org.apache.oozie.sla.SLACalculatorMemory
-
- changeJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- changeJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
protected method to change a coordinator job
- changeSLA(String, String, String, String, String) - Method in class org.apache.oozie.BaseEngine
-
Change SLA properties for job
- changeSLA(String, String, String, String, String) - Method in class org.apache.oozie.BundleEngine
-
- changeSLA(String, String, String, String, String) - Method in class org.apache.oozie.CoordinatorEngine
-
- changeSLA(String, String, String, String, String) - Method in class org.apache.oozie.DagEngine
-
- CHAR_ENCODING - Static variable in class org.apache.oozie.coord.input.dependency.CoordInputDependencyFactory
-
- check(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.ActionExecutor
-
Check if an action has completed.
- check(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.control.ControlNodeActionExecutor
-
- check(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.decision.DecisionActionExecutor
-
- check(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.email.EmailActionExecutor
-
- check(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.hadoop.FsActionExecutor
-
- check(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- check(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.hadoop.MapReduceActionExecutor
-
- check(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- check(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.ssh.SshActionExecutor
-
Check ssh action status.
- check(CoordinatorJobBean, CoordinatorJobBean) - Method in class org.apache.oozie.command.coord.CoordUpdateXCommand
-
Check.
- CHECK_INITIAL_RETRY_WAIT_TIME - Static variable in class org.apache.oozie.action.ssh.SshActionExecutor
-
- CHECK_MAX_RETRIES - Static variable in class org.apache.oozie.action.ssh.SshActionExecutor
-
- checkAndSetDisallowedProperties(Configuration, String, E, boolean) - Static method in class org.apache.oozie.util.ConfigUtils
-
Check Configuration
whether it contains disallowed properties.
- checkAndSetFilterField(String, String) - Method in class org.apache.oozie.executor.jpa.sla.SLASummaryGetForFilterJPAExecutor
-
- checkAndWriteApplicationXMLToHDFS(String, Configuration) - Method in class org.apache.oozie.servlet.BaseJobsServlet
-
- checkAndWriteApplicationXMLToHDFS(String, Configuration) - Method in class org.apache.oozie.servlet.V0JobsServlet
-
- checkAndWriteApplicationXMLToHDFS(String, Configuration) - Method in class org.apache.oozie.servlet.V1JobsServlet
-
- checkDateOozieTZ(String, String) - Static method in class org.apache.oozie.util.ParamChecker
-
Check whether the value is Oozie processing timezone data format.
- checkDefaultDisallowedProperties(Configuration) - Static method in class org.apache.oozie.util.PropertiesUtils
-
- checkDisallowedProperties(Configuration, Set<String>) - Static method in class org.apache.oozie.util.PropertiesUtils
-
Validate against DISALLOWED Properties.
- checkForAvailability(String, Configuration, boolean) - Static method in class org.apache.oozie.dependency.DependencyChecker
-
Get the currently missing and available dependencies after checking the list of known missing
dependencies against the source.
- checkForAvailability(List<String>, Configuration, boolean) - Static method in class org.apache.oozie.dependency.DependencyChecker
-
Get the currently missing and available dependencies after checking the list of known missing
dependencies against the source.
- checkFrequency(String) - Static method in class org.apache.oozie.util.ParamChecker
-
Check whether a value is a valid coordinator frequency.
- checkGEZero(int, String) - Static method in class org.apache.oozie.util.ParamChecker
-
Check whether the value is greater than or equals to 0.
- checkGTZero(int, String) - Static method in class org.apache.oozie.util.ParamChecker
-
Check whether the value is greater than or equals 0.
- checkIfBothSameType(String, String) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
- checkIfRunning(OozieClient, String) - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- checkInteger(String, String) - Static method in class org.apache.oozie.util.ParamChecker
-
Check whether the value is Integer.
- checkInterrupts(String) - Method in class org.apache.oozie.service.CallableQueueService
-
check the interrupt map for the existence of an interrupt commands if
exist a List of Interrupt Callable for the same lock key will bereturned,
otherwise it will return null
- checkInterruptTypes(XCallable<?>) - Method in class org.apache.oozie.service.CallableQueueService
-
check if the callable is of an interrupt type and insert it into the map
accordingly
- checkLEZero(int, String) - Static method in class org.apache.oozie.util.ParamChecker
-
Check whether the value is less than or equal to 0.
- checkMandatoryConf(Configuration) - Method in class org.apache.oozie.command.wf.SubmitHttpXCommand
-
- checkMandatoryConf(Configuration) - Method in class org.apache.oozie.command.wf.SubmitMRXCommand
-
- checkMaxConcurrency(String) - Method in class org.apache.oozie.service.AsyncXCommandExecutor
-
- checkPullMissingDependencies(CoordinatorActionBean, StringBuilder, StringBuilder) - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- checkPullMissingDependencies(CoordinatorActionBean, StringBuilder, StringBuilder) - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Check pull missing dependencies.
- checkPullMissingDependencies(CoordinatorActionBean, StringBuilder, StringBuilder) - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- checkPullMissingDependencies() - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorUtil
-
Check pull missing dependencies.
- checkPushDependencies() - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorUtil
-
Check push dependencies.
- checkPushMissingDependencies(CoordinatorActionBean, boolean) - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- checkPushMissingDependencies(CoordinatorActionBean, boolean) - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Check push missing dependencies.
- checkPushMissingDependencies(CoordinatorActionBean, boolean) - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- checkResolvedInput(StringBuilder, StringBuilder, StringBuilder, Configuration) - Method in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
To check the list of input paths if all of them exist
- checkStaticExistence(String, String) - Static method in class org.apache.oozie.util.StringUtils
-
Check if the input expression contains sequence statically.
- checkSupportedFilesystem(URI) - Method in class org.apache.oozie.service.HadoopAccessorService
-
checks configuration parameter if filesystem scheme is among the list of supported ones
this makes system robust to filesystems other than HDFS also
- checkTimeZone(String, String) - Static method in class org.apache.oozie.util.ParamChecker
-
Check whether the value mention correct Timezone.
- checkUnresolved(CoordinatorActionBean, Element) - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- checkUnresolved(CoordinatorActionBean, Element) - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Check unresolved.
- checkUnresolved(CoordinatorActionBean, Element) - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- checkUnResolved(Date) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorUtil
-
Check unresolved.
- checkUnResolvedInput(CoordinatorActionBean, StringBuilder, Configuration) - Method in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
Check un resolved input.
- checkUnResolvedInput(StringBuilder, Configuration) - Method in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
Check un resolved input.
- ChildReaper - Class in org.apache.oozie.util
-
Utility to reap empty child nodes of a parent node.
- ChildReaper(CuratorFramework, String, Reaper.Mode) - Constructor for class org.apache.oozie.util.ChildReaper
-
- ChildReaper(CuratorFramework, String, Reaper.Mode, int) - Constructor for class org.apache.oozie.util.ChildReaper
-
- ChildReaper(CuratorFramework, String, Reaper.Mode, ScheduledExecutorService, int) - Constructor for class org.apache.oozie.util.ChildReaper
-
- ChildReaper(CuratorFramework, String, Reaper.Mode, ScheduledExecutorService, int, String) - Constructor for class org.apache.oozie.util.ChildReaper
-
- CLASS_NAMES - Static variable in class org.apache.oozie.action.hadoop.DistcpActionExecutor
-
- ClasspathUtils - Class in org.apache.oozie.util
-
- ClasspathUtils() - Constructor for class org.apache.oozie.util.ClasspathUtils
-
- ClassUtils - Class in org.apache.oozie.util
-
Class utilities.
- ClassUtils() - Constructor for class org.apache.oozie.util.ClassUtils
-
- clear() - Method in interface org.apache.oozie.event.EventQueue
-
Clear the events queue
- clear() - Method in class org.apache.oozie.event.MemoryEventQueue
-
- clear() - Method in interface org.apache.oozie.sla.SLACalculator
-
- clear() - Method in class org.apache.oozie.sla.SLACalculatorMemory
-
- clear() - Method in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
Removes all of the elements from this queue.
- clear() - Method in class org.apache.oozie.util.XLog.Info
-
Clear all parameters set in this logInfo instance.
- clearEntries() - Static method in class org.apache.oozie.util.JaasConfiguration
-
Clears all entries.
- clearLogPrefix() - Static method in class org.apache.oozie.util.LogUtils
-
- clearParameter(String) - Method in class org.apache.oozie.util.XLog.Info
-
Clear a parameter value from the LogInfo
context.
- clearWarnings() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- CLIENT_ID_TAG - Static variable in class org.apache.oozie.util.db.SLADbOperations
-
Deprecated.
- CLIENT_ID_TAG - Static variable in class org.apache.oozie.util.db.SLADbXOperations
-
Deprecated.
- clone() - Method in class org.apache.oozie.dependency.hcat.EhcacheHCatDependencyCache
-
- close() - Method in interface org.apache.oozie.jms.ConnectionContext
-
Closes the connection
- close() - Method in class org.apache.oozie.jms.DefaultConnectionContext
-
- close() - Method in class org.apache.oozie.util.ChildReaper
-
- close() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- close() - Method in class org.apache.oozie.util.db.SqlStatement.ResultSetReader
-
Close the Result Set
- close() - Method in class org.apache.oozie.util.MultiFileReader
-
- close() - Method in class org.apache.oozie.workflow.lite.DBLiteWorkflowLib
-
- close() - Method in interface org.apache.oozie.workflow.WorkflowLib
-
Close store.
- closeReader() - Method in class org.apache.oozie.util.TimestampedMessageParser
-
Closes the Reader.
- closeSafely(Closeable...) - Static method in class org.apache.oozie.util.IOUtils
-
Close a list of resources.
- closeTrx() - Method in class org.apache.oozie.store.Store
-
Close current transaction
- CODEC_NAME - Static variable in class org.apache.oozie.compression.GzipCompressionCodec
-
- CodecFactory - Class in org.apache.oozie.compression
-
Utility class for maintaining list of codecs and providing facility
for compressing and decompressing.
- CodecFactory() - Constructor for class org.apache.oozie.compression.CodecFactory
-
- column() - Method in enum org.apache.oozie.store.OozieSchema.OozieIndex
-
- column() - Method in interface org.apache.oozie.util.db.Schema.Index
-
Column that is to be indexed
- columnName() - Method in enum org.apache.oozie.store.OozieSchema.OozieColumn
-
- columnName() - Method in interface org.apache.oozie.util.db.Schema.Column
-
Name of the column
- combine(String...) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicBuilder
-
Combine function of dataset
- combine(String...) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicBuilder.CoordInputDependencyBuilder
-
Construct complie function
- combine(AbstractCoordInputDependency, String[], int, int) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
- combine(AbstractCoordInputDependency, String[], int, int) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseThree
-
- COMBINE - Static variable in class org.apache.oozie.coord.input.logic.InputLogicParser
-
- CommandException - Exception in org.apache.oozie.command
-
- CommandException(XException) - Constructor for exception org.apache.oozie.command.CommandException
-
Create an dag command exception from a XException.
- CommandException(ErrorCode, Object...) - Constructor for exception org.apache.oozie.command.CommandException
-
Create a dag command exception.
- commandFinished() - Method in class org.apache.oozie.service.AsyncXCommandExecutor
-
- commit() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- commit() - Method in class org.apache.oozie.workflow.lite.DBLiteWorkflowLib
-
- commit() - Method in interface org.apache.oozie.workflow.WorkflowLib
-
Commit changes to store.
- commitTrx() - Method in class org.apache.oozie.store.Store
-
Commit current transaction
- compare(CallableQueueService.CallableWrapper<?>, CallableQueueService.CallableWrapper<?>) - Method in class org.apache.oozie.service.AsyncXCommandExecutor.PriorityComparator
-
- compareTo(Delayed) - Method in class org.apache.oozie.service.AsyncXCommandExecutor.AccessibleRunnableScheduledFuture
-
- compareTo(Delayed) - Method in class org.apache.oozie.util.PriorityDelayQueue.QueueElement
-
Deprecated.
Compare the age of this wrapper element with another.
- compareTo(XLogStreamer.FileInfo) - Method in class org.apache.oozie.util.XLogStreamer.FileInfo
-
- CompletedActionXCommand - Class in org.apache.oozie.command.wf
-
This command is executed once the Workflow command is finished.
- CompletedActionXCommand(String, String, Properties, int, int) - Constructor for class org.apache.oozie.command.wf.CompletedActionXCommand
-
- CompletedActionXCommand(String, String, Properties, int) - Constructor for class org.apache.oozie.command.wf.CompletedActionXCommand
-
- CompletedActionXCommand(String, String, Properties) - Constructor for class org.apache.oozie.command.wf.CompletedActionXCommand
-
- completeJob() - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- CompositeIndex - Enum in org.apache.oozie.util.db
-
- compressBytes(byte[], byte[]) - Method in interface org.apache.oozie.compression.CompressionCodec
-
- compressBytes(byte[], byte[]) - Method in class org.apache.oozie.compression.GzipCompressionCodec
-
- COMPRESSION_CODECS - Static variable in class org.apache.oozie.compression.CodecFactory
-
- COMPRESSION_KEY_HEADER - Static variable in class org.apache.oozie.compression.CodecFactory
-
- COMPRESSION_MAGIC_DATA - Static variable in class org.apache.oozie.compression.CodecFactory
-
- COMPRESSION_OUTPUT_CODEC - Static variable in class org.apache.oozie.compression.CodecFactory
-
- CompressionCodec - Interface in org.apache.oozie.compression
-
- compressString(byte[], String) - Method in interface org.apache.oozie.compression.CompressionCodec
-
- compressString(byte[], String) - Method in class org.apache.oozie.compression.GzipCompressionCodec
-
- computeNextNominalTime(CoordinatorJobBean, CoordinatorActionBean) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
Computes the nominal time of the next action.
- concat(String, String) - Static method in class org.apache.oozie.util.ELConstantsFunctions
-
Return the concatenation of 2 strings.
- CONCURRENCY_DELAY - Static variable in class org.apache.oozie.service.CallableQueueService
-
- conf - Variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- CONF_ACTION_CHECK_DELAY - Static variable in class org.apache.oozie.service.ActionCheckerService
-
The time, in seconds, between an ActionCheck for the same action.
- CONF_ACTION_CHECK_INTERVAL - Static variable in class org.apache.oozie.service.ActionCheckerService
-
The frequency at which the ActionCheckService will run.
- CONF_ACTION_EXECUTOR_CLASSES - Static variable in class org.apache.oozie.service.ActionService
-
- CONF_ACTION_EXECUTOR_EXT_CLASSES - Static variable in class org.apache.oozie.service.ActionService
-
- CONF_ADMIN_GROUPS - Static variable in class org.apache.oozie.service.AuthorizationService
-
Configuration parameter to define admin groups, if NULL/empty the adminusers.txt file is used.
- CONF_ADMIN_USERS - Static variable in class org.apache.oozie.service.AuthorizationService
-
Configuration parameter to define admin users in oozie-site.xml.
- CONF_ALERT_EVENTS - Static variable in class org.apache.oozie.sla.service.SLAService
-
- CONF_AUTHORIZATION_ENABLED - Static variable in class org.apache.oozie.service.AuthorizationService
-
Configuration parameter to enable or disable Oozie admin role.
- CONF_BACKWARD_SUPPORT_FOR_COORD_STATUS - Static variable in class org.apache.oozie.service.StatusTransitService
-
- CONF_BACKWARD_SUPPORT_FOR_STATES_WITHOUT_ERROR - Static variable in class org.apache.oozie.service.StatusTransitService
-
- CONF_BASE_URL - Static variable in class org.apache.oozie.service.CallbackService
-
- CONF_BATCH_SIZE - Static variable in class org.apache.oozie.service.EventHandlerService
-
- CONF_BUNDLE_OLDER_THAN - Static variable in class org.apache.oozie.service.RecoveryService
-
Age of Bundle jobs to recover, in seconds.
- CONF_BUNDLE_PAUSE_START_INTERVAL - Static variable in class org.apache.oozie.service.PauseTransitService
-
- CONF_CACHE_NAME - Static variable in class org.apache.oozie.dependency.hcat.EhcacheHCatDependencyCache
-
- CONF_CALCULATOR_IMPL - Static variable in class org.apache.oozie.sla.service.SLAService
-
- CONF_CALLABLE_BATCH_SIZE - Static variable in class org.apache.oozie.service.ActionCheckerService
-
The number of callables to be queued in a batch.
- CONF_CALLABLE_BATCH_SIZE - Static variable in class org.apache.oozie.service.CoordMaterializeTriggerService
-
The number of callables to be queued in a batch.
- CONF_CALLABLE_BATCH_SIZE - Static variable in class org.apache.oozie.service.PauseTransitService
-
- CONF_CALLABLE_BATCH_SIZE - Static variable in class org.apache.oozie.service.RecoveryService
-
The number of callables to be queued in a batch.
- CONF_CALLABLE_CONCURRENCY - Static variable in class org.apache.oozie.service.CallableQueueService
-
- CONF_CALLABLE_INTERRUPT_MAP_MAX_SIZE - Static variable in class org.apache.oozie.service.CallableQueueService
-
- CONF_CALLABLE_INTERRUPT_TYPES - Static variable in class org.apache.oozie.service.CallableQueueService
-
- CONF_CALLABLE_NEXT_ELIGIBLE - Static variable in class org.apache.oozie.service.CallableQueueService
-
- CONF_CAPACITY - Static variable in class org.apache.oozie.sla.service.SLAService
-
- CONF_CHECK_DELAY - Static variable in class org.apache.oozie.service.AbandonedCoordCheckerService
-
- CONF_CHECK_INTERVAL - Static variable in class org.apache.oozie.service.AbandonedCoordCheckerService
-
- CONF_CHECK_MAX_FREQUENCY - Static variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- CONF_CONN_DATA_SOURCE - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_CONN_PROPERTIES - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_CONSOLE_URL - Static variable in class org.apache.oozie.command.wf.JobXCommand
-
- CONF_CONSTANTS - Static variable in class org.apache.oozie.service.ELService
-
- CONF_COORD_INPUT_CHECK_REQUEUE_INTERVAL - Static variable in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
Property name of command re-queue interval for coordinator action input check in
milliseconds.
- CONF_COORD_INPUT_CHECK_REQUEUE_INTERVAL_ADDITIONAL_DELAY - Static variable in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
- CONF_COORD_OLDER_THAN - Static variable in class org.apache.oozie.service.RecoveryService
-
Age of coordinator jobs to recover, in seconds.
- CONF_COORD_PUSH_CHECK_REQUEUE_INTERVAL - Static variable in class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
Property name of command re-queue interval for coordinator push check in
milliseconds.
- CONF_CREATE_DB_SCHEMA - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_DB_SCHEMA - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_DEFAULT_CONCURRENCY - Static variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- CONF_DEFAULT_GROUP_AS_ACL - Static variable in class org.apache.oozie.service.AuthorizationService
-
Configuration parameter to enable old behavior default group as ACL.
- CONF_DEFAULT_MAX_TIMEOUT - Static variable in class org.apache.oozie.command.coord.CoordMaterializeTransitionXCommand
-
Default MAX timeout in minutes, after which coordinator input check will timeout
- CONF_DEFAULT_MAX_TIMEOUT - Static variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
Default MAX timeout in minutes, after which coordinator input check will timeout
- CONF_DEFAULT_THROTTLE - Static variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- CONF_DEFAULT_TIMEOUT_NORMAL - Static variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
Default timeout for normal jobs, in minutes, after which coordinator input check will timeout
- CONF_DELAYED_CALLABLE_THREADS - Static variable in class org.apache.oozie.service.CallableQueueService
-
- CONF_DELETE_RUNTIME_DIR - Static variable in class org.apache.oozie.service.Services
-
- CONF_DRIVER - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_EARLY_REQUEUE_MAX_RETRIES - Static variable in class org.apache.oozie.service.CallbackService
-
- CONF_EVENT_QUEUE - Static variable in class org.apache.oozie.service.EventHandlerService
-
- CONF_EVENTS_MODIFIED_AFTER - Static variable in class org.apache.oozie.sla.service.SLAService
-
- CONF_EXT_CONSTANTS - Static variable in class org.apache.oozie.service.ELService
-
- CONF_EXT_FUNCTIONS - Static variable in class org.apache.oozie.service.ELService
-
- CONF_EXT_SCHEMAS - Static variable in class org.apache.oozie.service.WorkflowSchemaService
-
- CONF_FAILURE_LEN - Static variable in class org.apache.oozie.service.AbandonedCoordCheckerService
-
- CONF_FILTER_APP_TYPES - Static variable in class org.apache.oozie.service.EventHandlerService
-
- CONF_FUNCTIONS - Static variable in class org.apache.oozie.service.ELService
-
- CONF_GENERATOR - Static variable in class org.apache.oozie.service.UUIDService
-
- CONF_GROUPS - Static variable in class org.apache.oozie.service.ELService
-
- CONF_IGNORE_EXTRAS - Static variable in class org.apache.oozie.service.SchemaCheckerService
-
- CONF_IGNORE_SYS_PROPS - Static variable in class org.apache.oozie.service.ConfigurationService
-
- CONF_INTERVAL - Static variable in class org.apache.oozie.service.SchemaCheckerService
-
- CONF_JAVAX_XML_PARSERS_DOCUMENTBUILDERFACTORY - Static variable in class org.apache.oozie.service.ConfigurationService
-
- CONF_JOB_EVENT_LATENCY - Static variable in class org.apache.oozie.sla.service.SLAService
-
- CONF_JOB_INFO - Static variable in class org.apache.oozie.action.hadoop.OozieJobInfo
-
- CONF_JOB_KILL - Static variable in class org.apache.oozie.service.AbandonedCoordCheckerService
-
- CONF_JOB_OLDER_THAN - Static variable in class org.apache.oozie.service.AbandonedCoordCheckerService
-
- CONF_LISTENERS - Static variable in class org.apache.oozie.service.EventHandlerService
-
- CONF_LOGGING_INTERVAL - Static variable in class org.apache.oozie.service.InstrumentationService
-
Deprecated.
- CONF_LOOKUP_INTERVAL - Static variable in class org.apache.oozie.service.CoordMaterializeTriggerService
-
Time interval, in seconds, at which the Job materialization service will be scheduled to run.
- CONF_MAT_THROTTLING_FACTOR - Static variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- CONF_MATERIALIZATION_SYSTEM_LIMIT - Static variable in class org.apache.oozie.service.CoordMaterializeTriggerService
-
The number of coordinator jobs to be picked for materialization at a given time.
- CONF_MATERIALIZATION_WINDOW - Static variable in class org.apache.oozie.service.CoordMaterializeTriggerService
-
This configuration defined the duration for which job should be materialized in future
- CONF_MAX_ACTIVE_CONN - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_MAX_DATA_LEN - Static variable in class org.apache.oozie.servlet.CallbackServlet
-
- CONF_MAXIMUM_RETRY_COUNT - Static variable in class org.apache.oozie.sla.service.SLAService
-
- CONF_METRICS_INTERVAL_MINS - Static variable in class org.apache.oozie.service.DBLiteWorkflowStoreService
-
- CONF_METRICS_INTERVAL_WINDOW - Static variable in class org.apache.oozie.service.DBLiteWorkflowStoreService
-
- CONF_NEWIMPL - Static variable in class org.apache.oozie.service.CallableQueueService
-
- CONF_NODE_DEF_VERSION - Static variable in class org.apache.oozie.service.LiteWorkflowStoreService
-
- CONF_OLDER_THAN - Static variable in class org.apache.oozie.service.PurgeService
-
Age of completed jobs to be deleted, in days.
- CONF_OOZIE_DISTCP_ACTION_MAIN_CLASS - Static variable in class org.apache.oozie.action.hadoop.DistcpActionExecutor
-
- CONF_OPENJPA_BROKER_IMPL - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_PASSWORD - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.action.ActionExecutor
-
Configuration prefix for action executor (sub-classes) properties.
- CONF_PREFIX - Static variable in class org.apache.oozie.action.email.EmailActionExecutor
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.ActionCheckerService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.AuthorizationService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.CallableQueueService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.CallbackService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.ConfigurationService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.CoordMaterializeTriggerService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.DBLiteWorkflowStoreService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.ELService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.EventHandlerService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.GroupsService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.HadoopAccessorService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.HCatAccessorService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.InstrumentationService
-
Deprecated.
- CONF_PREFIX - Static variable in class org.apache.oozie.service.JMSAccessorService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.JMSTopicService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.JvmPauseMonitorService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.LiteWorkflowStoreService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.PartitionDependencyManagerService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.PauseTransitService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.ProxyUserService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.PurgeService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.SchedulerService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.SchemaCheckerService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.SchemaService
-
- CONF_PREFIX - Static variable in interface org.apache.oozie.service.Service
-
Prefix for all services configuration properties.
- CONF_PREFIX - Static variable in class org.apache.oozie.service.SparkConfigurationService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.UUIDService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.WorkflowAppService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.WorkflowSchemaService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.service.ZKUUIDService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.sla.service.SLAService
-
- CONF_PREFIX - Static variable in class org.apache.oozie.util.XLogStreamer
-
- CONF_PREFIX_BUNDLE - Static variable in class org.apache.oozie.service.RecoveryService
-
- CONF_PREFIX_COORD - Static variable in class org.apache.oozie.service.RecoveryService
-
- CONF_PREFIX_USER_RETRY - Static variable in class org.apache.oozie.service.LiteWorkflowStoreService
-
- CONF_PREFIX_WF_ACTIONS - Static variable in class org.apache.oozie.service.RecoveryService
-
- CONF_PURGE_INTERVAL - Static variable in class org.apache.oozie.service.PurgeService
-
Time interval, in seconds, at which the purge jobs service will be scheduled to run.
- CONF_PUSH_DEPENDENCY_INTERVAL - Static variable in class org.apache.oozie.service.RecoveryService
-
Delay for the push missing dependencies in milliseconds.
- CONF_QUEUE_AWAIT_TERMINATION_TIMEOUT_SECONDS - Static variable in class org.apache.oozie.service.CallableQueueService
-
- CONF_QUEUE_SIZE - Static variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- CONF_QUEUE_SIZE - Static variable in class org.apache.oozie.service.CallableQueueService
-
- CONF_QUEUE_SIZE - Static variable in class org.apache.oozie.service.EventHandlerService
-
- CONF_RETRY_INITIAL_DELAY - Static variable in class org.apache.oozie.service.JMSAccessorService
-
- CONF_RETRY_MAX_ATTEMPTS - Static variable in class org.apache.oozie.service.JMSAccessorService
-
- CONF_RETRY_MULTIPLIER - Static variable in class org.apache.oozie.service.JMSAccessorService
-
- CONF_SCHEDULING_INTERVAL - Static variable in class org.apache.oozie.service.CoordMaterializeTriggerService
-
- CONF_SECURITY_ENABLED - Static variable in class org.apache.oozie.service.AuthorizationService
-
Configuration parameter to enable or disable Oozie admin role.
- CONF_SEQUENCE_MAX - Static variable in class org.apache.oozie.service.ZKUUIDService
-
- CONF_SERVICE_CLASSES - Static variable in class org.apache.oozie.service.Services
-
- CONF_SERVICE_EXT_CLASSES - Static variable in class org.apache.oozie.service.Services
-
- CONF_SERVICE_INTERVAL - Static variable in class org.apache.oozie.service.RecoveryService
-
Time interval, in seconds, at which the recovery service will be scheduled to run.
- CONF_SHUTDOWN_ON_TIMEOUT - Static variable in class org.apache.oozie.event.listener.ZKConnectionListener
-
- CONF_SLA_CALC_LOCK_TIMEOUT - Static variable in class org.apache.oozie.sla.service.SLAService
-
- CONF_SLA_CHECK_INITIAL_DELAY - Static variable in class org.apache.oozie.sla.service.SLAService
-
- CONF_SLA_CHECK_INTERVAL - Static variable in class org.apache.oozie.sla.service.SLAService
-
- CONF_SLA_HISTORY_PURGE_INTERVAL - Static variable in class org.apache.oozie.sla.service.SLAService
-
- CONF_SSH_ALLOW_USER_AT_HOST - Static variable in class org.apache.oozie.action.ssh.SshActionExecutor
-
Configuration parameter which specifies whether the specified ssh user is allowed, or has to be the job user.
- CONF_SYSTEM_ID - Static variable in class org.apache.oozie.service.Services
-
- CONF_SYSTEM_INFO_AUTHORIZED_USERS - Static variable in class org.apache.oozie.service.AuthorizationService
-
- CONF_SYSTEM_MODE - Static variable in class org.apache.oozie.service.Services
-
- CONF_THREADS - Static variable in class org.apache.oozie.service.CallableQueueService
-
- CONF_URL - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_USER_RETRY_ERROR_CODE - Static variable in class org.apache.oozie.service.LiteWorkflowStoreService
-
- CONF_USER_RETRY_ERROR_CODE_EXT - Static variable in class org.apache.oozie.service.LiteWorkflowStoreService
-
- CONF_USER_RETRY_INTEVAL - Static variable in class org.apache.oozie.service.LiteWorkflowStoreService
-
- CONF_USER_RETRY_MAX - Static variable in class org.apache.oozie.service.LiteWorkflowStoreService
-
- CONF_USER_RETRY_POLICY - Static variable in class org.apache.oozie.service.LiteWorkflowStoreService
-
- CONF_USERNAME - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_VALIDATE_DB_CONN - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_VALIDATE_DB_CONN_EVICTION_INTERVAL - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_VALIDATE_DB_CONN_EVICTION_NUM - Static variable in class org.apache.oozie.service.JPAService
-
- CONF_VERIFY_AVAILABLE_PROPS - Static variable in class org.apache.oozie.service.ConfigurationService
-
- CONF_WF_ACTIONS_CREATED_TIME_INTERVAL - Static variable in class org.apache.oozie.service.RecoveryService
-
- CONF_WF_ACTIONS_OLDER_THAN - Static variable in class org.apache.oozie.service.RecoveryService
-
Age of actions to queue, in seconds.
- CONF_WORKER_INTERVAL - Static variable in class org.apache.oozie.service.EventHandlerService
-
- CONF_WORKER_THREADS - Static variable in class org.apache.oozie.service.EventHandlerService
-
- CONFG_MAX_WF_LENGTH - Static variable in class org.apache.oozie.service.WorkflowAppService
-
- CONFIG_DEFAULT - Static variable in class org.apache.oozie.command.bundle.BundleSubmitXCommand
-
- CONFIG_DEFAULT - Static variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- CONFIG_DEFAULT - Static variable in class org.apache.oozie.command.wf.SubmitXCommand
-
- CONFIGURATION - Static variable in class org.apache.oozie.coord.CoordELFunctions
-
- CONFIGURATION_SUBSTITUTE_DEPTH - Static variable in class org.apache.oozie.util.XConfiguration
-
- ConfigurationService - Class in org.apache.oozie.service
-
Built in service that initializes the services configuration.
- ConfigurationService() - Constructor for class org.apache.oozie.service.ConfigurationService
-
- configureEvaluator(ELEvaluator, SyncCoordDataset, SyncCoordAction) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Configure an evaluator with data set and application specific information.
- configureEvaluator(ELEvaluator, WorkflowJobBean, WorkflowActionBean) - Static method in class org.apache.oozie.DagELFunctions
-
- ConfigUtils - Class in org.apache.oozie.util
-
- ConfigUtils() - Constructor for class org.apache.oozie.util.ConfigUtils
-
- connect(String, Properties) - Method in class org.apache.oozie.util.db.FailingHSQLDBDriverWrapper
-
- connect(String, Properties) - Method in class org.apache.oozie.util.db.FailingMySQLDriverWrapper
-
- connection - Variable in class org.apache.oozie.jms.DefaultConnectionContext
-
- ConnectionContext - Interface in org.apache.oozie.jms
-
Maintains a JMS connection for creating session, consumer and producer
- connectionFactoryName - Variable in class org.apache.oozie.jms.DefaultConnectionContext
-
- constructPattern() - Method in class org.apache.oozie.util.XLogAuditFilter
-
- constructPattern() - Method in class org.apache.oozie.util.XLogFilter
-
Constructs the regular expression according to the filter and assigns it
to fileterPattarn.
- contains(Object) - Method in class org.apache.oozie.store.Store
-
- context - Variable in class org.apache.oozie.command.wf.ActionStartXCommand
-
- Context(Configuration, String) - Constructor for class org.apache.oozie.dependency.URIHandler.Context
-
Create a Context that can be used to access a URI
- Context() - Constructor for class org.apache.oozie.util.ELEvaluator.Context
-
Create an empty context.
- contextDestroyed(ServletContextEvent) - Method in class org.apache.oozie.servlet.ServicesLoader
-
Destroy Oozie services.
- contextInitialized(ServletContextEvent) - Method in class org.apache.oozie.servlet.ServicesLoader
-
Initialize Oozie services.
- ControlNodeActionExecutor - Class in org.apache.oozie.action.control
-
Base action executor for control nodes: START/END/KILL/FORK/JOIN
- ControlNodeActionExecutor(String) - Constructor for class org.apache.oozie.action.control.ControlNodeActionExecutor
-
- ControlNodeDef - Class in org.apache.oozie.workflow.lite
-
Node definition for control nodes: START/END/KILL/FORK/JOIN.
- ControlNodeDef(String, String, Class<? extends ControlNodeHandler>, List<String>) - Constructor for class org.apache.oozie.workflow.lite.ControlNodeDef
-
- ControlNodeHandler - Class in org.apache.oozie.workflow.lite
-
Node handler that provides the necessary workflow logic for control nodes: START/END/KILL/FORK/JOIN.
- ControlNodeHandler() - Constructor for class org.apache.oozie.workflow.lite.ControlNodeHandler
-
- convertDateToTimestamp(Date) - Static method in class org.apache.oozie.util.DateUtils
-
Convert java.util.Date to java.sql.Timestamp
- convertException(Exception) - Method in class org.apache.oozie.action.ActionExecutor
-
- COORD_ACTION - Static variable in class org.apache.oozie.coord.CoordELFunctions
-
- COORD_ACTIONS_DEFAULT_LENGTH - Static variable in class org.apache.oozie.servlet.V1JobServlet
-
- COORD_ACTIONS_LOG_MAX_COUNT - Static variable in class org.apache.oozie.CoordinatorEngine
-
- coord_actualTime_echo() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- coord_conf(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Return a job configuration property for the coordinator.
- COORD_CONF_EXT_SCHEMAS - Static variable in class org.apache.oozie.service.SchemaService
-
- COORD_CONF_OLDER_THAN - Static variable in class org.apache.oozie.service.PurgeService
-
- COORD_CONF_SCHEMAS - Static variable in class org.apache.oozie.service.SchemaService
-
- coord_days_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- coord_endOfDay_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- coord_endOfMonth_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- COORD_EXECUTION_NONE_TOLERANCE - Static variable in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
- COORD_GET_ALL_COLS_FOR_ACTION - Static variable in class org.apache.oozie.executor.jpa.CoordActionGetForInfoJPAExecutor
-
- coord_hours_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- COORD_ID - Static variable in class org.apache.oozie.action.hadoop.OozieJobInfo
-
- COORD_INPUT_EVENTS - Variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- COORD_INPUT_EVENTS_DATA_IN - Variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- COORD_INPUT_EVENTS_DATA_IN - Static variable in class org.apache.oozie.coord.input.logic.InputLogicParser
-
- coord_minutes_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- coord_months_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- COORD_NAME - Static variable in class org.apache.oozie.action.hadoop.OozieJobInfo
-
- COORD_NOMINAL_TIME - Static variable in class org.apache.oozie.action.hadoop.OozieJobInfo
-
- COORD_OUTPUT_EVENTS - Variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- COORD_OUTPUT_EVENTS_DATA_OUT - Variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- coord_user() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Return the user that submitted the coordinator job.
- coordAction - Variable in class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
- coordAction - Variable in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
- coordAction - Variable in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseValidate
-
- CoordActionCheckXCommand - Class in org.apache.oozie.command.coord
-
The command checks workflow status for coordinator action.
- CoordActionCheckXCommand(String, int) - Constructor for class org.apache.oozie.command.coord.CoordActionCheckXCommand
-
- CoordActionGetForCheckJPAExecutor - Class in org.apache.oozie.executor.jpa
-
JPAExecutor to get attributes of CoordinatorActionBean required by CoordActionCheckCommand
- CoordActionGetForCheckJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordActionGetForCheckJPAExecutor
-
- CoordActionGetForExternalIdJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load coordinator action by externalId.
- CoordActionGetForExternalIdJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordActionGetForExternalIdJPAExecutor
-
- CoordActionGetForInfoJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the CoordinatorAction into a Bean and return it.
- CoordActionGetForInfoJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordActionGetForInfoJPAExecutor
-
- CoordActionGetForInputCheckJPAExecutor - Class in org.apache.oozie.executor.jpa
-
JPAExecutor to get attributes of CoordinatorActionBean required by CoordActionInputCheckXCommand
- CoordActionGetForInputCheckJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordActionGetForInputCheckJPAExecutor
-
- CoordActionGetForStartJPAExecutor - Class in org.apache.oozie.executor.jpa
-
JPAExecutor to get attributes of CoordinatorActionBean required by CoordActionStartXCommand
- CoordActionGetForStartJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordActionGetForStartJPAExecutor
-
- CoordActionGetForTimeoutJPAExecutor - Class in org.apache.oozie.executor.jpa
-
JPAExecutor to get attributes of CoordinatorActionBean required by CoordActionTimeoutXCommand
- CoordActionGetForTimeoutJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordActionGetForTimeoutJPAExecutor
-
- CoordActionGetJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the CoordinatorAction into a Bean and return it.
- CoordActionGetJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordActionGetJPAExecutor
-
- CoordActionInfoXCommand - Class in org.apache.oozie.command.coord
-
- CoordActionInfoXCommand(String) - Constructor for class org.apache.oozie.command.coord.CoordActionInfoXCommand
-
- CoordActionInputCheckXCommand - Class in org.apache.oozie.command.coord
-
The command to check if an action's data input paths exist in the file system.
- CoordActionInputCheckXCommand(String, String) - Constructor for class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
- CoordActionInsertJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Persist the CoordinatorAction bean.
- CoordActionInsertJPAExecutor(CoordinatorActionBean) - Constructor for class org.apache.oozie.executor.jpa.CoordActionInsertJPAExecutor
-
- CoordActionMissingDependenciesXCommand - Class in org.apache.oozie.command.coord
-
- CoordActionMissingDependenciesXCommand(String, String, String) - Constructor for class org.apache.oozie.command.coord.CoordActionMissingDependenciesXCommand
-
- CoordActionMissingDependenciesXCommand(String) - Constructor for class org.apache.oozie.command.coord.CoordActionMissingDependenciesXCommand
-
- CoordActionNotificationXCommand - Class in org.apache.oozie.command.coord
-
This class will send the notification for the coordinator action
- CoordActionNotificationXCommand(CoordinatorActionBean) - Constructor for class org.apache.oozie.command.coord.CoordActionNotificationXCommand
-
- CoordActionQueryExecutor - Class in org.apache.oozie.executor.jpa
-
Query Executor that provides API to run query for Coordinator Action
- CoordActionQueryExecutor.CoordActionQuery - Enum in org.apache.oozie.executor.jpa
-
- CoordActionReadyXCommand - Class in org.apache.oozie.command.coord
-
- CoordActionReadyXCommand(String) - Constructor for class org.apache.oozie.command.coord.CoordActionReadyXCommand
-
- CoordActionRemoveJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Deletes the coordinator action if its in WAITING or READY state.
- CoordActionRemoveJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordActionRemoveJPAExecutor
-
Constructor which records coordinator action id.
- CoordActionsActiveCountJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the number of running actions for a coordinator job.
- CoordActionsActiveCountJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordActionsActiveCountJPAExecutor
-
- CoordActionsCountForJobIdJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the number of running actions for a coordinator job.
- CoordActionsCountForJobIdJPAExecutor(String, Map<Pair<String, CoordinatorEngine.FILTER_COMPARATORS>, List<Object>>) - Constructor for class org.apache.oozie.executor.jpa.CoordActionsCountForJobIdJPAExecutor
-
- CoordActionsDeleteJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Delete Coord actions of long running coordinators, return the number of actions that were deleted.
- CoordActionsDeleteJPAExecutor(Collection<String>) - Constructor for class org.apache.oozie.executor.jpa.CoordActionsDeleteJPAExecutor
-
Initialize the JPAExecutor using the delete list of CoordinatorActionBeans
- CoordActionsDeleteJPAExecutor() - Constructor for class org.apache.oozie.executor.jpa.CoordActionsDeleteJPAExecutor
-
- CoordActionsGetFromCoordJobIdJPAExecutor - Class in org.apache.oozie.executor.jpa
-
- CoordActionsGetFromCoordJobIdJPAExecutor(String, int, int) - Constructor for class org.apache.oozie.executor.jpa.CoordActionsGetFromCoordJobIdJPAExecutor
-
- CoordActionsIgnoreXCommand - Class in org.apache.oozie.command.coord
-
- CoordActionsIgnoreXCommand(String, String, String) - Constructor for class org.apache.oozie.command.coord.CoordActionsIgnoreXCommand
-
- CoordActionsInDateRange - Class in org.apache.oozie.util
-
This class provides the utility of listing
coordinator actions that were executed between a certain
date range.
- CoordActionsInDateRange() - Constructor for class org.apache.oozie.util.CoordActionsInDateRange
-
- CoordActionsKillXCommand - Class in org.apache.oozie.command.coord
-
Kill coordinator actions by a range of dates (nominal time) or action number.
- CoordActionsKillXCommand(String, String, String) - Constructor for class org.apache.oozie.command.coord.CoordActionsKillXCommand
-
- CoordActionSkipXCommand - Class in org.apache.oozie.command.coord
-
This class sets a Coordinator action's status to SKIPPED
- CoordActionSkipXCommand(CoordinatorActionBean, String, String) - Constructor for class org.apache.oozie.command.coord.CoordActionSkipXCommand
-
- CoordActionsPendingFalseCountGetJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the number of pending actions for a coordinator job.
- CoordActionsPendingFalseCountGetJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordActionsPendingFalseCountGetJPAExecutor
-
- CoordActionsPendingFalseStatusCountGetJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the number of pending actions for a status for a coordinator job.
- CoordActionsPendingFalseStatusCountGetJPAExecutor(String, String) - Constructor for class org.apache.oozie.executor.jpa.CoordActionsPendingFalseStatusCountGetJPAExecutor
-
- CoordActionsRunningGetJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the list of running CoordinatorAction and return the list.
- CoordActionsRunningGetJPAExecutor(long) - Constructor for class org.apache.oozie.executor.jpa.CoordActionsRunningGetJPAExecutor
-
- CoordActionStartXCommand - Class in org.apache.oozie.command.coord
-
- CoordActionStartXCommand(String, String, String, String) - Constructor for class org.apache.oozie.command.coord.CoordActionStartXCommand
-
- CoordActionTimeOutXCommand - Class in org.apache.oozie.command.coord
-
This class updates the Time out in the action bean
- CoordActionTimeOutXCommand(CoordinatorActionBean, String, String) - Constructor for class org.apache.oozie.command.coord.CoordActionTimeOutXCommand
-
- CoordActionUpdatePushMissingDependency - Class in org.apache.oozie.command.coord
-
- CoordActionUpdatePushMissingDependency(String) - Constructor for class org.apache.oozie.command.coord.CoordActionUpdatePushMissingDependency
-
- CoordActionUpdateXCommand - Class in org.apache.oozie.command.coord
-
- CoordActionUpdateXCommand(WorkflowJobBean) - Constructor for class org.apache.oozie.command.coord.CoordActionUpdateXCommand
-
- CoordActionUpdateXCommand(WorkflowJobBean, int) - Constructor for class org.apache.oozie.command.coord.CoordActionUpdateXCommand
-
- CoordChangeXCommand - Class in org.apache.oozie.command.coord
-
- CoordChangeXCommand(String, String) - Constructor for class org.apache.oozie.command.coord.CoordChangeXCommand
-
This command is used to update the Coordinator job with the new values Update the coordinator job bean and update
that to database.
- CoordCommandUtils - Class in org.apache.oozie.command.coord
-
- CoordCommandUtils() - Constructor for class org.apache.oozie.command.coord.CoordCommandUtils
-
- coordCountStr - Static variable in class org.apache.oozie.store.StoreStatusFilter
-
- CoordELConstants - Class in org.apache.oozie.coord
-
- CoordELConstants() - Constructor for class org.apache.oozie.coord.CoordELConstants
-
- CoordELEvaluator - Class in org.apache.oozie.coord
-
This class provide different evaluators required at different stages
- CoordELEvaluator() - Constructor for class org.apache.oozie.coord.CoordELEvaluator
-
- CoordELFunctions - Class in org.apache.oozie.coord
-
This class implements the EL function related to coordinator
- CoordELFunctions() - Constructor for class org.apache.oozie.coord.CoordELFunctions
-
- COORDINATOR_NAMESPACE_URI_1 - Static variable in class org.apache.oozie.service.SchemaService
-
- COORDINATOR_XML_FILE - Static variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- CoordinatorActionBean - Class in org.apache.oozie
-
- CoordinatorActionBean() - Constructor for class org.apache.oozie.CoordinatorActionBean
-
- CoordinatorActionEvent - Class in org.apache.oozie.event
-
Class implementing JobEvent for events generated by Coordinator Actions
- CoordinatorActionEvent(String, String, CoordinatorAction.Status, String, String, Date, Date, String) - Constructor for class org.apache.oozie.event.CoordinatorActionEvent
-
- CoordinatorActionInfo - Class in org.apache.oozie
-
- CoordinatorActionInfo(List<CoordinatorActionBean>) - Constructor for class org.apache.oozie.CoordinatorActionInfo
-
Create a coordiantor actions info bean.
- CoordinatorEngine - Class in org.apache.oozie
-
- CoordinatorEngine() - Constructor for class org.apache.oozie.CoordinatorEngine
-
Create a system Coordinator engine, with no user and no group.
- CoordinatorEngine(String) - Constructor for class org.apache.oozie.CoordinatorEngine
-
Create a Coordinator engine to perform operations on behave of a user.
- CoordinatorEngine.FILTER_COMPARATORS - Enum in org.apache.oozie
-
- CoordinatorEngineException - Exception in org.apache.oozie
-
- CoordinatorEngineException(XException) - Constructor for exception org.apache.oozie.CoordinatorEngineException
-
Create a coordinator engine exception from a XException.
- CoordinatorEngineException(ErrorCode, Object...) - Constructor for exception org.apache.oozie.CoordinatorEngineException
-
Create a coordinator engine exception.
- CoordinatorEngineService - Class in org.apache.oozie.service
-
Service that return a coordinator engine for a user.
- CoordinatorEngineService() - Constructor for class org.apache.oozie.service.CoordinatorEngineService
-
- CoordinatorJobBean - Class in org.apache.oozie
-
- CoordinatorJobBean() - Constructor for class org.apache.oozie.CoordinatorJobBean
-
- CoordinatorJobEvent - Class in org.apache.oozie.event
-
Class implementing JobEvent for events generated by Coordinator Jobs
- CoordinatorJobEvent(String, String, Job.Status, String, String, Date, Date) - Constructor for class org.apache.oozie.event.CoordinatorJobEvent
-
- CoordinatorJobException - Exception in org.apache.oozie.coord
-
Exception thrown by CoordinatorJob
.
- CoordinatorJobException(XException) - Constructor for exception org.apache.oozie.coord.CoordinatorJobException
-
Create an Coordinator Job exception from a XException.
- CoordinatorJobException(ErrorCode, Object...) - Constructor for exception org.apache.oozie.coord.CoordinatorJobException
-
Create a Coordinator Job exception.
- CoordinatorJobGetForUserAppnameJPAExecutor - Class in org.apache.oozie.executor.jpa
-
DB query executor to fetch columns 'user' and 'appName' from Coordinator Job table
- CoordinatorJobGetForUserAppnameJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordinatorJobGetForUserAppnameJPAExecutor
-
- CoordinatorJobGetForUserJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Retrieve the name of user submitting coordinator
- CoordinatorJobGetForUserJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordinatorJobGetForUserJPAExecutor
-
- CoordinatorJobInfo - Class in org.apache.oozie
-
- CoordinatorJobInfo(List<CoordinatorJobBean>, int, int, int) - Constructor for class org.apache.oozie.CoordinatorJobInfo
-
Create a coordinator info bean.
- CoordinatorWfActionBean - Class in org.apache.oozie
-
- CoordinatorWfActionBean(int) - Constructor for class org.apache.oozie.CoordinatorWfActionBean
-
- CoordinatorWfActionBean(int, WorkflowActionBean, String) - Constructor for class org.apache.oozie.CoordinatorWfActionBean
-
- CoordinatorXCommand<T> - Class in org.apache.oozie.command.coord
-
Abstract coordinator command class derived from XCommand
- CoordinatorXCommand(String, String, int) - Constructor for class org.apache.oozie.command.coord.CoordinatorXCommand
-
Base class constructor for coordinator commands.
- CoordinatorXCommand(String, String, int, boolean) - Constructor for class org.apache.oozie.command.coord.CoordinatorXCommand
-
Base class constructor for coordinator commands.
- CoordInputDependency - Interface in org.apache.oozie.coord.input.dependency
-
- coordInputDependency - Variable in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
- CoordInputDependencyBuilder(CoordInputLogicEvaluator) - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicBuilder.CoordInputDependencyBuilder
-
- CoordInputDependencyFactory - Class in org.apache.oozie.coord.input.dependency
-
- CoordInputDependencyFactory() - Constructor for class org.apache.oozie.coord.input.dependency.CoordInputDependencyFactory
-
- CoordInputInstance - Class in org.apache.oozie.coord.input.dependency
-
- CoordInputInstance() - Constructor for class org.apache.oozie.coord.input.dependency.CoordInputInstance
-
- CoordInputInstance(String, boolean) - Constructor for class org.apache.oozie.coord.input.dependency.CoordInputInstance
-
- CoordInputLogicBuilder - Class in org.apache.oozie.coord.input.logic
-
- CoordInputLogicBuilder(CoordInputLogicEvaluator) - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicBuilder
-
- CoordInputLogicBuilder.CoordInputDependencyBuilder - Class in org.apache.oozie.coord.input.logic
-
The Class CoordInputDependencyBuilder.
- CoordInputLogicEvaluator - Interface in org.apache.oozie.coord.input.logic
-
- CoordInputLogicEvaluatorPhaseOne - Class in org.apache.oozie.coord.input.logic
-
PhaseOne is for all dependencies check, except unresolved.
- CoordInputLogicEvaluatorPhaseOne(CoordinatorActionBean) - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
- CoordInputLogicEvaluatorPhaseOne(CoordinatorActionBean, CoordInputDependency) - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
- CoordInputLogicEvaluatorPhaseThree - Class in org.apache.oozie.coord.input.logic
-
- CoordInputLogicEvaluatorPhaseThree(CoordinatorActionBean, ELEvaluator) - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseThree
-
- CoordInputLogicEvaluatorPhaseTwo - Class in org.apache.oozie.coord.input.logic
-
- CoordInputLogicEvaluatorPhaseTwo(CoordinatorActionBean, Date) - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseTwo
-
- CoordInputLogicEvaluatorPhaseTwo(CoordinatorActionBean, AbstractCoordInputDependency) - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseTwo
-
- CoordInputLogicEvaluatorPhaseValidate - Class in org.apache.oozie.coord.input.logic
-
- CoordInputLogicEvaluatorPhaseValidate(CoordinatorActionBean) - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseValidate
-
- CoordInputLogicEvaluatorResult - Class in org.apache.oozie.coord.input.logic
-
- CoordInputLogicEvaluatorResult() - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult
-
- CoordInputLogicEvaluatorResult(CoordInputLogicEvaluatorResult.STATUS, String) - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult
-
- CoordInputLogicEvaluatorResult(CoordInputLogicEvaluatorResult.STATUS) - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult
-
- CoordInputLogicEvaluatorResult.STATUS - Enum in org.apache.oozie.coord.input.logic
-
- CoordInputLogicEvaluatorUtil - Class in org.apache.oozie.coord.input.logic
-
- CoordInputLogicEvaluatorUtil(CoordinatorActionBean) - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorUtil
-
- CoordInputLogicEvaluatorUtil() - Constructor for class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorUtil
-
- CoordInputLogicEvaluatorUtil.OozieJexlParser - Class in org.apache.oozie.coord.input.logic
-
- coordJob - Variable in class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
- coordJob - Variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- coordJob - Variable in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseValidate
-
- CoordJobGetActionByActionNumberJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the CoordinatorJob into a Bean and return it.
- CoordJobGetActionByActionNumberJPAExecutor(String, int) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetActionByActionNumberJPAExecutor
-
- CoordJobGetActionForNominalTimeJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load coordinator action by nominal time.
- CoordJobGetActionForNominalTimeJPAExecutor(String, Date) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetActionForNominalTimeJPAExecutor
-
- CoordJobGetActionModifiedDateForRangeJPAExecutor - Class in org.apache.oozie.executor.jpa
-
- CoordJobGetActionModifiedDateForRangeJPAExecutor(String, String, String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetActionModifiedDateForRangeJPAExecutor
-
- CoordJobGetActionRunningCountForRangeJPAExecutor - Class in org.apache.oozie.executor.jpa
-
- CoordJobGetActionRunningCountForRangeJPAExecutor(String, String, String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetActionRunningCountForRangeJPAExecutor
-
- CoordJobGetActionsJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load coordinator actions for a coordinator job.
- CoordJobGetActionsJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetActionsJPAExecutor
-
- CoordJobGetActionsNotCompletedJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the Coordinator actions which are not completed for a given Coordinator job
- CoordJobGetActionsNotCompletedJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetActionsNotCompletedJPAExecutor
-
- CoordJobGetActionsRunningJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the running Coordinator actions for a given Coordinator job
- CoordJobGetActionsRunningJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetActionsRunningJPAExecutor
-
- CoordJobGetActionsStatusJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Get the status of Coordinator actions for a given Coordinator job
- CoordJobGetActionsStatusJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetActionsStatusJPAExecutor
-
- CoordJobGetActionsSubsetJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load coordinator actions by offset and len (a subset) for a coordinator job.
- CoordJobGetActionsSubsetJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetActionsSubsetJPAExecutor
-
- CoordJobGetActionsSubsetJPAExecutor(String, Map<Pair<String, CoordinatorEngine.FILTER_COMPARATORS>, List<Object>>, int, int, boolean) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetActionsSubsetJPAExecutor
-
- CoordJobGetActionsSuspendedJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the suspended Coordinator actions of a given Coordinator job
- CoordJobGetActionsSuspendedJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetActionsSuspendedJPAExecutor
-
- CoordJobGetJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the CoordinatorJob into a Bean and return it.
- CoordJobGetJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetJPAExecutor
-
- CoordJobGetReadyActionsJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load coordinator actions in READY state for a coordinator job.
- CoordJobGetReadyActionsJPAExecutor(String, String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetReadyActionsJPAExecutor
-
- CoordJobGetRunningActionsCountJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the number of running actions for a coordinator job.
- CoordJobGetRunningActionsCountJPAExecutor(String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobGetRunningActionsCountJPAExecutor
-
- CoordJobInfoGetJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the CoordinatorInfo and return it.
- CoordJobInfoGetJPAExecutor(Map<String, List<String>>, int, int) - Constructor for class org.apache.oozie.executor.jpa.CoordJobInfoGetJPAExecutor
-
- CoordJobInsertJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Persist the CoordinatorJob bean.
- CoordJobInsertJPAExecutor(CoordinatorJobBean) - Constructor for class org.apache.oozie.executor.jpa.CoordJobInsertJPAExecutor
-
- CoordJobQueryExecutor - Class in org.apache.oozie.executor.jpa
-
Query Executor that provides API to run query for Coordinator Job
- CoordJobQueryExecutor.CoordJobQuery - Enum in org.apache.oozie.executor.jpa
-
- CoordJobsCountNotForPurgeFromParentIdJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Count the number of Coordinator children of a parent bundle that are not ready to be purged
- CoordJobsCountNotForPurgeFromParentIdJPAExecutor(long, String) - Constructor for class org.apache.oozie.executor.jpa.CoordJobsCountNotForPurgeFromParentIdJPAExecutor
-
- CoordJobsDeleteJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Delete Coord job, its list of actions and return the number of actions that were deleted.
- CoordJobsDeleteJPAExecutor(Collection<String>) - Constructor for class org.apache.oozie.executor.jpa.CoordJobsDeleteJPAExecutor
-
Initialize the JPAExecutor using the delete list of CoordinatorJobBeans
- CoordJobsDeleteJPAExecutor() - Constructor for class org.apache.oozie.executor.jpa.CoordJobsDeleteJPAExecutor
-
- CoordJobsGetForPurgeJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the list of completed CoordinatorJob for purge ready.
- CoordJobsGetForPurgeJPAExecutor(long, int) - Constructor for class org.apache.oozie.executor.jpa.CoordJobsGetForPurgeJPAExecutor
-
- CoordJobsGetForPurgeJPAExecutor(long, int, int) - Constructor for class org.apache.oozie.executor.jpa.CoordJobsGetForPurgeJPAExecutor
-
- CoordJobsGetFromParentIdJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Load the list of CoordinatorJob with the passed in parentId
- CoordJobsGetFromParentIdJPAExecutor(String, int) - Constructor for class org.apache.oozie.executor.jpa.CoordJobsGetFromParentIdJPAExecutor
-
- CoordJobsGetFromParentIdJPAExecutor(String, int, int) - Constructor for class org.apache.oozie.executor.jpa.CoordJobsGetFromParentIdJPAExecutor
-
- CoordJobsGetPausedJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Get a list of paused bundle Jobs;
- CoordJobsGetPausedJPAExecutor(int) - Constructor for class org.apache.oozie.executor.jpa.CoordJobsGetPausedJPAExecutor
-
- CoordJobsGetPendingJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Get a list of Coordinator Jobs that are in pending.
- CoordJobsGetPendingJPAExecutor(int) - Constructor for class org.apache.oozie.executor.jpa.CoordJobsGetPendingJPAExecutor
-
- CoordJobsGetUnpausedJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Get a list of unpaused Coordinator Jobs;
- CoordJobsGetUnpausedJPAExecutor(int) - Constructor for class org.apache.oozie.executor.jpa.CoordJobsGetUnpausedJPAExecutor
-
- CoordJobsToBeMaterializedJPAExecutor - Class in org.apache.oozie.executor.jpa
-
JPA command to get coordinator jobs which are qualify for Materialization.
- CoordJobsToBeMaterializedJPAExecutor(Date, int) - Constructor for class org.apache.oozie.executor.jpa.CoordJobsToBeMaterializedJPAExecutor
-
- CoordJobsXCommand - Class in org.apache.oozie.command.coord
-
The command to get a job info for a list of coordinator jobs by given filters.
- CoordJobsXCommand(Map<String, List<String>>, int, int) - Constructor for class org.apache.oozie.command.coord.CoordJobsXCommand
-
- CoordJobXCommand - Class in org.apache.oozie.command.coord
-
Command for loading a coordinator job information
- CoordJobXCommand(String) - Constructor for class org.apache.oozie.command.coord.CoordJobXCommand
-
Constructor for loading a coordinator job information
- CoordJobXCommand(String, Map<Pair<String, CoordinatorEngine.FILTER_COMPARATORS>, List<Object>>, int, int, boolean) - Constructor for class org.apache.oozie.command.coord.CoordJobXCommand
-
Constructor for loading a coordinator job information
- CoordJobXCommand(String, boolean) - Constructor for class org.apache.oozie.command.coord.CoordJobXCommand
-
Constructor for loading a coordinator job information
- CoordKillXCommand - Class in org.apache.oozie.command.coord
-
- CoordKillXCommand(String) - Constructor for class org.apache.oozie.command.coord.CoordKillXCommand
-
- CoordMaterializeTransitionXCommand - Class in org.apache.oozie.command.coord
-
Materialize actions for specified start and end time for coordinator job.
- CoordMaterializeTransitionXCommand(String, int) - Constructor for class org.apache.oozie.command.coord.CoordMaterializeTransitionXCommand
-
- CoordMaterializeTransitionXCommand(CoordinatorJobBean, int, Date, Date) - Constructor for class org.apache.oozie.command.coord.CoordMaterializeTransitionXCommand
-
- CoordMaterializeTriggerService - Class in org.apache.oozie.service
-
The coordinator Materialization Lookup trigger service schedule lookup trigger command for every interval (default is
5 minutes ).
- CoordMaterializeTriggerService() - Constructor for class org.apache.oozie.service.CoordMaterializeTriggerService
-
- coordName - Variable in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- CoordOldInputDependency - Class in org.apache.oozie.coord.input.dependency
-
Old approach where dependencies are stored as String.
- CoordOldInputDependency(String) - Constructor for class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- CoordOldInputDependency() - Constructor for class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- CoordPauseXCommand - Class in org.apache.oozie.command.coord
-
- CoordPauseXCommand(CoordinatorJobBean) - Constructor for class org.apache.oozie.command.coord.CoordPauseXCommand
-
- CoordPullInputDependency - Class in org.apache.oozie.coord.input.dependency
-
- CoordPullInputDependency() - Constructor for class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- CoordPushDependencyCheckXCommand - Class in org.apache.oozie.command.coord
-
- CoordPushDependencyCheckXCommand(String) - Constructor for class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
- CoordPushDependencyCheckXCommand(String, boolean) - Constructor for class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
- CoordPushDependencyCheckXCommand(String, boolean, boolean) - Constructor for class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
- CoordPushDependencyCheckXCommand(String, String) - Constructor for class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
- CoordPushInputDependency - Class in org.apache.oozie.coord.input.dependency
-
- CoordPushInputDependency() - Constructor for class org.apache.oozie.coord.input.dependency.CoordPushInputDependency
-
- CoordRerunXCommand - Class in org.apache.oozie.command.coord
-
Rerun coordinator actions by a list of dates or ids.
- CoordRerunXCommand(String, String, String, boolean, boolean, boolean, Configuration) - Constructor for class org.apache.oozie.command.coord.CoordRerunXCommand
-
- CoordResumeXCommand - Class in org.apache.oozie.command.coord
-
Resume coordinator job and actions.
- CoordResumeXCommand(String) - Constructor for class org.apache.oozie.command.coord.CoordResumeXCommand
-
- coordSeletStr - Static variable in class org.apache.oozie.store.StoreStatusFilter
-
- CoordSLAAlertsDisableXCommand - Class in org.apache.oozie.command.coord
-
- CoordSLAAlertsDisableXCommand(String, String, String) - Constructor for class org.apache.oozie.command.coord.CoordSLAAlertsDisableXCommand
-
- CoordSLAAlertsEnableXCommand - Class in org.apache.oozie.command.coord
-
- CoordSLAAlertsEnableXCommand(String, String, String) - Constructor for class org.apache.oozie.command.coord.CoordSLAAlertsEnableXCommand
-
- CoordSLAAlertsXCommand - Class in org.apache.oozie.command.coord
-
- CoordSLAAlertsXCommand(String, String, String, String, String) - Constructor for class org.apache.oozie.command.coord.CoordSLAAlertsXCommand
-
- CoordSLAChangeXCommand - Class in org.apache.oozie.command.coord
-
- CoordSLAChangeXCommand(String, String, String, Map<String, String>) - Constructor for class org.apache.oozie.command.coord.CoordSLAChangeXCommand
-
- CoordStatusTransitXCommand - Class in org.apache.oozie.command.coord
-
CoordStatusTransitXCommand update coord job's status according to its child actions' status.
- CoordStatusTransitXCommand(String) - Constructor for class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- CoordSubmitXCommand - Class in org.apache.oozie.command.coord
-
This class provides the functionalities to resolve a coordinator job XML and write the job information into a DB
table.
- CoordSubmitXCommand(Configuration) - Constructor for class org.apache.oozie.command.coord.CoordSubmitXCommand
-
Constructor to create the Coordinator Submit Command.
- CoordSubmitXCommand(Configuration, String, String) - Constructor for class org.apache.oozie.command.coord.CoordSubmitXCommand
-
Constructor to create the Coordinator Submit Command by bundle job.
- CoordSubmitXCommand(boolean, Configuration) - Constructor for class org.apache.oozie.command.coord.CoordSubmitXCommand
-
Constructor to create the Coordinator Submit Command.
- CoordSuspendXCommand - Class in org.apache.oozie.command.coord
-
Suspend coordinator job and actions.
- CoordSuspendXCommand(String) - Constructor for class org.apache.oozie.command.coord.CoordSuspendXCommand
-
- CoordUnpauseXCommand - Class in org.apache.oozie.command.coord
-
- CoordUnpauseXCommand(CoordinatorJobBean) - Constructor for class org.apache.oozie.command.coord.CoordUnpauseXCommand
-
- CoordUnResolvedInputDependency - Class in org.apache.oozie.coord.input.dependency
-
- CoordUnResolvedInputDependency(List<String>) - Constructor for class org.apache.oozie.coord.input.dependency.CoordUnResolvedInputDependency
-
- CoordUnResolvedInputDependency() - Constructor for class org.apache.oozie.coord.input.dependency.CoordUnResolvedInputDependency
-
- CoordUpdateXCommand - Class in org.apache.oozie.command.coord
-
This class provides the functionalities to update coordinator job XML and properties.
- CoordUpdateXCommand(boolean, Configuration, String) - Constructor for class org.apache.oozie.command.coord.CoordUpdateXCommand
-
- CoordUpdateXCommand(boolean, Configuration, String, boolean) - Constructor for class org.apache.oozie.command.coord.CoordUpdateXCommand
-
- CoordUtils - Class in org.apache.oozie.coord
-
- CoordUtils() - Constructor for class org.apache.oozie.coord.CoordUtils
-
- CoordWfActionInfoXCommand - Class in org.apache.oozie.command.coord
-
- CoordWfActionInfoXCommand(String, String) - Constructor for class org.apache.oozie.command.coord.CoordWfActionInfoXCommand
-
- CoordWfActionInfoXCommand(String, String, int, int) - Constructor for class org.apache.oozie.command.coord.CoordWfActionInfoXCommand
-
- copy(Configuration, Configuration) - Static method in class org.apache.oozie.util.XConfiguration
-
Copy configuration key/value pairs from one configuration to another if a property exists in the target, it gets
replaced.
- copyCharStream(Reader, Writer) - Static method in class org.apache.oozie.util.IOUtils
-
Copies an char input stream into an char output stream.
- copyStream(InputStream, OutputStream) - Static method in class org.apache.oozie.util.IOUtils
-
Copies an inputstream into an output stream.
- COULD_NOT_END - Static variable in class org.apache.oozie.command.wf.ActionEndXCommand
-
- COULD_NOT_START - Static variable in class org.apache.oozie.command.coord.CoordActionStartXCommand
-
- COULD_NOT_START - Static variable in class org.apache.oozie.command.wf.ActionStartXCommand
-
- count - Variable in class org.apache.oozie.util.TimestampedMessageParser
-
- Counter() - Constructor for class org.apache.oozie.util.Instrumentation.Counter
-
Deprecated.
- create() - Method in class org.apache.oozie.service.DBLiteWorkflowStoreService
-
- create(S) - Method in class org.apache.oozie.service.DBLiteWorkflowStoreService
-
- create() - Method in class org.apache.oozie.service.SLAStoreService
-
Return a SLA store instance with a fresh transaction.
- create(S) - Method in class org.apache.oozie.service.SLAStoreService
-
Return a SLA store instance with an existing transaction.
- create() - Method in class org.apache.oozie.service.WorkflowStoreService
-
Return a workflow store instance with a fresh transaction.
- create(S) - Method in class org.apache.oozie.service.WorkflowStoreService
-
Return a workflow store instance with an existing transaction.
- createActionDefaultConf(String, String) - Method in class org.apache.oozie.service.HadoopAccessorService
-
Returns a Configuration containing any defaults for an action for a particular cluster.
- createArrayOf(String, Object[]) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- createBaseHadoopConf(ActionExecutor.Context, Element) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- createBaseHadoopConf(ActionExecutor.Context, Element, boolean) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- createBaseHadoopConf(ActionExecutor.Context, Element, boolean) - Method in class org.apache.oozie.action.hadoop.MapReduceActionExecutor
-
- createBlob() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- createCallBackUrl(String, String) - Method in class org.apache.oozie.service.CallbackService
-
Create a callback URL.
- createClob() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- createConfiguration(String) - Method in class org.apache.oozie.service.HadoopAccessorService
-
Creates a Configuration using the site configuration for the specified hostname:port.
- createConnection(Properties) - Method in interface org.apache.oozie.jms.ConnectionContext
-
Create connection using properties
- createConnection(Properties) - Method in class org.apache.oozie.jms.DefaultConnectionContext
-
- createConnectionContext(JMSConnectionInfo) - Method in class org.apache.oozie.service.JMSAccessorService
-
- createConnectionFactory() - Method in class org.apache.oozie.util.db.BasicDataSourceWrapper
-
Fixing a bug within BasicDataSource.createConnectionFactory()
for driverClassName
to have real effect.
- createConsumer(Session, String) - Method in interface org.apache.oozie.jms.ConnectionContext
-
Creates consumer using session and topic name
- createConsumer(Session, String, String) - Method in interface org.apache.oozie.jms.ConnectionContext
-
Creates consumer using session, topic name and selector
- createConsumer(Session, String) - Method in class org.apache.oozie.jms.DefaultConnectionContext
-
- createConsumer(Session, String, String) - Method in class org.apache.oozie.jms.DefaultConnectionContext
-
- createCoordinatorActionMessage(CoordinatorActionEvent) - Static method in class org.apache.oozie.event.messaging.MessageFactory
-
Constructs and returns the coordinator action message for coordinator
action event
- createCredentialsProvider(String) - Method in class org.apache.oozie.action.hadoop.CredentialsProviderFactory
-
Create Credential object
- createDataEvaluator(Element, Configuration, String) - Static method in class org.apache.oozie.coord.CoordELEvaluator
-
Create an Evaluator to resolve dataIns and dataOuts of an application instance (used in stage 3)
- createDataEvaluator(Element, Configuration, String, CoordInputDependency, CoordInputDependency) - Static method in class org.apache.oozie.coord.CoordELEvaluator
-
- createEarlyURIs(Element, String, StringBuilder, StringBuilder) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
The function create a list of URIs separated by "," using the instances
time stamp and URI-template
- createELEvaluatorForDataAndConf(Configuration, String, HashMap<String, String>) - Static method in class org.apache.oozie.coord.CoordELEvaluator
-
Create an Evaluator using conf and input/output-data (used for sla)
- createELEvaluatorForDataEcho(Configuration, String, HashMap<String, String>) - Static method in class org.apache.oozie.coord.CoordELEvaluator
-
- createELEvaluatorForGroup(Configuration, String) - Static method in class org.apache.oozie.command.bundle.BundleSubmitXCommand
-
- createELEvaluatorForGroup(Configuration, String) - Static method in class org.apache.oozie.command.wf.SignalXCommand
-
- createELEvaluatorForGroup(Configuration, String) - Static method in class org.apache.oozie.command.wf.SubmitXCommand
-
Create an EL evaluator for a given group.
- createELEvaluatorForGroup(Configuration, String) - Static method in class org.apache.oozie.coord.CoordELEvaluator
-
Create an evaluator to be used in resolving configuration vars and frequency constant/functions (used in Stage
1)
- createEvaluator(Configuration) - Method in class org.apache.oozie.command.bundle.BundleSubmitXCommand
-
Create ELEvaluator
- createEvaluator(String) - Method in class org.apache.oozie.service.ELService
-
Return an
ELEvaluator
pre-configured with the constants and functions for the specific group of
EL-functions and variables defined in the configuration.
- createExecutionPath(String) - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- createFileSystem(String, URI, Configuration) - Method in class org.apache.oozie.service.HadoopAccessorService
-
Return a FileSystem created with the provided user for the specified URI.
- createFullTransition(String, String) - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- createInstance(WorkflowApp, Configuration) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowLib
-
- createInstance(WorkflowApp, Configuration, String) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowLib
-
- createInstance(WorkflowApp, Configuration) - Method in interface org.apache.oozie.workflow.WorkflowLib
-
Create a workflow instance.
- createInstance(WorkflowApp, Configuration, String) - Method in interface org.apache.oozie.workflow.WorkflowLib
-
Create a workflow instance with the given wfId and actions endtime map.
- createInstancesELEvaluator(Element, SyncCoordAction, Configuration) - Static method in class org.apache.oozie.coord.CoordELEvaluator
-
Create a new Evaluator to resolve the EL functions and variables using action creation time (Phase 2)
- createInstancesELEvaluator(String, Element, SyncCoordAction, Configuration) - Static method in class org.apache.oozie.coord.CoordELEvaluator
-
- createInterpreter(JexlContext, boolean, boolean) - Method in class org.apache.oozie.coord.input.logic.OozieJexlEngine
-
- createJar(File, String, Class...) - Static method in class org.apache.oozie.util.IOUtils
-
Creates a JAR file with the specified classes.
- createJobClient(ActionExecutor.Context, Configuration) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
Create job client object
- createJobClient(String, JobConf) - Method in class org.apache.oozie.service.HadoopAccessorService
-
Return a JobClient created with the provided user/group.
- createJobClient(String, Configuration) - Method in class org.apache.oozie.service.HadoopAccessorService
-
Return a JobClient created with the provided user/group.
- createLazyEvaluator(Date, Date, Element, Configuration) - Static method in class org.apache.oozie.coord.CoordELEvaluator
-
Create a new evaluator for Lazy resolve (phase 3).
- createLocalResourceForConfigurationFile(String, String, Configuration, URI, Path) - Method in class org.apache.oozie.service.HadoopAccessorService
-
Creates a LocalResource
for the Configuration to localize it for a Yarn Container.
- createNClob() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- createPrefix() - Method in class org.apache.oozie.util.XLog.Info
-
Create the LogInfo
prefix using the current parameter values.
- createProducer(Session, String) - Method in interface org.apache.oozie.jms.ConnectionContext
-
Creates producer using session and topic
- createProducer(Session, String) - Method in class org.apache.oozie.jms.DefaultConnectionContext
-
- createProducerConnectionContext(JMSConnectionInfo) - Method in class org.apache.oozie.service.JMSAccessorService
-
- createPropertySet(String[], Set<String>) - Static method in class org.apache.oozie.util.PropertiesUtils
-
Create a set from an array
- createProtoActionConf(Configuration, boolean) - Method in class org.apache.oozie.service.WorkflowAppService
-
Create proto configuration.
- createPullInputDependencies(boolean) - Static method in class org.apache.oozie.coord.input.dependency.CoordInputDependencyFactory
-
Create the pull dependencies.
- createPushInputDependencies(boolean) - Static method in class org.apache.oozie.coord.input.dependency.CoordInputDependencyFactory
-
Create the push dependencies.
- createSequence() - Method in class org.apache.oozie.service.UUIDService
-
- createSequence() - Method in class org.apache.oozie.service.ZKUUIDService
-
Gets the unique id.
- createSession(int) - Method in interface org.apache.oozie.jms.ConnectionContext
-
Creates session using the specified session opts
- createSession(int) - Method in class org.apache.oozie.jms.DefaultConnectionContext
-
- createSLAEvaluator(Element, CoordinatorActionBean, Configuration) - Static method in class org.apache.oozie.coord.CoordELEvaluator
-
Create a SLA evaluator to be used during Materialization
- createSLAMessage(SLAEvent) - Static method in class org.apache.oozie.event.messaging.MessageFactory
-
Constructs and returns SLA notification message
- createSlaRegistrationEvent(Element, String, String, AppType, String, String, XLog, boolean, boolean) - Static method in class org.apache.oozie.sla.SLAOperations
-
- createSlaRegistrationEvent(Element, String, AppType, String, String, XLog) - Static method in class org.apache.oozie.sla.SLAOperations
-
- createSlaRegistrationEvent(Element, String, String, AppType, String, XLog) - Static method in class org.apache.oozie.sla.SLAOperations
-
- createSlaRegistrationEvent(Element, String, AppType, String, XLog) - Static method in class org.apache.oozie.sla.SLAOperations
-
- createSlaRegistrationEvent(Element, String, String, AppType, String, String, XLog, boolean) - Static method in class org.apache.oozie.sla.SLAOperations
-
- createSlaRegistrationEvent(Element, Store, String, SLAEvent.SlaAppType, String, String) - Static method in class org.apache.oozie.util.db.SLADbOperations
-
Deprecated.
- createSlaRegistrationEvent(Element, String, SLAEvent.SlaAppType, String, String, XLog) - Static method in class org.apache.oozie.util.db.SLADbOperations
-
Deprecated.
- createSlaRegistrationEvent(Element, String, SLAEvent.SlaAppType, String, String) - Static method in class org.apache.oozie.util.db.SLADbXOperations
-
Deprecated.
Create SLA registration event
- createSlaStatusEvent(String, SLAEvent.Status, SLAEvent.SlaAppType, String, XLog) - Static method in class org.apache.oozie.util.db.SLADbOperations
-
Deprecated.
- createSlaStatusEvent(String, SLAEvent.Status, SLAEvent.SlaAppType) - Static method in class org.apache.oozie.util.db.SLADbXOperations
-
Deprecated.
Create SLA status event
- createSQLXML() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- createStatement() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- createStatement(int, int) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- createStatement(int, int, int) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- createStatusEvent(String, String, SLAEvent.Status, SLAEvent.SlaAppType, XLog) - Static method in class org.apache.oozie.util.db.SLADbOperations
-
Deprecated.
- createStatusEvent(String, String, SLAEvent.Status, SLAEvent.SlaAppType) - Static method in class org.apache.oozie.util.db.SLADbXOperations
-
Deprecated.
Create SLA status event
- createStruct(String, Object[]) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- createSymlink(FileSystem, Path, Path, boolean) - Static method in class org.apache.oozie.util.FSUtils
-
- createThreadLocalSession(int) - Method in interface org.apache.oozie.jms.ConnectionContext
-
Creates a threadlocal session using session opts
- createThreadLocalSession(int) - Method in class org.apache.oozie.jms.DefaultConnectionContext
-
- createURIELEvaluator(String) - Static method in class org.apache.oozie.coord.CoordELEvaluator
-
Create a new Evaluator to resolve URI temple with time specific constant
- createWorkflowJobMessage(WorkflowJobEvent) - Static method in class org.apache.oozie.event.messaging.MessageFactory
-
Constructs and returns the workflow job message for workflow job event
- createYarnClient(ActionExecutor.Context, Configuration) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
Create yarn client object
- createYarnClient(String, Configuration) - Method in class org.apache.oozie.service.HadoopAccessorService
-
Return a YarnClient created with the provided user and configuration.
- CRED_KEY - Static variable in class org.apache.oozie.action.hadoop.CredentialsProviderFactory
-
- CredentialException - Exception in org.apache.oozie.action.hadoop
-
- CredentialException(XException) - Constructor for exception org.apache.oozie.action.hadoop.CredentialException
-
Create an credential exception from a XException.
- CredentialException(ErrorCode, Object...) - Constructor for exception org.apache.oozie.action.hadoop.CredentialException
-
Create a credential exception.
- CredentialsProperties - Class in org.apache.oozie.action.hadoop
-
- CredentialsProperties(String, String) - Constructor for class org.apache.oozie.action.hadoop.CredentialsProperties
-
- CredentialsProvider - Interface in org.apache.oozie.action.hadoop
-
- CredentialsProviderFactory - Class in org.apache.oozie.action.hadoop
-
- Cron() - Constructor for class org.apache.oozie.util.Instrumentation.Cron
-
Deprecated.
Creates new Cron, stopped, in zero.
- CURRENT - Static variable in class org.apache.oozie.command.coord.CoordCommandUtils
-
- currentSize - Variable in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
- GANGLIA - Static variable in class org.apache.oozie.util.MetricsInstrumentation
-
- GB - Static variable in class org.apache.oozie.util.ELConstantsFunctions
-
GigaByte constant (1024 MB).
- GB - Static variable in class org.apache.oozie.util.PropertiesUtils
-
- generateChildId(String, String) - Method in class org.apache.oozie.service.UUIDService
-
Create a child ID.
- generateConfigurationSection(List<String>, Namespace) - Method in class org.apache.oozie.command.wf.SubmitHttpXCommand
-
- generateCreateIndexScript(Schema.Index, Schema.DBType) - Static method in class org.apache.oozie.util.db.Schema
-
Generates the SQL statement for creating the Index
- generateCreateTableScript(Schema.Table, Schema.DBType) - Static method in class org.apache.oozie.store.OozieSchema
-
Generates the create table SQL Statement
- generateCreateTableScript(Schema.Table, Schema.DBType, List<Schema.Column>) - Static method in class org.apache.oozie.util.db.Schema
-
Generates the SQL Statement for creating the table
- generateDependencies() - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- generateDependencies() - Method in class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- generateDropTableScript(Schema.Table, Schema.DBType) - Static method in class org.apache.oozie.util.db.Schema
-
Generates the SQL Statement for droping the table
- generateEvent(CoordinatorActionBean, String, String, Date) - Static method in class org.apache.oozie.command.coord.CoordinatorXCommand
-
- generateEvent(CoordinatorJobBean) - Method in class org.apache.oozie.command.coord.CoordinatorXCommand
-
- generateEvent(WorkflowJobBean, String, String) - Static method in class org.apache.oozie.command.wf.WorkflowXCommand
-
- generateEvent(WorkflowJobBean) - Static method in class org.apache.oozie.command.wf.WorkflowXCommand
-
- generateEvent(WorkflowActionBean, String) - Method in class org.apache.oozie.command.wf.WorkflowXCommand
-
- generateEvents(CoordinatorJobBean, Date) - Method in class org.apache.oozie.command.TransitionXCommand
-
This will be used to generate Job Notification events on status changes
- generateId(UUIDService.ApplicationType) - Method in class org.apache.oozie.service.UUIDService
-
Create a unique ID.
- generateInsertVersionScript(String) - Static method in class org.apache.oozie.store.OozieSchema
-
Generates the Insert statement to insert the OOZIE_VERSION to table
- generateResourceRequests(int, int, int, Collection<String>) - Static method in class org.apache.oozie.action.hadoop.AMLocalityHelper
-
- generateSection(Configuration, Namespace) - Method in class org.apache.oozie.command.wf.SubmitHttpXCommand
-
- generateSection(Configuration, Namespace) - Method in class org.apache.oozie.command.wf.SubmitMRXCommand
-
- generateSection(Configuration, Namespace) - Method in class org.apache.oozie.command.wf.SubmitScriptLanguageXCommand
-
- generateSection(Configuration, Namespace) - Method in class org.apache.oozie.command.wf.SubmitSqoopXCommand
-
- get(String) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorUtil.OozieJexlParser
-
- get(BundleActionQueryExecutor.BundleActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.BundleActionQueryExecutor
-
- get(BundleJobQueryExecutor.BundleJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.BundleJobQueryExecutor
-
- get(CoordActionQueryExecutor.CoordActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.CoordActionQueryExecutor
-
- get(CoordJobQueryExecutor.CoordJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.CoordJobQueryExecutor
-
- get(E, Object...) - Method in class org.apache.oozie.executor.jpa.QueryExecutor
-
- get(SLARegistrationQueryExecutor.SLARegQuery, Object...) - Method in class org.apache.oozie.executor.jpa.SLARegistrationQueryExecutor
-
- get(SLASummaryQueryExecutor.SLASummaryQuery, Object...) - Method in class org.apache.oozie.executor.jpa.SLASummaryQueryExecutor
-
- get(WorkflowActionQueryExecutor.WorkflowActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.WorkflowActionQueryExecutor
-
- get(WorkflowJobQueryExecutor.WorkflowJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.WorkflowJobQueryExecutor
-
- get() - Method in class org.apache.oozie.service.AsyncXCommandExecutor.AccessibleRunnableScheduledFuture
-
- get(long, TimeUnit) - Method in class org.apache.oozie.service.AsyncXCommandExecutor.AccessibleRunnableScheduledFuture
-
- get(String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- get(Configuration, String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- get() - Method in class org.apache.oozie.service.InstrumentationService
-
Deprecated.
Return the instrumentation instance used by the service.
- get(Class<T>) - Method in class org.apache.oozie.service.Services
-
Return a service by its public interface.
- get() - Static method in class org.apache.oozie.service.Services
-
Return the services singleton.
- get() - Static method in class org.apache.oozie.servlet.HostnameFilter
-
Returns the requester hostname.
- get(String) - Method in interface org.apache.oozie.sla.SLACalculator
-
- get(String) - Method in class org.apache.oozie.sla.SLACalculatorMemory
-
- get(Class<T>, Schema.Column) - Method in class org.apache.oozie.util.db.SqlStatement.ResultSetReader
-
Get the Column data given its type and name
- get(String) - Method in class org.apache.oozie.util.XConfiguration
-
Get the value of the name
property, null
if
no such property exists.
- get(String, String) - Method in class org.apache.oozie.util.XConfiguration
-
Get the value of the name
property.
- get() - Static method in class org.apache.oozie.util.XLog.Info
-
Return the LogInfo
instance in context.
- get(String) - Method in class org.apache.oozie.workflow.lite.DBLiteWorkflowLib
-
Loads the Workflow instance with the given ID.
- get(String) - Method in interface org.apache.oozie.workflow.WorkflowLib
-
Load a workflow instance from storage.
- getAcl() - Method in class org.apache.oozie.BundleJobBean
-
- getAcl() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getAcl() - Method in class org.apache.oozie.WorkflowJobBean
-
- getAclForPath(String) - Method in class org.apache.oozie.util.ZKUtils.SASLOwnerACLProvider
-
- getAction() - Method in class org.apache.oozie.client.rest.BulkResponseImpl
-
- getAction() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
Returns the workflow action of the given action context
- getAction() - Method in class org.apache.oozie.CoordinatorWfActionBean
-
- getAction() - Static method in class org.apache.oozie.DagELFunctions
-
- getAction(String, boolean) - Method in class org.apache.oozie.store.WorkflowStore
-
Load the action data and returns a bean.
- getActionCredentialsProperties(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- getActionData(FileSystem, WorkflowAction, ActionExecutor.Context) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
Get the output data of an action.
- getActionData(FileSystem, Path, Configuration) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
Utility function to load the contents of action data sequence file into
memory object
- getActionDataSequenceFilePath(Path) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
Get the sequence file path storing all action data
- getActionDateListAsString() - Method in class org.apache.oozie.command.coord.CoordSLAAlertsXCommand
-
Gets the action and date list as string.
- getActionDir() - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
- getActionDir(String, WorkflowAction, String, boolean) - Method in class org.apache.oozie.action.ActionExecutor
-
Return the path that will be used to store action specific data.
- getActionDir() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- getActionDirPath(String, WorkflowAction, String, boolean) - Method in class org.apache.oozie.action.ActionExecutor
-
Return the path that will be used to store action specific data
- getActionId() - Method in class org.apache.oozie.coord.SyncCoordAction
-
- getActionID() - Method in class org.apache.oozie.dependency.hcat.WaitingAction
-
Get the action id
- getActionId(String) - Method in class org.apache.oozie.service.CallbackService
-
Return the action ID from a callback URL.
- getActionList() - Method in class org.apache.oozie.command.coord.CoordSLAAlertsXCommand
-
Gets the action list.
- getActionListForScopeAndDate(String, String, String) - Static method in class org.apache.oozie.coord.CoordUtils
-
- getActionNumber() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getActionNumber() - Method in class org.apache.oozie.CoordinatorWfActionBean
-
- getActions() - Method in class org.apache.oozie.command.bundle.BundleSLAAlertsXCommand
-
Gets the actions.
- getActions() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getActions() - Method in class org.apache.oozie.WorkflowJobBean
-
- getActionsForWorkflow(String, boolean) - Method in class org.apache.oozie.store.WorkflowStore
-
Loads all the actions for the given Workflow.
- getActionsIds(String, String) - Static method in class org.apache.oozie.coord.CoordUtils
-
- getActionSignal(WorkflowAction.Status) - Method in class org.apache.oozie.action.ActionExecutor
-
Convenience method that return the signal for an Action based on the action status.
- getActionsSubsetForWorkflow(String, int, int) - Method in class org.apache.oozie.store.WorkflowStore
-
Loads given number of actions for the given Workflow.
- getActionStatus(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.ssh.SshActionExecutor
-
Get action status.
- getActionStatus(String) - Method in class org.apache.oozie.CoordinatorEngine
-
Return the status for an Action ID
- getActionsToFail(WorkflowInstance) - Static method in class org.apache.oozie.service.WorkflowStoreService
-
Return the list of action IDs to fail.
- getActionsToKill(WorkflowInstance) - Static method in class org.apache.oozie.service.WorkflowStoreService
-
Return the list of action IDs to kill.
- getActionsToStart(WorkflowInstance) - Static method in class org.apache.oozie.service.WorkflowStoreService
-
Return the list of actions started by a signal in an instance.
- getActionVar(String, String) - Static method in class org.apache.oozie.DagELFunctions
-
- getActionXml() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getActionXmlBlob() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getActionYarnTag(Configuration, WorkflowJob, WorkflowAction) - Static method in class org.apache.oozie.action.ActionExecutor
-
Creating and forwarding the tag, It will be useful during repeat attempts of Launcher, to ensure only
one child job is running.
- getActionYarnTag(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- getActionYarnTag(Configuration, String, WorkflowAction) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
- getActualDuration() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getActualDuration() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getActualEnd() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getActualEnd() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getActualEndTimestamp() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getActualExternalId(WorkflowAction) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
Useful for overriding in actions that do subsequent job runs
such as the MapReduce Action, where the launcher job is not the
actual job that then gets monitored.
- getActualExternalId(WorkflowAction) - Method in class org.apache.oozie.action.hadoop.MapReduceActionExecutor
-
- getActualStart() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getActualStart() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getActualStartTimestamp() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getActualTime() - Method in class org.apache.oozie.coord.SyncCoordAction
-
- getAlertContact() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getAlertContact() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getAlertContact() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getAlertEvents() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getAlertEvents() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getAlertFrequency() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getAlertPercentage() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getAll() - Method in class org.apache.oozie.util.Instrumentation
-
Deprecated.
Return a map containing all variables, counters and timers.
- getAll() - Method in class org.apache.oozie.util.MetricsInstrumentation
-
- getAllExceptions(Throwable) - Method in class org.apache.oozie.util.db.DatabaseRetryPredicate
-
- getAllMetaData() - Method in class org.apache.oozie.util.ZKUtils
-
Returns a list of the metadata provided by all of the Oozie Servers.
- getAllVars() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- getAllVars() - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Return a map with all the variables in the context of the instance.
- getApp() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- getApp() - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Return the workflow application that defines the instance.
- getAppConfigurationEntry(String) - Method in class org.apache.oozie.util.JaasConfiguration
-
- getAppFileSystem() - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
- getAppFileSystem() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- getAppFileSystem(WorkflowJob) - Method in class org.apache.oozie.command.wf.WfEndXCommand
-
- getAppName(ActionExecutor.Context) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- getAppName() - Method in class org.apache.oozie.BundleJobBean
-
- getAppName() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getAppName() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getAppName() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getAppName() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getAppName() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getAppName() - Method in class org.apache.oozie.WorkflowJobBean
-
- getAppNamespace() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get app namespce
- getAppPath() - Method in class org.apache.oozie.BundleJobBean
-
- getAppPath() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getAppPath() - Method in class org.apache.oozie.WorkflowJobBean
-
- getAppType() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getAppType() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getAppType() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getAppType() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getAppType() - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- getAppTypes() - Method in class org.apache.oozie.service.EventHandlerService
-
- getAppTypeStr() - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- getAuthorityWithScheme(String) - Method in class org.apache.oozie.service.URIHandlerService
-
Get the URI with scheme://host:port removing the path
- getAutoCommit() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- getAvailableDependencies(String) - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- getAvailableDependencies(String) - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Gets the available dependencies.
- getAvailableDependencies(String) - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- getAvailableDependencies(String) - Method in class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- getAvailableDependencies() - Method in class org.apache.oozie.dependency.ActionDependency
-
- getAvailableDependenciesAsList() - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- getAvailableDependenciesAsList() - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Gets the available dependencies as list.
- getAvailableDependenciesAsList() - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- getAvailableDependencyURIs(String) - Method in class org.apache.oozie.dependency.hcat.EhcacheHCatDependencyCache
-
- getAvailableDependencyURIs(String) - Method in interface org.apache.oozie.dependency.hcat.HCatDependencyCache
-
Get a list of available dependency URIs for a actionID
- getAvailableDependencyURIs(String) - Method in class org.apache.oozie.dependency.hcat.SimpleHCatDependencyCache
-
- getAvailableDependencyURIs(String) - Method in class org.apache.oozie.service.PartitionDependencyManagerService
-
Get a list of available dependency URIs for a actionID
- getBaseEngine(String, String) - Method in class org.apache.oozie.servlet.V2JobServlet
-
Gets the base engine based on jobId.
- getBatchSize() - Method in interface org.apache.oozie.event.EventQueue
-
Get the batch size used during polling events
- getBatchSize() - Method in class org.apache.oozie.event.MemoryEventQueue
-
- getBean() - Method in class org.apache.oozie.executor.jpa.BatchQueryExecutor.UpdateEntry
-
- getBoolean(String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getBoolean(String, boolean) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getBoolean(Configuration, String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getBoolean(Schema.Column) - Method in class org.apache.oozie.util.db.SqlStatement.ResultSetReader
-
Get the Boolean Column
- getBooleanOrDefault(Configuration, String, boolean) - Static method in class org.apache.oozie.service.ConfigurationService
-
Get the boolean
value for name
from conf
, or the default Configuration
coming from
oozie-site.xml
, or defaultValue
, if no previous occurrences present.
- getBottomUpSuspendedState() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
Bottom up look for children to check the parent's status only if materialization is done and all actions are
non-pending.
- getBufferLen() - Method in class org.apache.oozie.util.XLogStreamer
-
- getBulkInfo(String, int, int) - Method in class org.apache.oozie.LocalOozieClientBundle
-
- getBulkJobs(String, int, int) - Method in class org.apache.oozie.BundleEngine
-
Get bulk job response
- getBundle() - Method in class org.apache.oozie.client.rest.BulkResponseImpl
-
- getBundleActionId() - Method in class org.apache.oozie.BundleActionBean
-
Get the Bundle Action Id.
- getBundleEngine(String) - Method in class org.apache.oozie.service.BundleEngineService
-
Return a Bundle engine.
- getBundleId() - Method in class org.apache.oozie.BundleActionBean
-
Get the BundleId
- getBundleId() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getBundleJob(String) - Method in class org.apache.oozie.BundleEngine
-
- getBundleJobId() - Method in class org.apache.oozie.event.CoordinatorActionEvent
-
- getBundleJobInfo(String) - Method in class org.apache.oozie.LocalOozieClientBundle
-
- getBundleJobs(String, int, int) - Method in class org.apache.oozie.BundleEngine
-
Get bundle jobs
- getBundleJobs() - Method in class org.apache.oozie.BundleJobInfo
-
Return the bundle jobs being returned.
- getBundleJobsInfo(String, int, int) - Method in class org.apache.oozie.LocalOozieClientBundle
-
- getBundleJSONObject(BundleJobInfo, String) - Static method in class org.apache.oozie.OozieJsonFactory
-
- getByteArray(Schema.Column) - Method in class org.apache.oozie.util.db.SqlStatement.ResultSetReader
-
Get the data for columns with blob type
- getBytes() - Method in class org.apache.oozie.BinaryBlob
-
Returns a decompressed byte array
- getCachedConf() - Method in class org.apache.oozie.service.HadoopAccessorService
-
- getCalendar(String, TimeZone) - Static method in class org.apache.oozie.util.DateUtils
-
Create a Calendar instance using the specified date and Time zone
- getCalendar(String) - Static method in class org.apache.oozie.util.DateUtils
-
Create a Calendar instance for UTC time zone using the specified date.
- getCalendarUnit() - Method in enum org.apache.oozie.coord.TimeUnit
-
- getCallableWrapper() - Method in class org.apache.oozie.service.AsyncXCommandExecutor.ScheduledXCallable
-
- getCallbackUrl(String) - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Create the callback URL for the action.
- getCallbackUrl(String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- getCaptureOutput(WorkflowAction) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- getCaptureOutput(WorkflowAction) - Method in class org.apache.oozie.action.hadoop.PigActionExecutor
-
- getCatalog() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- getCause(Object...) - Static method in class org.apache.oozie.util.XLog
-
Utility method that extracts the Throwable
, if present, from the parameters.
- getChildName(String) - Method in class org.apache.oozie.service.UUIDService
-
Return the child name from a child ID.
- getClass(Configuration, String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getClassByName(String) - Method in class org.apache.oozie.util.XConfiguration
-
This is a stop gap fix for HADOOP-4416.
- getClasses(String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getClasses(Configuration, String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getClassesForLauncher() - Method in class org.apache.oozie.dependency.FSURIHandler
-
- getClassesForLauncher() - Method in class org.apache.oozie.dependency.HCatURIHandler
-
- getClassesForLauncher() - Method in interface org.apache.oozie.dependency.URIHandler
-
Get list of classes to ship to launcher for LauncherURIHandler
- getClassesForLauncher() - Method in class org.apache.oozie.service.URIHandlerService
-
Return the classes to be shipped to the launcher
- getClassLoadingInfo() - Method in class org.apache.oozie.servlet.JVMInfo
-
- getClassNamebyType(String) - Static method in class org.apache.oozie.action.hadoop.DistcpActionExecutor
-
This function returns the Action classes names from the configuration
- getClient() - Static method in class org.apache.oozie.local.LocalOozie
-
Return a OozieClient
for LocalOozie.
- getClient(String) - Static method in class org.apache.oozie.local.LocalOozie
-
Return a OozieClient
for LocalOozie configured for a given user.
- getClient() - Method in class org.apache.oozie.util.ZKUtils
-
Returns the CuratorFramework
used for managing the ZooKeeper connection; it can be used by calling classes to perform
more direct operations on ZooKeeper.
- getClientBundle() - Static method in class org.apache.oozie.local.LocalOozie
-
The returned instance is configured with the user name of the JVM (the
value of the system property 'user.name').
- getClientBundle(String) - Static method in class org.apache.oozie.local.LocalOozie
-
The returned instance is configured with the user name of the JVM (the
value of the system property 'user.name').
- getClientCoord(String) - Static method in class org.apache.oozie.local.LocalOozie
-
Return a OozieClient
for LocalOozie
configured for a given user.
- getClientId() - Static method in class org.apache.oozie.util.db.SLADbOperations
-
Deprecated.
- getClientId() - Static method in class org.apache.oozie.util.db.SLADbXOperations
-
Deprecated.
Return client id
- getClientInfo(String) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- getClientInfo() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- getCommonLauncherClasses() - Static method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- getCompressionCodec() - Static method in class org.apache.oozie.compression.CodecFactory
-
Get output compression codec
- getConcurrency() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getConf() - Method in class org.apache.oozie.BundleJobBean
-
- getConf() - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
- getConf() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getConf() - Method in class org.apache.oozie.service.ConfigurationService
-
Return the services configuration.
- getConf() - Method in class org.apache.oozie.service.Services
-
- getConf() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- getConf() - Method in class org.apache.oozie.workflow.lite.NodeDef
-
- getConf() - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Return the configuration of the instance.
- getConf() - Method in class org.apache.oozie.WorkflowActionBean
-
- getConf() - Method in class org.apache.oozie.WorkflowJobBean
-
- getConfBlob() - Method in class org.apache.oozie.BundleJobBean
-
- getConfBlob() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getConfBlob() - Method in class org.apache.oozie.WorkflowActionBean
-
- getConfBlob() - Method in class org.apache.oozie.WorkflowJobBean
-
- getConfigDir() - Method in class org.apache.oozie.service.ConfigurationService
-
Return Oozie configuration directory.
- getConfiguration() - Method in class org.apache.oozie.dependency.URIHandler.Context
-
Get the Configuration to access the URI
- getConfiguration(String, FilterConfig) - Method in class org.apache.oozie.servlet.AuthFilter
-
Returns the configuration from Oozie configuration to be used by the authentication filter.
- getConfiguration() - Method in class org.apache.oozie.util.Instrumentation
-
Deprecated.
Return the current system configuration as a Map<String,String>.
- getConfigurationDirectory() - Static method in class org.apache.oozie.service.ConfigurationService
-
- getConnection() - Method in class org.apache.oozie.store.Store
-
- getConsoleUrl() - Method in class org.apache.oozie.BundleJobBean
-
- getConsoleUrl() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getConsoleUrl() - Method in class org.apache.oozie.CoordinatorJobBean
-
Return the coordinate application console URL.
- getConsoleUrl() - Method in class org.apache.oozie.WorkflowActionBean
-
- getConsoleUrl() - Method in class org.apache.oozie.WorkflowJobBean
-
Return the workflow job console URL.
- getConsumer() - Method in class org.apache.oozie.jms.MessageReceiver
-
Get the JMS message consumer object for this message receiver
- getContentType(HttpServletRequest) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Return the request content type, lowercase and without attributes.
- getContext(boolean, boolean) - Method in class org.apache.oozie.command.wf.ActionStartXCommand
-
Get action executor context
- getContext(boolean, boolean) - Method in class org.apache.oozie.command.wf.ForkedActionStartXCommand
-
- getContext(URI, Configuration, String, boolean) - Method in class org.apache.oozie.dependency.FSURIHandler
-
- getContext(URI, Configuration, String, boolean) - Method in class org.apache.oozie.dependency.HCatURIHandler
-
- getContext(URI, Configuration, String, boolean) - Method in interface org.apache.oozie.dependency.URIHandler
-
Get the Context which can be used to access URI of the same scheme and
host
- getContext() - Method in class org.apache.oozie.util.ELEvaluator
-
Return the context with the functions and variables of the EL evaluator.
- getContextMap() - Method in class org.apache.oozie.command.wf.ActionXCommand.ForkedActionExecutorContext
-
- getContextURL() - Method in class org.apache.oozie.test.EmbeddedServletContainer
-
Return the full URL (including protocol, host, port, context path, servlet path) for the context path.
- getCoordAction(String) - Method in class org.apache.oozie.CoordinatorEngine
-
- getCoordActionErrorCode() - Method in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
getting the error code of the coord action.
- getCoordActionErrorMsg() - Method in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
getting the error message of the coord action.
- getCoordActionIdsFromDateRange(String, String) - Static method in class org.apache.oozie.util.CoordActionsInDateRange
-
Get the coordinator actions for a given date range
- getCoordActionIdsFromDates(String, String) - Static method in class org.apache.oozie.util.CoordActionsInDateRange
-
Get the list of Coordinator action Ids for given date ranges
- getCoordActionInfo(String) - Method in class org.apache.oozie.LocalOozieClientCoord
-
Get the info of a coordinator action.
- getCoordActionMissingDependencies(String, String, String) - Method in class org.apache.oozie.CoordinatorEngine
-
Get coord action missing dependencies
- getCoordActionMissingDependencies(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- getCoordActionMissingDependencies(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- getCoordActions(String, String, String, boolean) - Static method in class org.apache.oozie.coord.CoordUtils
-
Get the list of actions for a given coordinator job
- getCoordActions() - Method in class org.apache.oozie.CoordinatorActionInfo
-
Return the coordiantor actions being returned.
- getCoordActionsFromDateRange(String, String, boolean) - Static method in class org.apache.oozie.util.CoordActionsInDateRange
-
Get the coordinator actions for a given date range
- getCoordActionsFromDates(String, String, boolean) - Static method in class org.apache.oozie.coord.CoordUtils
-
Get the list of actions for given date ranges
- getCoordActionsFromIds(String, String) - Static method in class org.apache.oozie.coord.CoordUtils
-
Get the list of actions for given id ranges
- getCoordActionsLastModifiedDate(String, String, String) - Static method in class org.apache.oozie.util.CoordActionsInDateRange
-
Gets the coordinator actions last modified date for range, if any action is running it return new date
- getCoordClient() - Static method in class org.apache.oozie.local.LocalOozie
-
Return a OozieClient
for LocalOozie.
- getCoordId() - Method in class org.apache.oozie.BundleActionBean
-
Get the coordinator Id.
- getCoordinator() - Method in class org.apache.oozie.client.rest.BulkResponseImpl
-
- getCoordinatorEngine(String) - Method in class org.apache.oozie.service.CoordinatorEngineService
-
Return a Coordinator engine.
- getCoordinatorJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
Get coord job info
- getCoordinatorJobLength(int, int) - Method in class org.apache.oozie.servlet.V1JobServlet
-
Given the requested length and the default length, determine how many coordinator jobs to return.
- getCoordinatorJobLength(int, int) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- getCoordinators() - Method in class org.apache.oozie.BundleJobBean
-
- getCoordInputCheckRequeueInterval() - Method in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
This function reads the value of re-queue interval for coordinator input
check command from the Oozie configuration provided by Configuration
Service.
- getCoordJob(String) - Method in class org.apache.oozie.BaseEngine
-
Return the info about a coord job.
- getCoordJob(String, String, int, int, boolean) - Method in class org.apache.oozie.BaseEngine
-
Return the info about a coord job with actions subset.
- getCoordJob(String) - Method in class org.apache.oozie.BundleEngine
-
- getCoordJob(String, String, int, int, boolean) - Method in class org.apache.oozie.BundleEngine
-
- getCoordJob(String) - Method in class org.apache.oozie.CoordinatorEngine
-
- getCoordJob(String, String, int, int, boolean) - Method in class org.apache.oozie.CoordinatorEngine
-
- getCoordJob(String) - Method in class org.apache.oozie.DagEngine
-
- getCoordJob(String, String, int, int, boolean) - Method in class org.apache.oozie.DagEngine
-
- getCoordJobId() - Method in class org.apache.oozie.event.WorkflowJobEvent
-
- getCoordJobInfo(String) - Method in class org.apache.oozie.LocalOozieClientCoord
-
Get the info of a coordinator job.
- getCoordJobInfo(String, String, int, int) - Method in class org.apache.oozie.LocalOozieClientCoord
-
Get the info of a coordinator job.
- getCoordJobInfo(String, String, int, int, String) - Method in class org.apache.oozie.LocalOozieClientCoord
-
- getCoordJobs() - Method in class org.apache.oozie.command.bundle.BundleSLAAlertsXCommand
-
Gets the coord jobs.
- getCoordJobs(String, int, int) - Method in class org.apache.oozie.CoordinatorEngine
-
- getCoordJobs() - Method in class org.apache.oozie.CoordinatorJobInfo
-
Return the coordiantor jobs being returned.
- getCoordJobsFromBundle(String, String) - Method in class org.apache.oozie.command.bundle.BundleSLAAlertsXCommand
-
Gets the coord jobs from bundle.
- getCoordJobsInfo(String, int, int) - Method in class org.apache.oozie.LocalOozieClientCoord
-
Return the info of the coordinator jobs that match the filter.
- getCoordJSONObject(CoordinatorJobInfo, String) - Static method in class org.apache.oozie.OozieJsonFactory
-
- getCoordName() - Method in class org.apache.oozie.BundleActionBean
-
Get the Coordinator name.
- getCoordPushCheckRequeueInterval() - Method in class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
Return the re-queue interval for coord push dependency check
- getCount(Schema.Table...) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Select count(*) Statement generator.
- getCounter() - Method in class org.apache.oozie.service.UUIDService
-
- getCounters() - Method in class org.apache.oozie.util.Instrumentation
-
Deprecated.
Return all the counters.
- getCounters() - Method in class org.apache.oozie.util.MetricsInstrumentation
-
- getCpuMonitorTime() - Method in class org.apache.oozie.servlet.JVMInfo
-
- getCpuTime() - Method in class org.apache.oozie.servlet.JVMInfo.JThreadInfo
-
- getCreatedConf() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getCreatedConfBlob() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getCreatedTime() - Method in class org.apache.oozie.BundleJobBean
-
- getCreatedTime() - Method in class org.apache.oozie.command.XCommand
-
Returns the creation time of the command.
- getCreatedTime() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getCreatedTime() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get created time
- getCreatedTime() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getCreatedTime() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getCreatedTime() - Method in interface org.apache.oozie.util.XCallable
-
Returns the createdTime of the callable in milliseconds
- getCreatedTime() - Method in class org.apache.oozie.WorkflowActionBean
-
- getCreatedTime() - Method in class org.apache.oozie.WorkflowJobBean
-
- getCreatedTimestamp() - Method in class org.apache.oozie.BundleJobBean
-
- getCreatedTimestamp() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getCreatedTimestamp() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get created timestamp
- getCreatedTimestamp() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getCreatedTimestamp() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getCreatedTimestamp() - Method in class org.apache.oozie.WorkflowActionBean
-
- getCreatedTimestamp() - Method in class org.apache.oozie.WorkflowJobBean
-
- getCred() - Method in class org.apache.oozie.workflow.lite.NodeDef
-
- getCred() - Method in class org.apache.oozie.WorkflowActionBean
-
- getCredProperties(ActionExecutor.Context, String) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- getCurrent() - Static method in class org.apache.oozie.util.ELEvaluator
-
If within the scope of a EL evaluation call, it gives access to the ELEvaluator instance performing the EL
evaluation.
- getCurrentInstance(Date, int[]) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Find the current instance based on effectiveTime (i.e Action_Creation_Time or Action_Start_Time)
- getDagEngine(String) - Method in class org.apache.oozie.service.DagEngineService
-
Return a Dag engine.
- getData() - Method in class org.apache.oozie.WorkflowActionBean
-
- getDataBlob() - Method in class org.apache.oozie.WorkflowActionBean
-
- getDataSets() - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult
-
- getDatasetTZ() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- getDatasetTZ(ELEvaluator) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- getDate(String) - Method in class org.apache.oozie.util.XLogUserFilterParam
-
Gets the date.
- getDateInput() - Method in class org.apache.oozie.executor.jpa.CoordJobsToBeMaterializedJPAExecutor
-
- getDates() - Method in class org.apache.oozie.command.bundle.BundleSLAAlertsXCommand
-
Gets the dates.
- getDbDataType(Schema.Column, Schema.DBType) - Static method in class org.apache.oozie.util.db.Schema
-
Returns the appropriate DB type for given column according to the DB Type
- getDebugMessage() - Method in class org.apache.oozie.util.XLogFilter
-
- getDeCompressionCodec(DataInputStream) - Static method in class org.apache.oozie.compression.CodecFactory
-
Get decompression codec after reading from stream
- getDefaultAcl() - Method in class org.apache.oozie.util.ZKUtils.SASLOwnerACLProvider
-
- getDefaultGroup(String) - Method in class org.apache.oozie.service.AuthorizationService
-
Return the default group to which the user belongs.
- getDefaultShareLibName(Element) - Method in class org.apache.oozie.action.hadoop.DistcpActionExecutor
-
Return the sharelib name for the action.
- getDefaultShareLibName(Element) - Method in class org.apache.oozie.action.hadoop.GitActionExecutor
-
- getDefaultShareLibName(Element) - Method in class org.apache.oozie.action.hadoop.Hive2ActionExecutor
-
Return the sharelib name for the action.
- getDefaultShareLibName(Element) - Method in class org.apache.oozie.action.hadoop.HiveActionExecutor
-
Return the sharelib name for the action.
- getDefaultShareLibName(Element) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
Returns the default sharelib name for the action if any.
- getDefaultShareLibName(Element) - Method in class org.apache.oozie.action.hadoop.MapReduceActionExecutor
-
Return the sharelib name for the action.
- getDefaultShareLibName(Element) - Method in class org.apache.oozie.action.hadoop.PigActionExecutor
-
Return the sharelib postfix for the action.
- getDefaultShareLibName(Element) - Method in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
Return the sharelib name for the action.
- getDefaultShareLibName(Element) - Method in class org.apache.oozie.action.hadoop.SqoopActionExecutor
-
Return the sharelib name for the action.
- getDefinition(String) - Method in class org.apache.oozie.BaseEngine
-
Return the a job definition.
- getDefinition(String) - Method in class org.apache.oozie.BundleEngine
-
- getDefinition(String) - Method in class org.apache.oozie.CoordinatorEngine
-
- getDefinition(String) - Method in class org.apache.oozie.DagEngine
-
Return the a job definition.
- getDefinition() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowApp
-
- getDefinition() - Method in interface org.apache.oozie.workflow.WorkflowApp
-
Return the original workflow definition (normally XML).
- getDelay(TimeUnit) - Method in class org.apache.oozie.service.AsyncXCommandExecutor.AccessibleRunnableScheduledFuture
-
- getDelay(TimeUnit) - Method in class org.apache.oozie.util.PriorityDelayQueue.QueueElement
-
Deprecated.
Return the delay of the element.
- getDependencies() - Method in class org.apache.oozie.coord.input.dependency.CoordUnResolvedInputDependency
-
- getDependenciesWithoutMagicNumber(String) - Static method in class org.apache.oozie.coord.input.dependency.CoordInputDependencyFactory
-
Gets the dependencies without magic number.
- getDependencyMap() - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- getDependencyType(URI) - Method in class org.apache.oozie.dependency.FSURIHandler
-
- getDependencyType(URI) - Method in class org.apache.oozie.dependency.HCatURIHandler
-
- getDependencyType(URI) - Method in interface org.apache.oozie.dependency.URIHandler
-
Get the dependency type of the URI.
- getDependencyURI() - Method in class org.apache.oozie.dependency.hcat.WaitingAction
-
Get the dependency uri
- getDevContact() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getDoneFlag(Element) - Static method in class org.apache.oozie.coord.CoordUtils
-
- getDoneFlag() - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- getDryRun(CoordinatorJobBean) - Method in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
Gets the dryrun output.
- getDryRun(CoordinatorJobBean) - Method in class org.apache.oozie.command.coord.CoordUpdateXCommand
-
- getDSTimeUnit(ELEvaluator) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- getEarlyRequeueMaxRetries() - Method in class org.apache.oozie.service.CallbackService
-
- getEffectiveNominalTime() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- getElement() - Method in class org.apache.oozie.util.PriorityDelayQueue.QueueElement
-
Deprecated.
Return the element from the wrapper.
- getELEvaluator() - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Return an ELEvaluator with the context injected.
- getELEvaluator() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- getEnd() - Method in class org.apache.oozie.util.Instrumentation.Cron
-
Deprecated.
Return the end time of the cron.
- getEndDate() - Method in class org.apache.oozie.util.XLogFilter
-
- getEndDate() - Method in class org.apache.oozie.util.XLogUserFilterParam
-
Gets the end date.
- getEndOfDuration() - Method in class org.apache.oozie.coord.SyncCoordAction
-
- getEndOfDuration() - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- getEndOffset() - Method in class org.apache.oozie.util.XLogUserFilterParam
-
- getEndTime() - Method in class org.apache.oozie.BundleJobBean
-
- getEndTime() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getEndTime() - Method in class org.apache.oozie.util.XLogUserFilterParam
-
- getEndTime() - Method in class org.apache.oozie.WorkflowActionBean
-
- getEndTime() - Method in class org.apache.oozie.WorkflowJobBean
-
- getEndTimestamp() - Method in class org.apache.oozie.BundleJobBean
-
- getEndTimestamp() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get end timestamp
- getEndTimestamp() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the action last check time
- getEndTimestamp() - Method in class org.apache.oozie.WorkflowJobBean
-
- getEntityKey() - Method in class org.apache.oozie.command.BulkJobsXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BulkBundleXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleCoordSubmitXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleJobChangeXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleJobResumeXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleJobSuspendXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleJobsXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleJobXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleKillXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundlePauseXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleRerunXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleStartXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleStatusTransitXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleStatusUpdateXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleSubmitXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.bundle.BundleUnpauseXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.BulkCoordXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionCheckXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionInfoXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionMissingDependenciesXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionReadyXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionsIgnoreXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionsKillXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionSkipXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionStartXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionTimeOutXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionUpdatePushMissingDependency
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordActionUpdateXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordChangeXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordJobsXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordJobXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordKillXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordMaterializeTransitionXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordPauseXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordRerunXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordResumeXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordSuspendXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordUnpauseXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordUpdateXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.CoordWfActionInfoXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.coord.SLAEventsXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.NotificationXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.PurgeXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.SchemaCheckXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.sla.SLAJobEventXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.sla.SLAJobHistoryXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.SLAAlertsXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.ActionCheckXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.ActionEndXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.ActionKillXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.ActionStartXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.BulkWorkflowXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.CompletedActionXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.DefinitionXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.ExternalIdXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.ForkedActionStartXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.JobsXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.JobXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.KillXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.ReRunXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.ResumeXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.SignalXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.SubmitMRXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.SubmitScriptLanguageXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.SubmitSqoopXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.SubmitXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.SuspendXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.WfEndXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.WorkflowActionInfoXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.wf.WorkflowActionRetryInfoXCommand
-
- getEntityKey() - Method in class org.apache.oozie.command.XCommand
-
Return the entity key for the command.
- getEntityKey() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getEntityKey() - Method in interface org.apache.oozie.util.XCallable
-
Return the lock key of the callable
- getEntityManager() - Method in class org.apache.oozie.service.JPAService
-
Return an EntityManager.
- getEntityManager() - Method in class org.apache.oozie.service.StoreService
-
Return EntityManager
- getEntityManager() - Method in class org.apache.oozie.store.Store
-
Return EntityManager
- getEntries() - Static method in class org.apache.oozie.util.JaasConfiguration
-
Returns the entries map.
- getErrorBuffer() - Method in class org.apache.oozie.util.BufferDrainer
-
- getErrorCode() - Method in exception org.apache.oozie.action.ActionExecutorException
-
Return the error code of the exception.
- getErrorCode() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getErrorCode() - Method in class org.apache.oozie.event.CoordinatorActionEvent
-
- getErrorCode() - Method in class org.apache.oozie.event.WorkflowActionEvent
-
- getErrorCode() - Method in class org.apache.oozie.event.WorkflowJobEvent
-
- getErrorCode() - Method in exception org.apache.oozie.servlet.XServletException
-
Return the Oozie error code for the exception.
- getErrorCode() - Method in class org.apache.oozie.WorkflowActionBean
-
- getErrorCode() - Method in exception org.apache.oozie.XException
-
Return the error code of the exception.
- getErrorMessage() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getErrorMessage() - Method in class org.apache.oozie.event.CoordinatorActionEvent
-
- getErrorMessage() - Method in class org.apache.oozie.event.WorkflowActionEvent
-
- getErrorMessage() - Method in class org.apache.oozie.event.WorkflowJobEvent
-
- getErrorMessage() - Method in class org.apache.oozie.WorkflowActionBean
-
- getErrorType() - Method in exception org.apache.oozie.action.ActionExecutorException
-
Return the error type of the exception.
- getEvalResult(boolean, int, int, List<String>) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
- getEvalResult(AbstractCoordInputDependency, String, int) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
Gets evaluator Result
- getEvent_id() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getEventProcessed() - Method in class org.apache.oozie.sla.SLACalcStatus
-
Get which type of sla event has been processed needed when calculator
periodically loops to update all jobs' sla
- getEventProcessed() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getEventQueue() - Method in class org.apache.oozie.service.EventHandlerService
-
- getEventService() - Static method in class org.apache.oozie.command.XCommand
-
- getEventStatus() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getEventStatus() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getEventStatusString() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getEventType() - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- getExecution() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get execution
- getExecutionOrder() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getExecutionPath() - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- getExecutionPath() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the node execution path.
- getExecutionStats() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the action statistics info.
- getExecutor(String) - Method in class org.apache.oozie.service.ActionService
-
- getExecutorService() - Method in class org.apache.oozie.service.AsyncXCommandExecutor
-
- getExpectedDuration() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getExpectedDuration() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getExpectedDuration() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getExpectedEnd() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getExpectedEnd() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getExpectedEnd() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getExpectedEnd() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getExpectedEnd() - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- getExpectedEndTimestamp() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getExpectedEndTimestamp() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getExpectedEndTS() - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- getExpectedStart() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getExpectedStart() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getExpectedStart() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getExpectedStart() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getExpectedStart() - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- getExpectedStartTimestamp() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getExpectedStartTimestamp() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getExpectedStartTS() - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- getExternalChildIDs() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the external child IDs.
- getExternalChildIDsBlob() - Method in class org.apache.oozie.WorkflowActionBean
-
Get external ChildIds
- getExternalId() - Method in class org.apache.oozie.BundleJobBean
-
Return externalId
- getExternalId() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getExternalId() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getExternalId() - Method in class org.apache.oozie.WorkflowActionBean
-
- getExternalId() - Method in class org.apache.oozie.WorkflowJobBean
-
- getExternalStatus() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getExternalStatus(String) - Method in class org.apache.oozie.service.CallbackService
-
Return the action external status from a callback URL.
- getExternalStatus() - Method in class org.apache.oozie.WorkflowActionBean
-
- getFile() - Method in class org.apache.oozie.util.XLogStreamer.FileInfo
-
- getFileSystem() - Method in class org.apache.oozie.service.ShareLibService
-
Returns file system for shared libraries.
- getFilterParams() - Method in class org.apache.oozie.util.XLogFilter
-
- getFilterPattern() - Method in class org.apache.oozie.util.XLogFilter
-
- getFirst() - Method in class org.apache.oozie.util.Pair
-
- getFirstMissingDependency(CoordinatorActionBean) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
- getFirstMissingDependency() - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- getFirstMissingDependency() - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Gets the first missing dependency.
- getFirstMissingDependency() - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- getFloat(String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getFlushMode() - Method in class org.apache.oozie.store.Store
-
- getFormattedEndDate() - Method in class org.apache.oozie.util.XLogFilter
-
- getFormattedStartDate() - Method in class org.apache.oozie.util.XLogFilter
-
- getFrequency() - Method in class org.apache.oozie.coord.SyncCoordAction
-
- getFrequency() - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- getFrequency() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getFromRule() - Method in class org.apache.oozie.util.MappingRule
-
Gets the from rule
- getFuncType(String) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
- getGroup() - Method in class org.apache.oozie.BundleJobBean
-
Deprecated.
- getGroup() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getGroup() - Method in class org.apache.oozie.WorkflowJobBean
-
- getGroupName() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getGroups(String) - Method in class org.apache.oozie.service.GroupsService
-
Returns the list of groups a user belongs to.
- getHadoopConf(Configuration) - Static method in class org.apache.oozie.coord.CoordUtils
-
- getHadoopId() - Method in class org.apache.oozie.event.WorkflowActionEvent
-
- getHandlerClass() - Method in class org.apache.oozie.workflow.lite.NodeDef
-
- getHCatClient(Configuration, String, String) - Method in class org.apache.oozie.action.hadoop.HCatCredentialHelper
-
Getting the HCat client.
- getHCatConf() - Method in class org.apache.oozie.service.HCatAccessorService
-
- getHeaderBytes() - Static method in class org.apache.oozie.compression.CodecFactory
-
Get header bytes
- getHeapMemoryUsage() - Method in class org.apache.oozie.servlet.JVMInfo
-
- getHistorySet() - Method in class org.apache.oozie.sla.SLACalculatorMemory
-
- getHoldability() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- getHost() - Method in class org.apache.oozie.test.EmbeddedServletContainer
-
Return the hostname the servlet container is bound to.
- getHttpStatusCode() - Method in exception org.apache.oozie.servlet.XServletException
-
Return the HTTP error code to return to the client.
- getId() - Method in class org.apache.oozie.BundleJobBean
-
- getId() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getId() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getId() - Method in enum org.apache.oozie.service.SchemaService.SchemaName
-
- getId(String) - Method in class org.apache.oozie.service.UUIDService
-
Return the ID from a child ID.
- getId() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getId() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getId() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getId() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- getId() - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Return the ID of the instance.
- getId() - Method in class org.apache.oozie.WorkflowActionBean
-
- getId() - Method in class org.apache.oozie.WorkflowJobBean
-
- getIfExist(BundleActionQueryExecutor.BundleActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.BundleActionQueryExecutor
-
- getIfExist(BundleJobQueryExecutor.BundleJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.BundleJobQueryExecutor
-
- getIfExist(CoordActionQueryExecutor.CoordActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.CoordActionQueryExecutor
-
- getIfExist(CoordJobQueryExecutor.CoordJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.CoordJobQueryExecutor
-
- getIfExist(E, Object...) - Method in class org.apache.oozie.executor.jpa.QueryExecutor
-
- getIfExist(SLARegistrationQueryExecutor.SLARegQuery, Object...) - Method in class org.apache.oozie.executor.jpa.SLARegistrationQueryExecutor
-
- getIfExist(SLASummaryQueryExecutor.SLASummaryQuery, Object...) - Method in class org.apache.oozie.executor.jpa.SLASummaryQueryExecutor
-
- getIfExist(WorkflowActionQueryExecutor.WorkflowActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.WorkflowActionQueryExecutor
-
- getIfExist(WorkflowJobQueryExecutor.WorkflowJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.WorkflowJobQueryExecutor
-
- getIndexStatements() - Static method in enum org.apache.oozie.util.db.CompositeIndex
-
- getInitialDelay() - Method in class org.apache.oozie.util.PriorityDelayQueue.QueueElement
-
Deprecated.
Returns the original delay of the element.
- getInitInstance() - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- getInputBuffer() - Method in class org.apache.oozie.util.BufferDrainer
-
- getInputDataInstance() - Method in class org.apache.oozie.coord.input.dependency.CoordInputInstance
-
Gets the input data instance.
- getInputDependencies(String, SyncCoordAction) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorUtil
-
Get input dependencies.
- getInputLogic(String) - Static method in class org.apache.oozie.coord.CoordUtils
-
- getInputLogic(Element) - Static method in class org.apache.oozie.coord.CoordUtils
-
- getInstance() - Static method in class org.apache.oozie.action.hadoop.CredentialsProviderFactory
-
- getInstance() - Static method in class org.apache.oozie.executor.jpa.BatchQueryExecutor
-
- getInstance() - Static method in class org.apache.oozie.executor.jpa.BinaryBlobValueHandler
-
Singleton instance.
- getInstance() - Static method in class org.apache.oozie.executor.jpa.BundleActionQueryExecutor
-
- getInstance() - Static method in class org.apache.oozie.executor.jpa.BundleJobQueryExecutor
-
- getInstance() - Static method in class org.apache.oozie.executor.jpa.CoordActionQueryExecutor
-
- getInstance() - Static method in class org.apache.oozie.executor.jpa.CoordJobQueryExecutor
-
- getInstance() - Static method in class org.apache.oozie.executor.jpa.SLARegistrationQueryExecutor
-
- getInstance() - Static method in class org.apache.oozie.executor.jpa.SLASummaryQueryExecutor
-
- getInstance() - Static method in class org.apache.oozie.executor.jpa.StringBlobValueHandler
-
Singleton instance.
- getInstance() - Static method in class org.apache.oozie.executor.jpa.WorkflowActionQueryExecutor
-
- getInstance() - Static method in class org.apache.oozie.executor.jpa.WorkflowJobQueryExecutor
-
- getInstance() - Static method in class org.apache.oozie.util.JaasConfiguration
-
Return the singleton.
- getInstanceNumber(String, StringBuilder) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
parse a function like coord:latest(n)/future() and return the 'n'.
- getInstrumentation() - Method in class org.apache.oozie.command.XCommand
-
- getInt(String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getInt(String, int) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getInt(Configuration, String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getInterface() - Method in class org.apache.oozie.service.AbandonedCoordCheckerService
-
- getInterface() - Method in class org.apache.oozie.service.ActionCheckerService
-
Return the public interface for the action checker service.
- getInterface() - Method in class org.apache.oozie.service.ActionService
-
- getInterface() - Method in class org.apache.oozie.service.AuthorizationService
-
Return the public interface of the service.
- getInterface() - Method in class org.apache.oozie.service.BundleEngineService
-
Return the public interface of the Bundle engine service.
- getInterface() - Method in class org.apache.oozie.service.CallableQueueService
-
Return the public interface for command queue service.
- getInterface() - Method in class org.apache.oozie.service.CallbackService
-
Return the public interface of the Dag engine service.
- getInterface() - Method in class org.apache.oozie.service.ConfigurationService
-
Return the public interface for configuration service.
- getInterface() - Method in class org.apache.oozie.service.CoordinatorEngineService
-
Return the public interface of the Coordinator engine service.
- getInterface() - Method in class org.apache.oozie.service.CoordMaterializeTriggerService
-
- getInterface() - Method in class org.apache.oozie.service.DagEngineService
-
Return the public interface of the Dag engine service.
- getInterface() - Method in class org.apache.oozie.service.DagXLogInfoService
-
Return the public interface of the service.
- getInterface() - Method in class org.apache.oozie.service.ELService
-
Return the public interface for EL service.
- getInterface() - Method in class org.apache.oozie.service.EventHandlerService
-
- getInterface() - Method in class org.apache.oozie.service.GroupsService
-
Returns the service interface.
- getInterface() - Method in class org.apache.oozie.service.HadoopAccessorService
-
- getInterface() - Method in class org.apache.oozie.service.HCatAccessorService
-
- getInterface() - Method in class org.apache.oozie.service.InstrumentationService
-
Deprecated.
Return the public interface for instrumentation service.
- getInterface() - Method in class org.apache.oozie.service.JMSAccessorService
-
- getInterface() - Method in class org.apache.oozie.service.JMSTopicService
-
- getInterface() - Method in class org.apache.oozie.service.JobsConcurrencyService
-
Return the public interface for the jobs concurrency services
- getInterface() - Method in class org.apache.oozie.service.JPAService
-
Return the public interface of the service.
- getInterface() - Method in class org.apache.oozie.service.JvmPauseMonitorService
-
- getInterface() - Method in class org.apache.oozie.service.MemoryLocksService
-
Return the public interface for the memory locks services
- getInterface() - Method in class org.apache.oozie.service.PartitionDependencyManagerService
-
- getInterface() - Method in class org.apache.oozie.service.PauseTransitService
-
Return the public interface for the purge jobs service.
- getInterface() - Method in class org.apache.oozie.service.ProxyUserService
-
Returns the service interface.
- getInterface() - Method in class org.apache.oozie.service.PurgeService
-
Return the public interface for the purge jobs service.
- getInterface() - Method in class org.apache.oozie.service.RecoveryService
-
Return the public interface for the Recovery Service.
- getInterface() - Method in class org.apache.oozie.service.SchedulerService
-
Return the public interface for scheduler service.
- getInterface() - Method in class org.apache.oozie.service.SchemaCheckerService
-
- getInterface() - Method in class org.apache.oozie.service.SchemaService
-
Return the public interface of the service.
- getInterface() - Method in interface org.apache.oozie.service.Service
-
Return the public interface of the service.
- getInterface() - Method in class org.apache.oozie.service.ShareLibService
-
- getInterface() - Method in class org.apache.oozie.service.SLAStoreService
-
- getInterface() - Method in class org.apache.oozie.service.SparkConfigurationService
-
- getInterface() - Method in class org.apache.oozie.service.StatusTransitService
-
Return the public interface for the purge jobs service.
- getInterface() - Method in class org.apache.oozie.service.StoreService
-
Return the public interface of the service.
- getInterface() - Method in class org.apache.oozie.service.URIHandlerService
-
- getInterface() - Method in class org.apache.oozie.service.UserGroupInformationService
-
- getInterface() - Method in class org.apache.oozie.service.UUIDService
-
Return the public interface for UUID service.
- getInterface() - Method in class org.apache.oozie.service.WorkflowAppService
-
Return the public interface for workflow application service.
- getInterface() - Method in class org.apache.oozie.service.WorkflowSchemaService
-
Return the public interface of the service.
- getInterface() - Method in class org.apache.oozie.service.WorkflowStoreService
-
Return the public interface of the service.
- getInterface() - Method in class org.apache.oozie.service.XLogService
-
Return the public interface for log service.
- getInterface() - Method in class org.apache.oozie.service.XLogStreamingService
-
Return the public interface for log streaming service.
- getInterface() - Method in class org.apache.oozie.sla.service.SLAService
-
- getInterruptTypes() - Method in class org.apache.oozie.service.CallableQueueService
-
- getJavaSystemProperties() - Method in class org.apache.oozie.util.Instrumentation
-
Deprecated.
Return the JVM system properties.
- getJMSConnectionInfo(URI) - Method in class org.apache.oozie.service.HCatAccessorService
-
Given a publisher host:port return the connection details of JMS server that the publisher
publishes to
- getJMSConnectionInfo() - Method in class org.apache.oozie.service.JMSAccessorService.JMSRetryRunnable
-
- getJMSConnectionInfo(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0AdminServlet
-
- getJMSConnectionInfo(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1AdminServlet
-
- getJMSConnectionInfo(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2AdminServlet
-
- getJMSTopicName(String) - Method in class org.apache.oozie.BaseEngine
-
Return the jms topic name for the job.
- getJMSTopicName(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- getJMSTopicName(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- getJMSTopicName(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- getJNDIProperties() - Method in class org.apache.oozie.client.rest.JMSConnectionInfoBean
-
- getJNDIProperties() - Method in class org.apache.oozie.jms.JMSConnectionInfo
-
Get JNDI properties to establish a JMS connection
- getJNDIPropertiesString() - Method in class org.apache.oozie.jms.JMSConnectionInfo
-
Return JNDI properties string
- getJob(String) - Method in class org.apache.oozie.BaseEngine
-
Return the info about a wf job.
- getJob(String, int, int) - Method in class org.apache.oozie.BaseEngine
-
Return the info about a wf job with actions subset.
- getJob(String) - Method in class org.apache.oozie.BundleEngine
-
- getJob(String, int, int) - Method in class org.apache.oozie.BundleEngine
-
- getJob() - Method in class org.apache.oozie.command.bundle.BundleJobResumeXCommand
-
- getJob() - Method in class org.apache.oozie.command.bundle.BundleJobSuspendXCommand
-
- getJob() - Method in class org.apache.oozie.command.bundle.BundleKillXCommand
-
- getJob() - Method in class org.apache.oozie.command.bundle.BundlePauseXCommand
-
- getJob() - Method in class org.apache.oozie.command.bundle.BundleRerunXCommand
-
- getJob() - Method in class org.apache.oozie.command.bundle.BundleStartXCommand
-
- getJob() - Method in class org.apache.oozie.command.bundle.BundleSubmitXCommand
-
- getJob() - Method in class org.apache.oozie.command.bundle.BundleUnpauseXCommand
-
- getJob() - Method in class org.apache.oozie.command.coord.CoordKillXCommand
-
- getJob() - Method in class org.apache.oozie.command.coord.CoordPauseXCommand
-
- getJob() - Method in class org.apache.oozie.command.coord.CoordRerunXCommand
-
- getJob() - Method in class org.apache.oozie.command.coord.CoordResumeXCommand
-
- getJob() - Method in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- getJob() - Method in class org.apache.oozie.command.coord.CoordSuspendXCommand
-
- getJob() - Method in class org.apache.oozie.command.coord.CoordUnpauseXCommand
-
- getJob() - Method in class org.apache.oozie.command.TransitionXCommand
-
Get the Job for the command.
- getJob(String) - Method in class org.apache.oozie.CoordinatorEngine
-
- getJob(String, int, int) - Method in class org.apache.oozie.CoordinatorEngine
-
- getJob(String) - Method in class org.apache.oozie.DagEngine
-
Return the info about a job.
- getJob(String, int, int) - Method in class org.apache.oozie.DagEngine
-
Return the info about a job with actions subset.
- getJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- getJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- getJobConf() - Method in class org.apache.oozie.command.coord.CoordSLAAlertsXCommand
-
- getJobConsoleUrl(String) - Static method in class org.apache.oozie.command.wf.JobXCommand
-
- getJobData() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getJobData() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getJobData() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getJobDefinition(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- getJobDefinition(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- getJobId() - Method in class org.apache.oozie.command.SLAAlertsXCommand
-
- getJobId() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getJobId() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the job Id.
- getJobIdForExternalId(String) - Method in class org.apache.oozie.BaseEngine
-
Return the workflow Job ID for an external ID.
- getJobIdForExternalId(String) - Method in class org.apache.oozie.BundleEngine
-
- getJobIdForExternalId(String) - Method in class org.apache.oozie.CoordinatorEngine
-
- getJobIdForExternalId(String) - Method in class org.apache.oozie.DagEngine
-
Return the workflow Job ID for an external ID.
- getJobIdForExternalId(HttpServletRequest, String) - Method in class org.apache.oozie.servlet.V0JobsServlet
-
v0 service implementation to get a JSONObject representation of a job from its external ID
- getJobIdForExternalId(HttpServletRequest, String) - Method in class org.apache.oozie.servlet.V1JobsServlet
-
v1 service implementation to get a JSONObject representation of a job from its external ID
- getJobIdsForThisServer(List<String>) - Method in class org.apache.oozie.service.JobsConcurrencyService
-
Filter out any job ids that should not be processed by this server.
- getJobIdsForThisServer(List<String>) - Method in class org.apache.oozie.service.ZKJobsConcurrencyService
-
Filter out any job ids that should not be processed by this server.
- getJobInfo() - Method in class org.apache.oozie.action.hadoop.OozieJobInfo
-
Get the job info.
- getJobInfo(String) - Method in class org.apache.oozie.LocalOozieClient
-
Get the info of a workflow job.
- getJobInfo(String, int, int) - Method in class org.apache.oozie.LocalOozieClient
-
- getJobs(String, int, int) - Method in class org.apache.oozie.DagEngine
-
Return the info about a set of jobs.
- getJobs(HttpServletRequest) - Method in class org.apache.oozie.servlet.V0JobsServlet
-
v0 service implementation to get a list of workflows, with filtering or interested windows embedded in the
request object
- getJobs(HttpServletRequest) - Method in class org.apache.oozie.servlet.V1JobsServlet
-
v1 service implementation to get a list of workflows, coordinators, or bundles, with filtering or interested
windows embedded in the request object
- getJobsByParentId(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- getJobsByParentId(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- getJobsByParentId(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- getJobsInfo(String, int, int) - Method in class org.apache.oozie.LocalOozieClient
-
Return the info of the workflow jobs that match the filter.
- getJobsInfo(String) - Method in class org.apache.oozie.LocalOozieClient
-
Return the info of the workflow jobs that match the filter.
- getJobStatus(String) - Method in class org.apache.oozie.BaseEngine
-
Return the status for a Job ID
- getJobStatus(String) - Method in class org.apache.oozie.BundleEngine
-
Return the status for a Job ID
- getJobStatus() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getJobStatus() - Method in class org.apache.oozie.command.bundle.BundleStatusTransitXCommand
-
- getJobStatus() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- getJobStatus() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
Gets the job status.
- getJobStatus() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- getJobStatus(String) - Method in class org.apache.oozie.CoordinatorEngine
-
Return the status for a Job ID
- getJobStatus(String) - Method in class org.apache.oozie.DagEngine
-
Return the status for a Job ID
- getJobStatus(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- getJobStatus(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- getJobStatus(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- getJobStatus() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getJobStatus() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getJobStatus() - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- getJobStatusStr() - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- getJobXml() - Method in class org.apache.oozie.BundleJobBean
-
- getJobXml() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get job xml
- getJobXmlBlob() - Method in class org.apache.oozie.BundleJobBean
-
- getJobXmlBlob() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getKey() - Method in class org.apache.oozie.command.bundle.BundleCoordSubmitXCommand
-
- getKey() - Method in class org.apache.oozie.command.bundle.BundleKillXCommand
-
- getKey() - Method in class org.apache.oozie.command.bundle.BundleStartXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordActionCheckXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordActionReadyXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordActionSkipXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordActionStartXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordActionTimeOutXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordKillXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordMaterializeTransitionXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordResumeXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordSuspendXCommand
-
- getKey() - Method in class org.apache.oozie.command.coord.CoordUpdateXCommand
-
- getKey() - Method in class org.apache.oozie.command.SLAAlertsXCommand
-
- getKey() - Method in class org.apache.oozie.command.wf.ActionCheckXCommand
-
- getKey() - Method in class org.apache.oozie.command.wf.ActionEndXCommand
-
- getKey() - Method in class org.apache.oozie.command.wf.ActionKillXCommand
-
- getKey() - Method in class org.apache.oozie.command.wf.ActionStartXCommand
-
- getKey() - Method in class org.apache.oozie.command.wf.KillXCommand
-
- getKey() - Method in class org.apache.oozie.command.wf.ResumeXCommand
-
- getKey() - Method in class org.apache.oozie.command.wf.SignalXCommand
-
- getKey() - Method in class org.apache.oozie.command.wf.SuspendXCommand
-
- getKey() - Method in class org.apache.oozie.command.XCommand
-
Get command key
- getKey() - Method in interface org.apache.oozie.util.XCallable
-
Return the key of the callable
- getKickoffTime() - Method in class org.apache.oozie.BundleJobBean
-
- getKickoffTimestamp() - Method in class org.apache.oozie.BundleJobBean
-
- getLastActionNumber() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getLastActionTime() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getLastActionTimestamp() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get last action timestamp
- getLastCheckTime() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the action last check time
- getLastCheckTimestamp() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the action last check time
- getLastMessage() - Method in class org.apache.oozie.util.TimestampedMessageParser
-
Returns the message that was last parsed.
- getLastModifiedTime() - Method in class org.apache.oozie.BundleActionBean
-
Get Last modified time.
- getLastModifiedTime() - Method in class org.apache.oozie.BundleJobBean
-
Get last modified time
- getLastModifiedTime() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getLastModifiedTime() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get last modified time
- getLastModifiedTime() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getLastModifiedTime() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getLastModifiedTime() - Method in class org.apache.oozie.WorkflowJobBean
-
- getLastModifiedTimestamp() - Method in class org.apache.oozie.BundleActionBean
-
Get Last modified time.
- getLastModifiedTimestamp() - Method in class org.apache.oozie.BundleJobBean
-
- getLastModifiedTimestamp() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getLastModifiedTimestamp() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get last modified timestamp
- getLastModifiedTimestamp() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getLastModifiedTimestamp() - Method in class org.apache.oozie.WorkflowJobBean
-
- getLastSeqId() - Method in class org.apache.oozie.command.coord.SLAEventsXCommand
-
Get lastSeqId
- getLastTimestamp() - Method in class org.apache.oozie.util.TimestampedMessageParser
-
Returns the timestamp from the last message that was parsed.
- getLatestLibPath(Path, String) - Method in class org.apache.oozie.service.ShareLibService
-
Gets the Latest lib path.
- getLauncherClasses() - Method in class org.apache.oozie.action.hadoop.DistcpActionExecutor
-
- getLauncherClasses() - Method in class org.apache.oozie.action.hadoop.GitActionExecutor
-
- getLauncherClasses() - Method in class org.apache.oozie.action.hadoop.Hive2ActionExecutor
-
- getLauncherClasses() - Method in class org.apache.oozie.action.hadoop.HiveActionExecutor
-
- getLauncherClasses() - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- getLauncherClasses() - Method in class org.apache.oozie.action.hadoop.MapReduceActionExecutor
-
- getLauncherClasses() - Method in class org.apache.oozie.action.hadoop.PigActionExecutor
-
- getLauncherClasses() - Method in class org.apache.oozie.action.hadoop.ScriptLanguageActionExecutor
-
- getLauncherClasses() - Method in class org.apache.oozie.action.hadoop.ShellActionExecutor
-
- getLauncherClasses() - Method in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- getLauncherClasses() - Method in class org.apache.oozie.action.hadoop.SqoopActionExecutor
-
- getLauncherConfig() - Method in class org.apache.oozie.service.URIHandlerService
-
Return the configuration required to use LauncherURIHandler in the launcher
- getLauncherMain(Configuration, Element) - Method in class org.apache.oozie.action.hadoop.DistcpActionExecutor
-
- getLauncherMain(Configuration, Element) - Method in class org.apache.oozie.action.hadoop.GitActionExecutor
-
- getLauncherMain(Configuration, Element) - Method in class org.apache.oozie.action.hadoop.Hive2ActionExecutor
-
- getLauncherMain(Configuration, Element) - Method in class org.apache.oozie.action.hadoop.HiveActionExecutor
-
- getLauncherMain(Configuration, Element) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- getLauncherMain(Configuration, Element) - Method in class org.apache.oozie.action.hadoop.MapReduceActionExecutor
-
- getLauncherMain(Configuration, Element) - Method in class org.apache.oozie.action.hadoop.PigActionExecutor
-
- getLauncherMain(Configuration, Element) - Method in class org.apache.oozie.action.hadoop.ShellActionExecutor
-
- getLauncherMain(Configuration, Element) - Method in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- getLauncherMain(Configuration, Element) - Method in class org.apache.oozie.action.hadoop.SqoopActionExecutor
-
- getLauncherURIHandlerClass() - Method in class org.apache.oozie.dependency.FSURIHandler
-
- getLauncherURIHandlerClass() - Method in class org.apache.oozie.dependency.HCatURIHandler
-
- getLauncherURIHandlerClass() - Method in interface org.apache.oozie.dependency.URIHandler
-
Get the URIHandler that will be used to handle the supported schemes in launcher
- getLen() - Method in class org.apache.oozie.BulkResponseInfo
-
Return the number of the bulk entries being returned.
- getLen() - Method in class org.apache.oozie.BundleJobInfo
-
Return the number of the bundle being returned.
- getLen() - Method in class org.apache.oozie.CoordinatorJobInfo
-
Return the number of the workflows being returned.
- getLen() - Method in class org.apache.oozie.WorkflowsInfo
-
Return the number of the workflows being returned.
- getLength() - Method in enum org.apache.oozie.store.OozieSchema.OozieColumn
-
- getLength() - Method in interface org.apache.oozie.util.db.Schema.Column
-
Returns the length of the column
- getLimit() - Method in class org.apache.oozie.executor.jpa.CoordJobsToBeMaterializedJPAExecutor
-
- getLimit() - Method in class org.apache.oozie.util.XLogUserFilterParam
-
- getLine() - Method in class org.apache.oozie.util.LogLine
-
- getList(BundleActionQueryExecutor.BundleActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.BundleActionQueryExecutor
-
- getList(BundleJobQueryExecutor.BundleJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.BundleJobQueryExecutor
-
- getList(CoordActionQueryExecutor.CoordActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.CoordActionQueryExecutor
-
- getList(CoordJobQueryExecutor.CoordJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.CoordJobQueryExecutor
-
- getList(E, Object...) - Method in class org.apache.oozie.executor.jpa.QueryExecutor
-
- getList(SLARegistrationQueryExecutor.SLARegQuery, Object...) - Method in class org.apache.oozie.executor.jpa.SLARegistrationQueryExecutor
-
- getList(SLASummaryQueryExecutor.SLASummaryQuery, Object...) - Method in class org.apache.oozie.executor.jpa.SLASummaryQueryExecutor
-
- getList(WorkflowActionQueryExecutor.WorkflowActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.WorkflowActionQueryExecutor
-
- getList(WorkflowJobQueryExecutor.WorkflowJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.WorkflowJobQueryExecutor
-
- getListAsString(List<String>) - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- getListAsString(List<String>, String) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
- getListAsString(List<String>, String) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseThree
-
- getLocation() - Method in class org.apache.oozie.util.graph.WorkflowActionNode
-
- getLock(String, MemoryLocksService.Type, long) - Method in class org.apache.oozie.lock.MemoryLocks
-
Obtain a lock for a source.
- getLockMap() - Method in class org.apache.oozie.lock.MemoryLocks
-
- getLocks() - Method in class org.apache.oozie.service.ZKLocksService
-
- getLockTimeOut() - Method in class org.apache.oozie.command.sla.SLAJobEventXCommand
-
- getLockTimeOut() - Method in class org.apache.oozie.command.sla.SLAJobHistoryXCommand
-
- getLockTimeOut() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
- getLockTimeOut() - Method in class org.apache.oozie.command.XCommand
-
Return the time out when acquiring a lock.
- getLog() - Method in class org.apache.oozie.command.bundle.BundleRerunXCommand
-
- getLog() - Method in class org.apache.oozie.command.coord.CoordRerunXCommand
-
- getLog() - Method in class org.apache.oozie.command.XCommand
-
Get XLog log
- getLog(String) - Static method in class org.apache.oozie.util.XLog
-
Return the named logger.
- getLog(Class) - Static method in class org.apache.oozie.util.XLog
-
Return the named logger.
- getLogDisableMessage() - Method in class org.apache.oozie.util.XLogAuditStreamer
-
- getLogDisableMessage() - Method in class org.apache.oozie.util.XLogErrorStreamer
-
- getLogDisableMessage() - Method in class org.apache.oozie.util.XLogStreamer
-
- getLogFileName() - Method in class org.apache.oozie.service.XLogUtil
-
- getLogLevel() - Method in class org.apache.oozie.util.XLogUserFilterParam
-
Gets the log level.
- getLogLimit() - Method in class org.apache.oozie.util.XLogFilter
-
- getLogMask() - Method in enum org.apache.oozie.ErrorCode
-
Return the log mask (to which log the exception should be logged) of the error.
- getLogOverWS() - Method in class org.apache.oozie.service.XLogService
-
- getLogParts() - Method in class org.apache.oozie.util.LogLine
-
- getLogPath() - Method in class org.apache.oozie.service.XLogUtil
-
- getLogRotation() - Method in class org.apache.oozie.service.XLogUtil
-
- getLogToken() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the job log token.
- getLogToken() - Method in class org.apache.oozie.WorkflowJobBean
-
- getlogToken() - Method in class org.apache.oozie.WorkflowJobBean
-
- getLogType() - Method in class org.apache.oozie.util.XLogAuditStreamer
-
- getLogType() - Method in class org.apache.oozie.util.XLogErrorStreamer
-
- getLogType() - Method in class org.apache.oozie.util.XLogStreamer
-
- getLong(String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getLong(String, long) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getLong(Configuration, String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getLong(Configuration, String, long) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getLong(Schema.Column) - Method in class org.apache.oozie.util.db.SqlStatement.ResultSetReader
-
Get the Numeric data
- getLoopFlag(String) - Static method in class org.apache.oozie.workflow.lite.NodeHandler
-
- getMagicNumber() - Static method in class org.apache.oozie.coord.input.dependency.CoordInputDependencyFactory
-
Gets the magic number.
- getMaskedConfiguration() - Method in class org.apache.oozie.service.ConfigurationService
-
Return a configuration with all sensitive values masked.
- getMatchedPattern() - Method in class org.apache.oozie.util.LogLine
-
- getMatThrottling() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getMaxExternalStatsSize() - Static method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
Get the maximum allowed size of stats
- getMaxHistory() - Method in class org.apache.oozie.util.OozieRollingPolicy
-
- getMaxOutputData(Configuration) - Static method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- getMaxRetries() - Method in class org.apache.oozie.action.ActionExecutor
-
Return the maximum number of retries for the action executor.
- getMaxSize() - Method in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
Return the maximum queue size.
- getMaxWait(TimeUnit) - Method in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
Return the max wait time for elements before they are promoted to the next higher priority.
- getMemoryLocks() - Method in class org.apache.oozie.service.MemoryLocksService
-
- getMessageFormat() - Method in class org.apache.oozie.event.messaging.JSONMessageSerializer
-
- getMessageFormat() - Method in class org.apache.oozie.event.messaging.MessageSerializer
-
Get the message format for the serializer
- getMessageHandler() - Method in class org.apache.oozie.jms.MessageReceiver
-
Get the MessageHandler that will processSettings the message
- getMessageSerializer() - Static method in class org.apache.oozie.event.messaging.MessageFactory
-
Gets the configured serializer
- getMetaData() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- getMissingDependencies(String) - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- getMissingDependencies() - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- getMissingDependencies(CoordinatorActionBean) - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- getMissingDependencies() - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Gets the missing dependencies.
- getMissingDependencies(CoordinatorActionBean) - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Gets the missing dependencies.
- getMissingDependencies() - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- getMissingDependencies(CoordinatorActionBean) - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- getMissingDependencies() - Method in class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- getMissingDependencies(CoordinatorActionBean) - Method in class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- getMissingDependencies() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getMissingDependencies() - Method in class org.apache.oozie.dependency.ActionDependency
-
- getMissingDependenciesAsList() - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- getMissingDependenciesAsList() - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Gets the missing dependencies as list.
- getMissingDependenciesAsList() - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- getMissingDependenciesBlob() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getMissingDeps() - Method in class org.apache.oozie.event.CoordinatorActionEvent
-
- getModTime() - Method in class org.apache.oozie.util.XLogStreamer.FileInfo
-
- getMsgPrefix() - Method in class org.apache.oozie.util.XLog
-
Return the common prefix.
- getMsgType() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getMsgType() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getName() - Method in class org.apache.oozie.action.hadoop.CredentialsProperties
-
Get the name
- getName() - Method in class org.apache.oozie.command.XCommand
-
Return the command name.
- getName() - Method in class org.apache.oozie.coord.SyncCoordAction
-
- getName() - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- getName() - Method in class org.apache.oozie.executor.jpa.BulkJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleActionGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleActionInsertJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleActionsCountForJobGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleJobGetCoordinatorsJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleJobGetForUserJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleJobGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleJobInfoGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleJobInsertJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleJobsDeleteJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleJobsGetForPurgeJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleJobsGetNeedStartJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleJobsGetPausedJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleJobsGetRunningOrPendingJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.BundleJobsGetUnpausedJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionGetForCheckJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionGetForExternalIdJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionGetForInfoJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionGetForInputCheckJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionGetForStartJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionGetForTimeoutJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionInsertJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionRemoveJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionsActiveCountJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionsCountForJobIdJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionsDeleteJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionsGetFromCoordJobIdJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionsPendingFalseCountGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionsPendingFalseStatusCountGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordActionsRunningGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordinatorJobGetForUserAppnameJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordinatorJobGetForUserJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetActionByActionNumberJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetActionForNominalTimeJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetActionModifiedDateForRangeJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetActionRunningCountForRangeJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetActionsJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetActionsNotCompletedJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetActionsRunningJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetActionsStatusJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetActionsSubsetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetActionsSuspendedJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetReadyActionsJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobGetRunningActionsCountJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobInfoGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobInsertJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobsCountNotForPurgeFromParentIdJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobsDeleteJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobsGetForPurgeJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobsGetFromParentIdJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobsGetPausedJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobsGetPendingJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobsGetUnpausedJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.CoordJobsToBeMaterializedJPAExecutor
-
- getName() - Method in interface org.apache.oozie.executor.jpa.JPAExecutor
-
Return the name of the JPA executor.
- getName() - Method in class org.apache.oozie.executor.jpa.JsonBeanPersisterExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.sla.SLASummaryGetForFilterJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.sla.SLASummaryGetRecordsOnRestartJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.SLAEventInsertJPAExecutor
-
Deprecated.
- getName() - Method in class org.apache.oozie.executor.jpa.SLAEventsGetForFilterJPAExecutor
-
Deprecated.
- getName() - Method in class org.apache.oozie.executor.jpa.SLAEventsGetForSeqIdJPAExecutor
-
Deprecated.
- getName() - Method in class org.apache.oozie.executor.jpa.SLAEventsGetJPAExecutor
-
Deprecated.
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowActionDeleteJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowActionGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowActionInsertJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowActionRetryManualGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowActionsGetForJobJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowActionSubsetGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowIdGetForExternalIdJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowInfoWithActionsSubsetGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowJobDeleteJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowJobGetActionsJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowJobGetForUserJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowJobGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowJobInsertJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowJobsBasicInfoFromCoordParentIdJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowJobsBasicInfoFromWorkflowParentIdJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowJobsDeleteJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowJobsGetForPurgeJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowJobsGetFromCoordParentIdJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowJobsGetFromWorkflowParentIdJPAExecutor
-
- getName() - Method in class org.apache.oozie.executor.jpa.WorkflowsJobGetJPAExecutor
-
- getName() - Method in class org.apache.oozie.util.graph.WorkflowActionNode
-
- getName() - Method in interface org.apache.oozie.util.XCallable
-
Return the callable name.
- getName() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowApp
-
- getName() - Method in class org.apache.oozie.workflow.lite.NodeDef
-
- getName() - Method in interface org.apache.oozie.workflow.WorkflowApp
-
Return the name of teh workflow application.
- getName() - Method in class org.apache.oozie.WorkflowActionBean
-
- getNetworkTimeout() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- getNewStatementWithValues(Map<Object, Object>) - Method in class org.apache.oozie.util.db.SqlStatement
-
Replace the keys(newValues) which are place holders in the sql statements with the corresponding new values.
- getNextMaterializedTime() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getNextMaterializedTimestamp() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get next materialized timestamp
- getNextValidActionTimeForCronFrequency(Date, CoordinatorJobBean) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
Get the next action time after a given time
- getNode(String) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowApp
-
- getNodeDef(String) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
Get NodeDef from workflow instance
- getNodeDef() - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- getNodeDef(String) - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Get NodeDef from workflow instance
- getNodeDefDefaultVersion() - Static method in class org.apache.oozie.service.LiteWorkflowStoreService
-
Get NodeDef default version, _oozie_inst_v_0, _oozie_inst_v_1 or
_oozie_inst_v_2
- getNodeDefs() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowApp
-
- getNodeDefVersion() - Method in class org.apache.oozie.workflow.lite.NodeDef
-
- getNominalTime() - Method in class org.apache.oozie.coord.SyncCoordAction
-
- getNominalTime() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getNominalTime() - Method in class org.apache.oozie.event.CoordinatorActionEvent
-
- getNominalTime() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getNominalTime() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getNominalTime() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getNominalTimestamp() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getNominalTimestamp() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getNominalTimestamp() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getNonHeapMemoryUsage() - Method in class org.apache.oozie.servlet.JVMInfo
-
- getNotificationMsg() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getNotificationMsg() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getNotificationMsg() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getNullReason() - Method in class org.apache.oozie.CoordinatorWfActionBean
-
- getNumActions() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getOozieAuditLogName() - Method in class org.apache.oozie.service.XLogService
-
- getOozieAuditLogPath() - Method in class org.apache.oozie.service.XLogService
-
- getOozieAuditLogRotation() - Method in class org.apache.oozie.service.XLogService
-
- getOozieConf() - Method in class org.apache.oozie.action.ActionExecutor
-
Return Oozie configuration.
- getOozieEffectiveUrl() - Static method in class org.apache.oozie.util.ConfigUtils
-
Returns the HTTP or HTTPS URL for this Oozie server depending on which is actually configured
- getOozieErrorLogName() - Method in class org.apache.oozie.service.XLogService
-
- getOozieErrorLogPath() - Method in class org.apache.oozie.service.XLogService
-
- getOozieErrorLogRotation() - Method in class org.apache.oozie.service.XLogService
-
- getOozieHome() - Static method in class org.apache.oozie.service.Services
-
- getOozieInterpreter() - Method in class org.apache.oozie.coord.input.logic.OozieJexlEngine
-
- getOozieLogName() - Method in class org.apache.oozie.service.XLogService
-
- getOozieLogPath() - Method in class org.apache.oozie.service.XLogService
-
- getOozieLogRotation() - Method in class org.apache.oozie.service.XLogService
-
- getOozieProcessingTimeZone() - Static method in class org.apache.oozie.util.DateUtils
-
Returns Oozie processing timezone.
- getOozieRuntimeDir() - Method in class org.apache.oozie.action.ActionExecutor
-
Return the runtime directory of the Oozie instance.
- getOozieSystemId() - Method in class org.apache.oozie.action.ActionExecutor
-
Return the system ID, this ID is defined in Oozie configuration.
- getOozieTimeMask() - Static method in class org.apache.oozie.util.DateUtils
-
Returns Oozie processing datetime mask.
- getOozieURL(boolean) - Static method in class org.apache.oozie.util.ConfigUtils
-
Returns the HTTP or HTTPS URL for this Oozie server
(http://HOSTNAME:HTTP_PORT/oozie or https://HOSTNAME:HTTPS_PORT/oozie)
- getOozieURLs() - Method in class org.apache.oozie.servlet.BaseAdminServlet
-
- getOozieURLs() - Method in class org.apache.oozie.servlet.V0AdminServlet
-
- getOozieURLs() - Method in class org.apache.oozie.servlet.V1AdminServlet
-
- getOozieURLs() - Method in class org.apache.oozie.servlet.V2AdminServlet
-
- getOozieVersion() - Static method in class org.apache.oozie.store.OozieSchema
-
Gets the Oozie Schema Version
- getOptions() - Method in class org.apache.oozie.command.wf.SubmitHiveXCommand
-
- getOptions() - Method in class org.apache.oozie.command.wf.SubmitPigXCommand
-
- getOptions() - Method in class org.apache.oozie.command.wf.SubmitScriptLanguageXCommand
-
- getOptions() - Method in class org.apache.oozie.command.wf.SubmitSqoopXCommand
-
- getOrigJobXml() - Method in class org.apache.oozie.BundleJobBean
-
- getOrigJobXml() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get original job xml
- getOrigJobXmlBlob() - Method in class org.apache.oozie.BundleJobBean
-
- getOrigJobXmlBlob() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getOSEnv() - Method in class org.apache.oozie.util.Instrumentation
-
Deprecated.
Return the OS environment used to start Oozie.
- getOtherServerUrls() - Method in class org.apache.oozie.service.JobsConcurrencyService
-
Return a map of instance id to other Oozie servers URL in HA.
- getOtherServerUrls() - Method in class org.apache.oozie.service.ZKJobsConcurrencyService
-
Return a map of instance id to Oozie server URL of other servers.
- getOwn() - Method in class org.apache.oozie.util.Instrumentation.Cron
-
Deprecated.
Return the own time of the cron.
- getOwn() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Return the own accumulated computing time by the timer.
- getOwnAvg() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Returns the own average time.
- getOwnMax() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Returns the own maximum time.
- getOwnMin() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Returns the own minimum time.
- getOwnSquareSum() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Return the sum of the square own times.
- getOwnStdDev() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Returns the own time standard deviation.
- getParameter(String) - Method in class org.apache.oozie.util.XLog.Info
-
Returns the specified parameter.
- getParentClientId() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getParentExecutionPath(String) - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- getParentId() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getParentId() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getParentId() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getParentId() - Method in class org.apache.oozie.WorkflowJobBean
-
For a sub-workflow, return the Parent Workflow ID and for a top level workflow
return the Coordinator action id, if any.
- getParentSlaId() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getPassword(Configuration, String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getPassword(Configuration, String, String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getPassword(String, String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getPasswordAuthentication() - Method in class org.apache.oozie.action.email.EmailActionExecutor.JavaMailAuthenticator
-
- getPausedState() - Method in class org.apache.oozie.command.bundle.BundleStatusTransitXCommand
-
- getPausedState() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- getPausedState() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
Gets the job pause state.
- getPauseTime() - Method in class org.apache.oozie.BundleJobBean
-
- getPauseTime() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getPauseTimestamp() - Method in class org.apache.oozie.BundleJobBean
-
- getPauseTimestamp() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getPending() - Method in class org.apache.oozie.BundleActionBean
-
Get some actions are in progress for particular bundle action.
- getPending() - Method in class org.apache.oozie.BundleJobBean
-
- getPending() - Method in class org.apache.oozie.CoordinatorActionBean
-
Get some actions are in progress for particular bundle action.
- getPending() - Method in class org.apache.oozie.WorkflowActionBean
-
- getPendingActions(long) - Method in class org.apache.oozie.store.WorkflowStore
-
Load All the actions that are pending for more than given time.
- getPendingAge() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the pending age of the action.
- getPendingAgeTimestamp() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the action last check time
- getPort() - Method in class org.apache.oozie.test.EmbeddedServletContainer
-
Return the port number the servlet container is bound to.
- getPrefix() - Method in class org.apache.oozie.util.XLog.Info
-
- getPrevStatus() - Method in class org.apache.oozie.command.RerunTransitionXCommand
-
This method will return the previous status.
- getPriorities() - Method in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
Return number of priorities the queue supports.
- getPriority() - Method in class org.apache.oozie.command.XCommand
-
Return the priority of the command.
- getPriority() - Method in class org.apache.oozie.util.PriorityDelayQueue.QueueElement
-
Deprecated.
Return the priority of the element.
- getPriority() - Method in interface org.apache.oozie.util.XCallable
-
Return the priority of the callable.
- getProcessDefinition() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- getProcessInstance() - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- getPromotedLock() - Method in class org.apache.oozie.service.ZKUUIDService
-
- getProperties() - Method in class org.apache.oozie.action.hadoop.CredentialsProperties
-
Get the properties
- getProtoActionConf() - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Return a proto configuration for actions with auth properties already set.
- getProtoActionConf() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- getProtoActionConf() - Static method in class org.apache.oozie.DagELFunctions
-
- getProtoActionConf() - Method in class org.apache.oozie.WorkflowJobBean
-
- getProtoActionConfBlob() - Method in class org.apache.oozie.WorkflowJobBean
-
- getProxy(String) - Method in class org.apache.oozie.command.NotificationXCommand
-
- getProxyUser(String) - Method in class org.apache.oozie.service.UserGroupInformationService
-
- getProxyUser(HttpServletRequest) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Gets proxy user.
- getPullDependencies() - Method in class org.apache.oozie.coord.SyncCoordAction
-
- getPullInputDependencies(StringBlob) - Static method in class org.apache.oozie.coord.input.dependency.CoordInputDependencyFactory
-
Gets the pull input dependencies.
- getPullInputDependencies(String) - Static method in class org.apache.oozie.coord.input.dependency.CoordInputDependencyFactory
-
- getPullInputDependencies() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getPushDependencies() - Method in class org.apache.oozie.coord.SyncCoordAction
-
- getPushInputDependencies(StringBlob) - Static method in class org.apache.oozie.coord.input.dependency.CoordInputDependencyFactory
-
Gets the push input dependencies.
- getPushInputDependencies(String) - Static method in class org.apache.oozie.coord.input.dependency.CoordInputDependencyFactory
-
- getPushInputDependencies() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getPushMissingDependencies() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getPushMissingDependenciesBlob() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getQaContact() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getQuery() - Method in class org.apache.oozie.service.JPAService.QueryEntry
-
- getQueryName() - Method in class org.apache.oozie.executor.jpa.BatchQueryExecutor.UpdateEntry
-
- getQueryName() - Method in class org.apache.oozie.service.JPAService.QueryEntry
-
- getQueryParamString(Map<String, String[]>) - Static method in class org.apache.oozie.util.AuthUrlClient
-
- getQueueDump() - Method in class org.apache.oozie.service.AsyncXCommandExecutor
-
- getQueueDump() - Method in class org.apache.oozie.service.CallableQueueService
-
Get the list of strings of queue dump
- getQueueDump(JSONObject) - Method in class org.apache.oozie.servlet.BaseAdminServlet
-
- getQueueDump(JSONObject) - Method in class org.apache.oozie.servlet.V0AdminServlet
-
- getQueueDump(JSONObject) - Method in class org.apache.oozie.servlet.V1AdminServlet
-
Get a json array of queue dump and a json array of unique map dump
- getRawBlob() - Method in class org.apache.oozie.BinaryBlob
-
Returns a raw blob
- getRawBlob() - Method in class org.apache.oozie.StringBlob
-
Get raw blob
- getReaderAsString(Reader, int) - Static method in class org.apache.oozie.util.IOUtils
-
Return a reader as string.
- getReadLock(String, long) - Method in class org.apache.oozie.service.MemoryLocksService
-
Obtain a READ lock for a source.
- getReadLock(String, long) - Method in class org.apache.oozie.service.ZKLocksService
-
Obtain a READ lock for a source.
- getRecent() - Method in class org.apache.oozie.util.XLogUserFilterParam
-
- getRecoveryId() - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Get the Action Recovery ID.
- getRecoveryId(Configuration, Path, String) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
- getRecoveryId() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- getRecoveryPath(ActionExecutor.Context) - Method in class org.apache.oozie.action.hadoop.FsActionExecutor
-
- getRecoveryServiceInterval(Configuration) - Method in class org.apache.oozie.service.RecoveryService
-
- getRemoteFileName(ActionExecutor.Context, WorkflowAction, String, boolean, boolean) - Method in class org.apache.oozie.action.ssh.SshActionExecutor
-
Get remote host working location.
- getRequestParam() - Method in class org.apache.oozie.util.XLogStreamer
-
- getRequeueDelay() - Method in class org.apache.oozie.command.XCommand
-
Return the delay time for requeue
- getReruns(String) - Method in class org.apache.oozie.CoordinatorEngine
-
- getRerunTime() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getRerunTimestamp() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getResolvedList(String, StringBuilder, StringBuilder) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
Get resolved string from missDepList
- getResolvedList() - Method in class org.apache.oozie.coord.input.dependency.CoordUnResolvedInputDependency
-
- getResourceAsReader(String, int) - Static method in class org.apache.oozie.util.IOUtils
-
Return a classpath resource as a reader.
- getResourceAsStream(String, int) - Static method in class org.apache.oozie.util.IOUtils
-
Return a classpath resource as a stream.
- getResourceAsString(String, int) - Static method in class org.apache.oozie.util.IOUtils
-
Return a classpath resource as string.
- getResourceName(HttpServletRequest) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Return the resource name of the request.
- getResponses() - Method in class org.apache.oozie.BulkResponseInfo
-
Return the coordinator actions being returned.
- getRestrictParser() - Method in class org.apache.oozie.util.XConfiguration
-
- getRestrictSystemProperties() - Method in class org.apache.oozie.util.XConfiguration
-
- getResultFromPullPush(CoordinatorActionBean, String, int) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
- getRetries() - Method in class org.apache.oozie.WorkflowActionBean
-
- getRetryAndManualActions(String) - Method in class org.apache.oozie.store.WorkflowStore
-
Load All the actions that are START_RETRY or START_MANUAL or END_RETRY or END_MANUAL.
- getRetryInterval() - Method in class org.apache.oozie.action.ActionExecutor
-
Return the retry interval for the action executor in seconds.
- getRetryInterval() - Method in class org.apache.oozie.command.wf.ActionCheckXCommand
-
- getRetryKey(WorkflowActionBean, String) - Static method in class org.apache.oozie.util.JobUtils
-
- getRetryKey(String, int) - Static method in class org.apache.oozie.util.JobUtils
-
- getRetryPolicy() - Method in class org.apache.oozie.action.ActionExecutor
-
Return the retry policy for the action executor.
- getRetryPolicy() - Static method in class org.apache.oozie.util.ZKUtils
-
Returns retry policy
- getRootAttribute(String, String) - Static method in class org.apache.oozie.util.XmlUtils
-
//TODO move this to action registry method Return the value of an attribute from the root element of an XML
document.
- getRun() - Method in class org.apache.oozie.WorkflowJobBean
-
- getRunConf() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getRunConfBlob() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getRunningActions(long) - Method in class org.apache.oozie.store.WorkflowStore
-
Load All the actions that are running and were last checked after now - miminumCheckAgeSecs
- getRunningState() - Method in class org.apache.oozie.command.bundle.BundleStatusTransitXCommand
-
- getRunningState() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- getRunningState() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
Gets the job running state.
- getRuntimeDir() - Method in class org.apache.oozie.service.Services
-
Return the runtime directory of the Oozie instance.
- getSamplers() - Method in class org.apache.oozie.util.Instrumentation
-
Deprecated.
Return all the samplers.
- getSamplers() - Method in class org.apache.oozie.util.MetricsInstrumentation
-
- getSchedulableThreads(Configuration) - Method in class org.apache.oozie.service.SchedulerService
-
Return the number of threads configured with the Scheduler Service
- getScheduler() - Method in class org.apache.oozie.service.SchedulerService
-
Return the java.util.concurrent.ScheduledExecutorService instance used by the SchedulerService.
- getSchema(SchemaService.SchemaName) - Method in class org.apache.oozie.service.SchemaService
-
Return the schema for XML validation of application definitions.
- getSchema() - Method in class org.apache.oozie.service.WorkflowSchemaService
-
Return the schema for XML validation of application definitions.
- getSchema() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- getScriptName() - Method in class org.apache.oozie.action.hadoop.Hive2ActionExecutor
-
- getScriptName() - Method in class org.apache.oozie.action.hadoop.HiveActionExecutor
-
- getScriptName() - Method in class org.apache.oozie.action.hadoop.PigActionExecutor
-
- getScriptName() - Method in class org.apache.oozie.action.hadoop.ScriptLanguageActionExecutor
-
- getScriptParamters() - Method in class org.apache.oozie.command.wf.SubmitHiveXCommand
-
- getScriptParamters() - Method in class org.apache.oozie.command.wf.SubmitPigXCommand
-
- getScriptParamters() - Method in class org.apache.oozie.command.wf.SubmitScriptLanguageXCommand
-
- getSearchText() - Method in class org.apache.oozie.util.XLogUserFilterParam
-
Gets the search text.
- getSecond() - Method in class org.apache.oozie.util.Pair
-
- getSeContact() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getSectionNamespace() - Method in class org.apache.oozie.command.wf.SubmitHiveXCommand
-
- getSectionNamespace() - Method in class org.apache.oozie.command.wf.SubmitHttpXCommand
-
- getSectionNamespace() - Method in class org.apache.oozie.command.wf.SubmitMRXCommand
-
- getSectionNamespace() - Method in class org.apache.oozie.command.wf.SubmitScriptLanguageXCommand
-
- getSectionNamespace() - Method in class org.apache.oozie.command.wf.SubmitSqoopXCommand
-
- getSelectQuery(BundleActionQueryExecutor.BundleActionQuery, EntityManager, Object...) - Method in class org.apache.oozie.executor.jpa.BundleActionQueryExecutor
-
- getSelectQuery(BundleJobQueryExecutor.BundleJobQuery, EntityManager, Object...) - Method in class org.apache.oozie.executor.jpa.BundleJobQueryExecutor
-
- getSelectQuery(CoordActionQueryExecutor.CoordActionQuery, EntityManager, Object...) - Method in class org.apache.oozie.executor.jpa.CoordActionQueryExecutor
-
- getSelectQuery(CoordJobQueryExecutor.CoordJobQuery, EntityManager, Object...) - Method in class org.apache.oozie.executor.jpa.CoordJobQueryExecutor
-
- getSelectQuery(E, EntityManager, Object...) - Method in class org.apache.oozie.executor.jpa.QueryExecutor
-
- getSelectQuery(SLARegistrationQueryExecutor.SLARegQuery, EntityManager, Object...) - Method in class org.apache.oozie.executor.jpa.SLARegistrationQueryExecutor
-
- getSelectQuery(SLASummaryQueryExecutor.SLASummaryQuery, EntityManager, Object...) - Method in class org.apache.oozie.executor.jpa.SLASummaryQueryExecutor
-
- getSelectQuery(WorkflowActionQueryExecutor.WorkflowActionQuery, EntityManager, Object...) - Method in class org.apache.oozie.executor.jpa.WorkflowActionQueryExecutor
-
- getSelectQuery(WorkflowJobQueryExecutor.WorkflowJobQuery, EntityManager, Object...) - Method in class org.apache.oozie.executor.jpa.WorkflowJobQueryExecutor
-
- getSerializedObject(Object) - Method in class org.apache.oozie.event.messaging.JSONMessageSerializer
-
- getSerializedObject(Object) - Method in class org.apache.oozie.event.messaging.MessageSerializer
-
Get the serialized string from object
- getServerUrls() - Method in class org.apache.oozie.service.JobsConcurrencyService
-
Return a map of instance id to Oozie server URL.
- getServerUrls() - Method in class org.apache.oozie.service.ZKJobsConcurrencyService
-
Return a map of instance id to Oozie server URL.
- getServletURL(String) - Method in class org.apache.oozie.test.EmbeddedServletContainer
-
Return the full URL (including protocol, host, port, context path, servlet path) for a servlet path.
- getSession() - Method in class org.apache.oozie.jms.MessageReceiver
-
Get the JMS session for this message receiver
- getShareLib() - Method in class org.apache.oozie.service.ShareLibService
-
- getShareLibConf(String, Path) - Method in class org.apache.oozie.service.ShareLibService
-
- getShareLibConfigMap() - Method in class org.apache.oozie.service.ShareLibService
-
- getShareLibFilesForActionConf() - Method in class org.apache.oozie.action.hadoop.Hive2ActionExecutor
-
- getShareLibFilesForActionConf() - Method in class org.apache.oozie.action.hadoop.HiveActionExecutor
-
- getShareLibFilesForActionConf() - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- getShareLibFilesForActionConf() - Method in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- getShareLibJars(String) - Method in class org.apache.oozie.service.ShareLibService
-
Gets the action sharelib lib jars.
- getShareLibNames(ActionExecutor.Context, Element, Configuration) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
Return the sharelib names for the action.
- getSign() - Method in enum org.apache.oozie.CoordinatorEngine.FILTER_COMPARATORS
-
- getSignalValue() - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- getSignalValue() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the signal value for the action.
- getSingleValue(BundleActionQueryExecutor.BundleActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.BundleActionQueryExecutor
-
- getSingleValue(BundleJobQueryExecutor.BundleJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.BundleJobQueryExecutor
-
- getSingleValue(CoordActionQueryExecutor.CoordActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.CoordActionQueryExecutor
-
- getSingleValue(CoordJobQueryExecutor.CoordJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.CoordJobQueryExecutor
-
- getSingleValue(E, Object...) - Method in class org.apache.oozie.executor.jpa.QueryExecutor
-
- getSingleValue(SLARegistrationQueryExecutor.SLARegQuery, Object...) - Method in class org.apache.oozie.executor.jpa.SLARegistrationQueryExecutor
-
- getSingleValue(SLASummaryQueryExecutor.SLASummaryQuery, Object...) - Method in class org.apache.oozie.executor.jpa.SLASummaryQueryExecutor
-
- getSingleValue(WorkflowActionQueryExecutor.WorkflowActionQuery, Object...) - Method in class org.apache.oozie.executor.jpa.WorkflowActionQueryExecutor
-
- getSingleValue(WorkflowJobQueryExecutor.WorkflowJobQuery, Object...) - Method in class org.apache.oozie.executor.jpa.WorkflowJobQueryExecutor
-
- getSize() - Method in class org.apache.oozie.service.AsyncXCommandExecutor
-
- getSLACalculator() - Method in class org.apache.oozie.sla.service.SLAService
-
- getSLAConfig() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getSlaConfig() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getSLAConfigMap() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getSLAConfigMap() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getSLAElement(Element) - Static method in class org.apache.oozie.util.XmlUtils
-
- getSLAEventListNewerSeqLimited(long, int, long[]) - Method in class org.apache.oozie.store.SLAStore
-
Deprecated.
Get a list of SLA Events newer than a specific sequence with limit
clause.
- getSLAEventXCommand(SLACalcStatus) - Static method in class org.apache.oozie.sla.SLAXCommandFactory
-
Gets the SLAevent command.
- getSLAEventXCommand(SLACalcStatus, long) - Static method in class org.apache.oozie.sla.SLAXCommandFactory
-
Gets the SLA event x command.
- getSlaId() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getSLAJobHistoryXCommand(String) - Static method in class org.apache.oozie.sla.SLAXCommandFactory
-
Gets the SLA job history command.
- getSLARegistrationBean() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getSLAStatus() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getSLAStatus() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getSLAStatusString() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getSLASummaryBean() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getSlaXml() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getSlaXml() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get sla xml
- getSlaXml() - Method in class org.apache.oozie.WorkflowActionBean
-
- getSlaXml() - Method in class org.apache.oozie.WorkflowJobBean
-
- getSlaXmlBlob() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getSlaXmlBlob() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getSlaXmlBlob() - Method in class org.apache.oozie.WorkflowActionBean
-
- getSlaXmlBlob() - Method in class org.apache.oozie.WorkflowJobBean
-
- getSortBy(Map<String, List<String>>, String) - Static method in class org.apache.oozie.store.StoreStatusFilter
-
- getSparkConfig(String) - Method in class org.apache.oozie.service.SparkConfigurationService
-
- getStart() - Method in class org.apache.oozie.BulkResponseInfo
-
Return the offset of the bulk entries being returned.
- getStart() - Method in class org.apache.oozie.BundleJobInfo
-
Return the offset of the bundles being returned.
- getStart() - Method in class org.apache.oozie.CoordinatorJobInfo
-
Return the offset of the workflows being returned.
- getStart() - Method in class org.apache.oozie.util.Instrumentation.Cron
-
Deprecated.
Return the start time of the cron.
- getStart() - Method in class org.apache.oozie.WorkflowsInfo
-
Return the offset of the workflows being returned.
- getStartDate() - Method in class org.apache.oozie.util.XLogFilter
-
- getStartDate() - Method in class org.apache.oozie.util.XLogUserFilterParam
-
Gets the start date.
- getStartOffset() - Method in class org.apache.oozie.util.XLogUserFilterParam
-
- getStartTime() - Method in class org.apache.oozie.BundleJobBean
-
- getStartTime() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getStartTime() - Method in class org.apache.oozie.WorkflowActionBean
-
- getStartTime() - Method in class org.apache.oozie.WorkflowJobBean
-
- getstartTimestamp() - Method in class org.apache.oozie.BundleJobBean
-
- getStartTimestamp() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get start timestamp
- getStartTimestamp() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the action last check time
- getStartTimestamp() - Method in class org.apache.oozie.WorkflowJobBean
-
- getStats() - Method in class org.apache.oozie.WorkflowActionBean
-
- getStatsBlob() - Method in class org.apache.oozie.WorkflowActionBean
-
- getStatus() - Method in class org.apache.oozie.BundleActionBean
-
Get the Status of the Bundle Action
- getStatus() - Method in class org.apache.oozie.BundleJobBean
-
- getStatus() - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult
-
- getStatus() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getStatus() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getStatus() - Method in class org.apache.oozie.event.BundleJobEvent
-
- getStatus() - Method in class org.apache.oozie.event.CoordinatorActionEvent
-
- getStatus() - Method in class org.apache.oozie.event.CoordinatorJobEvent
-
- getStatus() - Method in class org.apache.oozie.event.WorkflowActionEvent
-
- getStatus() - Method in class org.apache.oozie.event.WorkflowJobEvent
-
- getStatus() - Method in class org.apache.oozie.util.graph.WorkflowActionNode
-
- getStatus(CoordinatorJobBean) - Static method in class org.apache.oozie.util.StatusUtils
-
This Function transforms the statuses based on the name space of the coordinator App
- getStatus() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- getStatus() - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Return the current status of the instance.
- getStatus() - Method in class org.apache.oozie.WorkflowActionBean
-
- getStatus() - Method in class org.apache.oozie.WorkflowJobBean
-
- getStatusForCoordActionInputCheck(CoordinatorJobBean) - Static method in class org.apache.oozie.util.StatusUtils
-
This function check if eligible to do action input check when running with backward support is true.
- getStatusForCoordRerun(CoordinatorJobBean, Job.Status) - Static method in class org.apache.oozie.util.StatusUtils
-
This function changes back the status for coordinator rerun if the job was SUCCEEDED or SUSPENDED when rerun
with backward support is true.
- getStatusIfBackwardSupportTrue(Job.Status) - Static method in class org.apache.oozie.util.StatusUtils
-
Get the status of coordinator job for Oozie versions (3.2 and before) when RUNNINGWITHERROR,
SUSPENDEDWITHERROR and PAUSEDWITHERROR are not supported
- getStatusStr() - Method in class org.apache.oozie.BundleActionBean
-
Get the Status of the Bundle Action
- getStatusStr() - Method in class org.apache.oozie.BundleJobBean
-
- getStatusStr() - Method in class org.apache.oozie.CoordinatorActionBean
-
Return the status in string
- getStatusStr() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get status
- getStatusStr() - Method in class org.apache.oozie.WorkflowActionBean
-
Get status
- getStatusStr() - Method in class org.apache.oozie.WorkflowJobBean
-
- getStatusTimestamp() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getStatusTimestamp() - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- getStatusTimestampTS() - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- getStore(Class<S>) - Method in class org.apache.oozie.service.StoreService
-
Return instance of store.
- getStore(Class<S>, T) - Method in class org.apache.oozie.service.StoreService
-
Return instance of store with an EntityManager pointing to an existing Store.
- getString() - Method in class org.apache.oozie.StringBlob
-
Get uncompressed string
- getString(Schema.Column) - Method in class org.apache.oozie.util.db.SqlStatement.ResultSetReader
-
Get a String Column
- getStrings(String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getStrings(Configuration, String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getSupportedSchemes() - Method in class org.apache.oozie.dependency.FSURIHandler
-
- getSupportedSchemes() - Method in class org.apache.oozie.dependency.HCatURIHandler
-
- getSupportedSchemes() - Method in interface org.apache.oozie.dependency.URIHandler
-
Get the list of uri schemes supported by this URIHandler
- getSupportedSchemes() - Method in class org.apache.oozie.service.HadoopAccessorService
-
- getSuspendedStatus() - Method in class org.apache.oozie.command.bundle.BundleStatusTransitXCommand
-
- getSuspendedStatus() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- getSuspendedStatus() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
Gets the suspended status.
- getSuspendedTime() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get suspended time
- getSuspendedTimestamp() - Method in class org.apache.oozie.BundleJobBean
-
- getSuspendedTimestamp() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get suspended timestamp
- getSymLinkTarget(FileSystem, Path) - Static method in class org.apache.oozie.util.FSUtils
-
- getSystemBundleEngine() - Method in class org.apache.oozie.service.BundleEngineService
-
Return a Bundle engine for a system user (no user, no group).
- getSystemCoordinatorEngine() - Method in class org.apache.oozie.service.CoordinatorEngineService
-
Return a Coordinator engine for a system user (no user, no group).
- getSystemDagEngine() - Method in class org.apache.oozie.service.DagEngineService
-
Return a Dag engine for a system user (no user, no group).
- getSystemId() - Method in class org.apache.oozie.service.Services
-
- getSystemLibJars(String) - Method in class org.apache.oozie.service.ShareLibService
-
Gets the launcher jars.
- getSystemLibPath() - Method in class org.apache.oozie.service.WorkflowAppService
-
Returns Oozie system libpath.
- getSystemMode() - Method in class org.apache.oozie.service.Services
-
Return active system mode.
- getTag(String) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
- getTagElement(Element, String) - Static method in class org.apache.oozie.sla.SLAOperations
-
- getTask() - Method in class org.apache.oozie.service.AsyncXCommandExecutor.AccessibleRunnableScheduledFuture
-
- getTemplate() - Method in enum org.apache.oozie.ErrorCode
-
Return the message (StringFormat) template for the error code.
- getTerminalStatus() - Method in class org.apache.oozie.command.bundle.BundleStatusTransitXCommand
-
- getTerminalStatus() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- getTerminalStatus() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
Gets the job terminal status.
- getThreadInfo() - Method in class org.apache.oozie.servlet.JVMInfo
-
- getThreadInfo() - Method in class org.apache.oozie.servlet.JVMInfo.JThreadInfo
-
- getThreads() - Method in class org.apache.oozie.servlet.JVMInfo
-
- getThreadSortOrder() - Method in class org.apache.oozie.servlet.JVMInfo
-
- getTicks() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Return the number of times a cron was added to the timer.
- getTimeout() - Method in class org.apache.oozie.BundleJobBean
-
- getTimeOut() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getTimeout() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getTimers() - Method in class org.apache.oozie.util.Instrumentation
-
Deprecated.
Return all the timers.
- getTimers() - Method in class org.apache.oozie.util.MetricsInstrumentation
-
- getTimestamp(Schema.Column) - Method in class org.apache.oozie.util.db.SqlStatement.ResultSetReader
-
Get the Timestamp Column
- getTimeUnit() - Method in class org.apache.oozie.BundleJobBean
-
- getTimeUnit() - Method in class org.apache.oozie.coord.SyncCoordAction
-
- getTimeUnit() - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- getTimeUnit() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getTimeUnitStr() - Method in class org.apache.oozie.BundleJobBean
-
- getTimeUnitStr() - Method in class org.apache.oozie.CoordinatorJobBean
-
Get time unit
- getTimeZone() - Method in class org.apache.oozie.coord.SyncCoordAction
-
- getTimeZone() - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- getTimeZone() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getTimeZone(String) - Static method in class org.apache.oozie.util.DateUtils
-
Returns the
TimeZone
for the given timezone ID.
- getTopic(WorkflowJobEvent) - Method in class org.apache.oozie.jms.JMSJobEventListener
-
- getTopic(CoordinatorActionEvent) - Method in class org.apache.oozie.jms.JMSJobEventListener
-
- getTopic(SLAEvent) - Method in class org.apache.oozie.jms.JMSSLAEventListener
-
- getTopic(String) - Method in class org.apache.oozie.service.JMSTopicService
-
Retrieve topic from Job id
- getTopic(AppType, String, String, String) - Method in class org.apache.oozie.service.JMSTopicService
-
Retrieve Topic
- getTopicPatternProperties() - Method in class org.apache.oozie.client.rest.JMSConnectionInfoBean
-
- getTopicPatternProperties() - Method in class org.apache.oozie.service.JMSTopicService
-
- getTopicPrefix() - Method in class org.apache.oozie.client.rest.JMSConnectionInfoBean
-
- getTopicPrefix() - Method in class org.apache.oozie.service.JMSTopicService
-
- getToRule() - Method in class org.apache.oozie.util.MappingRule
-
Gets the to rule
- getTotal() - Method in class org.apache.oozie.BulkResponseInfo
-
Return the total number of bulk entries.
- getTotal() - Method in class org.apache.oozie.BundleJobInfo
-
Return the total number of bundles.
- getTotal() - Method in class org.apache.oozie.CoordinatorJobInfo
-
Return the total number of workflows.
- getTotal() - Method in class org.apache.oozie.util.Instrumentation.Cron
-
Deprecated.
Return the total time of the cron.
- getTotal() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Return the total accumulated computing time by the timer.
- getTotal() - Method in class org.apache.oozie.WorkflowsInfo
-
Return the total number of workflows.
- getTotalAvg() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Returns the total average time.
- getTotalMax() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Returns the total maximum time.
- getTotalMin() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Returns the total minimum time.
- getTotalSquareSum() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Return the sum of the square total times.
- getTotalStdDev() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Returns the total time standard deviation.
- getTrackerUri() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getTrackerUri() - Method in class org.apache.oozie.WorkflowActionBean
-
- getTransactionIsolation() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- getTransientVar(String) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- getTransientVar(String) - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- getTransientVar(String) - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Return a transient variable from the context of the instance.
- getTransition(String) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- getTransition(String) - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Return the transition a node did.
- getTransition() - Method in class org.apache.oozie.WorkflowActionBean
-
- getTransitions() - Method in class org.apache.oozie.workflow.lite.NodeDef
-
- getTrimmedEncodedPath(String) - Static method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- getTrimmedStrings(String) - Method in class org.apache.oozie.util.XConfiguration
-
Get the comma delimited values of the name property as an array of trimmed Strings.
- getTruncatedMessage() - Method in class org.apache.oozie.util.XLogFilter
-
- getType() - Method in class org.apache.oozie.action.ActionExecutor
-
Return the action executor type.
- getType() - Method in class org.apache.oozie.action.hadoop.CredentialsProperties
-
Get the type
- getType() - Method in class org.apache.oozie.command.XCommand
-
Return the callable type.
- getType() - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- getType() - Method in class org.apache.oozie.CoordinatorActionBean
-
- getType() - Method in enum org.apache.oozie.service.UUIDService.ApplicationType
-
- getType() - Method in enum org.apache.oozie.store.OozieSchema.OozieColumn
-
- getType() - Method in interface org.apache.oozie.util.db.Schema.Column
-
Returns the datatype of the column
- getType() - Method in class org.apache.oozie.util.graph.WorkflowActionNode
-
- getType() - Method in interface org.apache.oozie.util.XCallable
-
Return the callable type.
- getType() - Method in class org.apache.oozie.WorkflowActionBean
-
- getTypeMap() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- getUniqueDump() - Method in class org.apache.oozie.service.CallableQueueService
-
Get the list of strings of uniqueness map dump
- getUnResolvedDependency(String) - Method in class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- getUnResolvedList() - Method in class org.apache.oozie.coord.input.dependency.CoordUnResolvedInputDependency
-
- getUnresolvedMissingDependencies() - Method in class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- getUpdateQuery(BundleActionQueryExecutor.BundleActionQuery, BundleActionBean, EntityManager) - Method in class org.apache.oozie.executor.jpa.BundleActionQueryExecutor
-
- getUpdateQuery(BundleJobQueryExecutor.BundleJobQuery, BundleJobBean, EntityManager) - Method in class org.apache.oozie.executor.jpa.BundleJobQueryExecutor
-
- getUpdateQuery(CoordActionQueryExecutor.CoordActionQuery, CoordinatorActionBean, EntityManager) - Method in class org.apache.oozie.executor.jpa.CoordActionQueryExecutor
-
- getUpdateQuery(CoordJobQueryExecutor.CoordJobQuery, CoordinatorJobBean, EntityManager) - Method in class org.apache.oozie.executor.jpa.CoordJobQueryExecutor
-
- getUpdateQuery(E, T, EntityManager) - Method in class org.apache.oozie.executor.jpa.QueryExecutor
-
- getUpdateQuery(SLARegistrationQueryExecutor.SLARegQuery, SLARegistrationBean, EntityManager) - Method in class org.apache.oozie.executor.jpa.SLARegistrationQueryExecutor
-
- getUpdateQuery(SLASummaryQueryExecutor.SLASummaryQuery, SLASummaryBean, EntityManager) - Method in class org.apache.oozie.executor.jpa.SLASummaryQueryExecutor
-
- getUpdateQuery(WorkflowActionQueryExecutor.WorkflowActionQuery, WorkflowActionBean, EntityManager) - Method in class org.apache.oozie.executor.jpa.WorkflowActionQueryExecutor
-
- getUpdateQuery(WorkflowJobQueryExecutor.WorkflowJobQuery, WorkflowJobBean, EntityManager) - Method in class org.apache.oozie.executor.jpa.WorkflowJobQueryExecutor
-
- getUpstreamApps() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getUpstreamApps() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getUpstreamApps() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getURIHandler(String) - Method in class org.apache.oozie.service.URIHandlerService
-
- getURIHandler(URI) - Method in class org.apache.oozie.service.URIHandlerService
-
- getURIHandler(URI, boolean) - Method in class org.apache.oozie.service.URIHandlerService
-
- getUriTemplate() - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- getUriTemplate() - Method in class org.apache.oozie.dependency.ActionDependency
-
- getURIWithDoneFlag(String, String) - Method in class org.apache.oozie.dependency.FSURIHandler
-
- getURIWithDoneFlag(String, String) - Method in class org.apache.oozie.dependency.HCatURIHandler
-
- getURIWithDoneFlag(String, String) - Method in interface org.apache.oozie.dependency.URIHandler
-
Get the URI based on the done flag
- getURIWithoutDoneFlag(String, String) - Method in class org.apache.oozie.dependency.FSURIHandler
-
- getURIWithoutDoneFlag(String, String) - Method in class org.apache.oozie.dependency.HCatURIHandler
-
- getURIWithoutDoneFlag(String, String) - Method in interface org.apache.oozie.dependency.URIHandler
-
Get the URI path from path which has done flag
- getUser() - Method in class org.apache.oozie.BaseEngine
-
Return the user name.
- getUser() - Method in class org.apache.oozie.BundleJobBean
-
- getUser() - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- getUser() - Method in class org.apache.oozie.CoordinatorJobBean
-
- getUser() - Method in class org.apache.oozie.dependency.URIHandler.Context
-
Get the name of the user the URI will be accessed as
- getUser(HttpServletRequest) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Return the user name of the request if any.
- getUser() - Method in class org.apache.oozie.sla.SLACalcStatus
-
- getUser() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- getUser() - Method in class org.apache.oozie.sla.SLASummaryBean
-
- getUser() - Method in class org.apache.oozie.WorkflowJobBean
-
- getUserLogFilter() - Method in class org.apache.oozie.util.XLogFilter
-
- getUserRetryCount() - Method in class org.apache.oozie.WorkflowActionBean
-
- getUserRetryErrorCode() - Static method in class org.apache.oozie.service.LiteWorkflowStoreService
-
Get system defined and instance defined error codes for which USER_RETRY is allowed
- getUserRetryInterval() - Method in class org.apache.oozie.workflow.lite.NodeDef
-
- getUserRetryInterval() - Method in class org.apache.oozie.WorkflowActionBean
-
- getUserRetryMax() - Method in class org.apache.oozie.workflow.lite.NodeDef
-
- getUserRetryMax() - Method in class org.apache.oozie.WorkflowActionBean
-
- getUserRetryPolicy() - Method in class org.apache.oozie.workflow.lite.NodeDef
-
- getUsers() - Static method in class org.apache.oozie.util.ZKUtils
-
Useful for tests to get the registered classes
- getUserTime() - Method in class org.apache.oozie.servlet.JVMInfo.JThreadInfo
-
- getValByRegex(String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- getValidationQuery(String) - Static method in class org.apache.oozie.store.OozieSchema
-
Gets the query that will be used to validate the connection
- getValidator(SchemaService.SchemaName) - Method in class org.apache.oozie.service.SchemaService
-
Returns validator for schema
- getValidator(Schema) - Static method in class org.apache.oozie.service.SchemaService
-
Returns validator for schema
- getValue() - Method in class org.apache.oozie.util.Instrumentation.Counter
-
Deprecated.
Return the counter snapshot.
- getValue() - Method in interface org.apache.oozie.util.Instrumentation.Element
-
Deprecated.
Return the snapshot value of the Intrumentation element.
- getValue() - Method in class org.apache.oozie.util.Instrumentation.Timer
-
Deprecated.
Return the timer snapshot.
- getVar(String) - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Get a workflow action variable.
- getVar(String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- getVar(String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ForkedActionExecutorContext
-
- getVar(String) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- getVar(String) - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- getVar(String) - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Return a variable from the context of the instance.
- getVariable(String) - Method in class org.apache.oozie.util.ELEvaluator.Context
-
Return a variable from the context.
- getVariable(String) - Method in class org.apache.oozie.util.ELEvaluator
-
Convenience method that returns a variable from the EL evaluator context.
- getVariables() - Method in class org.apache.oozie.util.Instrumentation
-
Deprecated.
Return all the variables.
- getVariables() - Method in class org.apache.oozie.util.MetricsInstrumentation
-
- getWaitingActions(HCatURI) - Method in class org.apache.oozie.dependency.hcat.EhcacheHCatDependencyCache
-
- getWaitingActions(HCatURI) - Method in interface org.apache.oozie.dependency.hcat.HCatDependencyCache
-
Get the list of actionIDs waiting for a partition
- getWaitingActions(HCatURI) - Method in class org.apache.oozie.dependency.hcat.SimpleHCatDependencyCache
-
- getWaitingActions() - Method in class org.apache.oozie.dependency.hcat.WaitingActions
-
Get the list of waiting actions
- getWaitingActions(HCatURI) - Method in class org.apache.oozie.service.PartitionDependencyManagerService
-
Get the list of actionIDs waiting for a partition
- getWarnings() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- getWfActionByJobIdAndName(String, String, int, int) - Method in class org.apache.oozie.CoordinatorEngine
-
get wf actions by action name in a coordinator job
- getWfActionByJobIdAndName(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.BaseJobServlet
-
get wf actions by name in coordinator job
- getWfActionByJobIdAndName(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- getWfConfiguration() - Method in class org.apache.oozie.command.wf.WfEndXCommand
-
- getWfId() - Method in class org.apache.oozie.WorkflowActionBean
-
Return the job Id.
- getWfInstanceBlob() - Method in class org.apache.oozie.WorkflowJobBean
-
- getWFJSONObject(WorkflowsInfo, String) - Static method in class org.apache.oozie.OozieJsonFactory
-
- getWfsForCoordAction(String) - Method in class org.apache.oozie.LocalOozieClientCoord
-
- getWhereClause(StringBuilder, Map<Pair<String, CoordinatorEngine.FILTER_COMPARATORS>, List<Object>>) - Static method in class org.apache.oozie.coord.CoordUtils
-
- getWithDeprecatedCheck(Configuration, String, String, String) - Static method in class org.apache.oozie.util.ConfigUtils
-
Fetches a property using both a deprecated name and the new name.
- getWithDeprecatedCheck(Configuration, String, String, boolean) - Static method in class org.apache.oozie.util.ConfigUtils
-
Fetches a property using both a deprecated name and the new name.
- getWorkflow() - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Return the workflow job.
- getWorkflow() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- getWorkflow() - Static method in class org.apache.oozie.DagELFunctions
-
- getWorkflow(String, boolean) - Method in class org.apache.oozie.store.WorkflowStore
-
Load the Workflow into a Bean and return it.
- getWorkflowAction(String) - Method in class org.apache.oozie.DagEngine
-
- getWorkflowAction(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
Get wf action info
- getWorkflowAction(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- getWorkflowActionBean(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- getWorkflowActionInfo(String) - Method in class org.apache.oozie.LocalOozieClient
-
- getWorkflowActionRetries(String) - Method in class org.apache.oozie.DagEngine
-
Gets the workflow action retries.
- getWorkflowClient(ActionExecutor.Context, String) - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- getWorkflowCountWithStatus(String) - Method in class org.apache.oozie.store.WorkflowStore
-
Get the number of Workflows with the given status.
- getWorkflowCountWithStatusInLastNSeconds(String, int) - Method in class org.apache.oozie.store.WorkflowStore
-
Get the number of Workflows with the given status which was modified in given time limit.
- getWorkflowIdForExternalId(String) - Method in class org.apache.oozie.store.WorkflowStore
-
Get the Workflow ID with given external ID which will be assigned for the subworkflows.
- getWorkflowInfo(String) - Method in class org.apache.oozie.store.WorkflowStore
-
Load the Workflow and all Action details and return a WorkflowJobBean.
- getWorkflowInfoWithActionsSubset(String, int, int) - Method in class org.apache.oozie.store.WorkflowStore
-
Load the Workflow and subset Actions details and return a WorkflowJobBean.
- getWorkflowInstance() - Method in class org.apache.oozie.WorkflowJobBean
-
- getWorkflowJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
Get workflow job
- getWorkflowJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- getWorkflowJobBean(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
Get workflow job
- getWorkflowLibWithNoDB() - Method in class org.apache.oozie.service.DBLiteWorkflowStoreService
-
Return the workflow lib without DB connection.
- getWorkflowLibWithNoDB() - Method in class org.apache.oozie.service.WorkflowStoreService
-
Return a workkflow lib, giving access to the parser functionality.
- getWorkflowName() - Method in class org.apache.oozie.command.wf.SubmitHiveXCommand
-
- getWorkflowName() - Method in class org.apache.oozie.command.wf.SubmitHttpXCommand
-
- getWorkflowName() - Method in class org.apache.oozie.command.wf.SubmitMRXCommand
-
- getWorkflowName() - Method in class org.apache.oozie.command.wf.SubmitPigXCommand
-
- getWorkflowName() - Method in class org.apache.oozie.command.wf.SubmitScriptLanguageXCommand
-
- getWorkflowName() - Method in class org.apache.oozie.command.wf.SubmitSqoopXCommand
-
- getWorkflowNamespace() - Method in class org.apache.oozie.command.wf.SubmitHttpXCommand
-
- getWorkflows() - Method in class org.apache.oozie.WorkflowsInfo
-
Return the workflows being returned.
- getWorkflowsInfo(Map<String, List<String>>, int, int) - Method in class org.apache.oozie.store.WorkflowStore
-
Loads all the jobs that are satisfying the given filter condition.
- getWorkflowXml(Configuration) - Method in class org.apache.oozie.command.wf.SubmitHttpXCommand
-
Generate workflow xml from conf object
- getWriteLock(String, long) - Method in class org.apache.oozie.service.MemoryLocksService
-
Obtain a WRITE lock for a source.
- getWriteLock(String, long) - Method in class org.apache.oozie.service.ZKLocksService
-
Obtain a WRITE lock for a source.
- getXLogFilter() - Method in class org.apache.oozie.util.XLogStreamer
-
- getZKConnectionState() - Static method in class org.apache.oozie.event.listener.ZKConnectionListener
-
- getZKId() - Method in class org.apache.oozie.util.ZKUtils
-
Returns the ID of this Oozie Server as seen by ZooKeeper and other Oozie Servers
- getZKIdIndex(List<ServiceInstance<Map>>) - Method in class org.apache.oozie.util.ZKUtils
-
Returns the index of this Oozie Server in ZooKeeper's list of Oozie Servers (ordered by registration time)
- getZKNameSpace() - Static method in class org.apache.oozie.util.ZKUtils
-
Returns configured zk namesapces
- getZKSequence() - Method in class org.apache.oozie.service.ZKUUIDService
-
- GIT_ACTION_TYPE - Static variable in class org.apache.oozie.action.hadoop.GitActionExecutor
-
- GitActionExecutor - Class in org.apache.oozie.action.hadoop
-
- GitActionExecutor() - Constructor for class org.apache.oozie.action.hadoop.GitActionExecutor
-
- GraphGenerator - Class in org.apache.oozie.util.graph
-
Class to generate and plot runtime workflow DAG.
- GraphGenerator(String, WorkflowJob, boolean, GraphRenderer) - Constructor for class org.apache.oozie.util.graph.GraphGenerator
-
Constructor Inversion of Control-style for better testability.
- GRAPHITE - Static variable in class org.apache.oozie.util.MetricsInstrumentation
-
- GraphRenderer - Interface in org.apache.oozie.util.graph
-
- GraphvizRenderer - Class in org.apache.oozie.util.graph
-
- GraphvizRenderer() - Constructor for class org.apache.oozie.util.graph.GraphvizRenderer
-
- greaterThan(Schema.Column, Object) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Generate Condition statement for GREATER THAN condition checking
- greaterThanOrEqual(Schema.Column, Object) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Generate Condition statement for GREATER THAN OR EQUAL condition checking
- GROUP - Static variable in class org.apache.oozie.service.XLogService
-
Group log info constant.
- GROUPS - Static variable in class org.apache.oozie.action.hadoop.HadoopELFunctions
-
- GROUPS - Static variable in class org.apache.oozie.service.ProxyUserService
-
- GROUPS - Static variable in class org.apache.oozie.util.PropertiesUtils
-
- GroupsService - Class in org.apache.oozie.service
-
The GroupsService class delegates to the Hadoop's org.apache.hadoop.security.Groups
to retrieve the groups a user belongs to.
- GroupsService() - Constructor for class org.apache.oozie.service.GroupsService
-
- GzipCompressionCodec - Class in org.apache.oozie.compression
-
Class to compress and decompress data using Gzip codec
- GzipCompressionCodec() - Constructor for class org.apache.oozie.compression.GzipCompressionCodec
-
- gzTimePattern - Static variable in class org.apache.oozie.util.XLogStreamer
-
This pattern matches the end of a gzip filename to have a format like "-YYYY-MM-dd-HH.gz" with capturing groups for each part
of the date
- ignore(String, String, String) - Method in class org.apache.oozie.CoordinatorEngine
-
- ignore(String, String) - Method in class org.apache.oozie.LocalOozieClientCoord
-
- ignoreChildren() - Method in class org.apache.oozie.command.coord.CoordActionsIgnoreXCommand
-
- ignoreChildren() - Method in class org.apache.oozie.command.IgnoreTransitionXCommand
-
- ignoreJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- ignoreJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- ignoreJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
Ignore a coordinator job
- IgnoreTransitionXCommand<T> - Class in org.apache.oozie.command
-
- IgnoreTransitionXCommand(String, String, int) - Constructor for class org.apache.oozie.command.IgnoreTransitionXCommand
-
- in(Schema.Column, Object...) - Static method in class org.apache.oozie.util.db.SqlStatement
-
IN Condition for checking multiple values
- in(Schema.Column, SqlStatement.Select) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Sub query with IN condition
- includeDataSets(Element, Configuration) - Method in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
Include referred datasets into XML.
- incr(String, String, long) - Method in class org.apache.oozie.util.Instrumentation
-
Deprecated.
Increment an instrumentation counter.
- incr(String, String, long) - Method in class org.apache.oozie.util.MetricsInstrumentation
-
Increment an instrumentation counter.
- incrActionCounter(String, int) - Method in class org.apache.oozie.command.wf.ActionXCommand
-
Increment the action counter in the instrumentation log.
- incrCommandCounter(String, int, Instrumentation) - Static method in class org.apache.oozie.util.InstrumentUtils
-
Used to increment command counters.
- incrCounter(String, int) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Convenience method for instrumentation counters.
- incrCounter(String, String, int, Instrumentation) - Static method in class org.apache.oozie.util.InstrumentUtils
-
Convenience method to increment counters.
- increment() - Method in class org.apache.oozie.util.TimestampedMessageParser
-
Causes the next message and timestamp to be parsed from the BufferedReader.
- incrementAndGetPending() - Method in class org.apache.oozie.BundleActionBean
-
increment pending and return it
- incrementAndGetPending() - Method in class org.apache.oozie.CoordinatorActionBean
-
increment pending and return it
- incRetries() - Method in class org.apache.oozie.WorkflowActionBean
-
Increments the number of retries for the action.
- incrJobCounter(String, int, Instrumentation) - Static method in class org.apache.oozie.util.InstrumentUtils
-
Used to increment job counters.
- incrmentUserRetryCount() - Method in class org.apache.oozie.WorkflowActionBean
-
- info(Object) - Method in class org.apache.oozie.util.XLog
-
Log a info message to the common Log
.
- info(Object, Throwable) - Method in class org.apache.oozie.util.XLog
-
Log a info message and Exception
to the common Log
.
- info(String, Object...) - Method in class org.apache.oozie.util.XLog
-
Log a info message Exception
to the common Log
.
- info(int, String, Object...) - Method in class org.apache.oozie.util.XLog
-
Tee Log a info message Exception
to the common log and specified Log
s.
- Info() - Constructor for class org.apache.oozie.util.XLog.Info
-
Constructs an empty LogInfo.
- Info(XLog.Info) - Constructor for class org.apache.oozie.util.XLog.Info
-
Construct a new LogInfo object from an existing one.
- INFO_THRESHOLD_KEY - Static variable in class org.apache.oozie.service.JvmPauseMonitorService
-
- inInterruptMode() - Method in class org.apache.oozie.command.XCommand
-
- inInterruptMode() - Method in interface org.apache.oozie.util.XCallable
-
- init(Configuration) - Method in class org.apache.oozie.dependency.FSURIHandler
-
- init(Configuration) - Method in class org.apache.oozie.dependency.hcat.EhcacheHCatDependencyCache
-
- init(Configuration) - Method in interface org.apache.oozie.dependency.hcat.HCatDependencyCache
-
Initialize the cache with configuration
- init(Configuration) - Method in class org.apache.oozie.dependency.hcat.SimpleHCatDependencyCache
-
- init(Configuration) - Method in class org.apache.oozie.dependency.HCatURIHandler
-
- init(Configuration) - Method in interface org.apache.oozie.dependency.URIHandler
-
Initialize the URIHandler
- init(Configuration) - Method in interface org.apache.oozie.event.EventQueue
-
Initialize the event queue
- init(Configuration) - Method in class org.apache.oozie.event.listener.JobEventListener
-
Initialize the listener
- init(Configuration) - Method in class org.apache.oozie.event.MemoryEventQueue
-
- init(Configuration) - Method in class org.apache.oozie.jms.JMSJobEventListener
-
- init(Configuration) - Method in class org.apache.oozie.jms.JMSSLAEventListener
-
- init(Services) - Method in class org.apache.oozie.service.AbandonedCoordCheckerService
-
- init(Services) - Method in class org.apache.oozie.service.ActionCheckerService
-
Initializes the Action Check service.
- init(Services) - Method in class org.apache.oozie.service.ActionService
-
- init(Services) - Method in class org.apache.oozie.service.AuthorizationService
-
Initialize the service.
- init(Services) - Method in class org.apache.oozie.service.BundleEngineService
-
Initialize the service.
- init(Services) - Method in class org.apache.oozie.service.CallableQueueService
-
Initialize the command queue service.
- init(Services) - Method in class org.apache.oozie.service.CallbackService
-
Initialize the service.
- init(Services) - Method in class org.apache.oozie.service.ConfigurationService
-
Initialize the log service.
- init(Services) - Method in class org.apache.oozie.service.CoordinatorEngineService
-
Initialize the service.
- init(Services) - Method in class org.apache.oozie.service.CoordMaterializeTriggerService
-
- init(Services) - Method in class org.apache.oozie.service.DagEngineService
-
Initialize the service.
- init(Services) - Method in class org.apache.oozie.service.DagXLogInfoService
-
Initialize the service.
- init(Services) - Method in class org.apache.oozie.service.DBLiteWorkflowStoreService
-
- init(Services) - Method in class org.apache.oozie.service.ELService
-
Initialize the EL service.
- init(Services) - Method in class org.apache.oozie.service.EventHandlerService
-
- init(Services) - Method in class org.apache.oozie.service.GroupsService
-
Initializes the service.
- init(Services) - Method in class org.apache.oozie.service.HadoopAccessorService
-
- init(Configuration) - Method in class org.apache.oozie.service.HadoopAccessorService
-
- init(Services) - Method in class org.apache.oozie.service.HCatAccessorService
-
- init(Services) - Method in class org.apache.oozie.service.InstrumentationService
-
Deprecated.
Initialize the instrumentation service.
- init(Services) - Method in class org.apache.oozie.service.JMSAccessorService
-
- init(Services) - Method in class org.apache.oozie.service.JMSTopicService
-
- init(Services) - Method in class org.apache.oozie.service.JobsConcurrencyService
-
Initialize the jobs concurrency service
- init(Services) - Method in class org.apache.oozie.service.JPAService
-
- init(Services) - Method in class org.apache.oozie.service.JvmPauseMonitorService
-
- init(Services) - Method in class org.apache.oozie.service.MemoryLocksService
-
Initialize the memory locks service
- init(Services) - Method in class org.apache.oozie.service.MetricsInstrumentationService
-
Initialize the metrics instrumentation service.
- init(Services) - Method in class org.apache.oozie.service.PartitionDependencyManagerService
-
- init(Services) - Method in class org.apache.oozie.service.PauseTransitService
-
- init(Services) - Method in class org.apache.oozie.service.ProxyUserService
-
Initializes the service.
- init(Services) - Method in class org.apache.oozie.service.PurgeService
-
- init(Services) - Method in class org.apache.oozie.service.RecoveryService
-
Initializes the RecoveryService.
- init(Services) - Method in class org.apache.oozie.service.SchedulerService
-
Initialize the scheduler service.
- init(Services) - Method in class org.apache.oozie.service.SchemaCheckerService
-
- init(Services) - Method in class org.apache.oozie.service.SchemaService
-
Initialize the service.
- init(Services) - Method in interface org.apache.oozie.service.Service
-
Initialize the service.
- init() - Method in class org.apache.oozie.service.Services
-
- init(Services) - Method in class org.apache.oozie.service.ShareLibService
-
- init(Services) - Method in class org.apache.oozie.service.SLAStoreService
-
- init(Services) - Method in class org.apache.oozie.service.SparkConfigurationService
-
- init(Services) - Method in class org.apache.oozie.service.StatusTransitService
-
- init(Services) - Method in class org.apache.oozie.service.StoreService
-
- init(Services) - Method in class org.apache.oozie.service.URIHandlerService
-
- init(Services) - Method in class org.apache.oozie.service.UserGroupInformationService
-
- init(Services) - Method in class org.apache.oozie.service.UUIDService
-
Initialize the UUID service.
- init(Services) - Method in class org.apache.oozie.service.WorkflowAppService
-
Initialize the workflow application service.
- init(Services) - Method in class org.apache.oozie.service.WorkflowSchemaService
-
Initialize the service.
- init(Services) - Method in class org.apache.oozie.service.XLogService
-
Initialize the log service.
- init(Services) - Method in class org.apache.oozie.service.XLogStreamingService
-
Initialize the log streaming service.
- init(Services) - Method in class org.apache.oozie.service.ZKJobsConcurrencyService
-
Initialize the zookeeper jobs concurrency service
- init(Services) - Method in class org.apache.oozie.service.ZKLocksService
-
Initialize the zookeeper locks service
- init(Services) - Method in class org.apache.oozie.service.ZKUUIDService
-
- init(Services) - Method in class org.apache.oozie.service.ZKXLogStreamingService
-
Initialize the log streaming service.
- init(FilterConfig) - Method in class org.apache.oozie.servlet.AuthFilter
-
Initialize the filter.
- init() - Method in class org.apache.oozie.servlet.CallbackServlet
-
- init(FilterConfig) - Method in class org.apache.oozie.servlet.HostnameFilter
-
Initializes the filter.
- init(FilterConfig) - Method in class org.apache.oozie.servlet.HttpResponseHeaderFilter
-
Initializes the filter.
- init(ServletConfig) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Initializes total request and servlet request samplers.
- init(Configuration) - Method in class org.apache.oozie.sla.listener.SLAEmailEventListener
-
- init(Configuration) - Method in class org.apache.oozie.sla.listener.SLAEventListener
-
Initialize the listener
- init(Configuration) - Method in class org.apache.oozie.sla.listener.SLAJobEventListener
-
- init(Services) - Method in class org.apache.oozie.sla.service.SLAService
-
- init(Configuration) - Method in interface org.apache.oozie.sla.SLACalculator
-
- init(Configuration) - Method in class org.apache.oozie.sla.SLACalculatorMemory
-
- initActionType() - Method in class org.apache.oozie.action.ActionExecutor
-
Invoked once at system initialization time.
- initActionType() - Method in class org.apache.oozie.action.email.EmailActionExecutor
-
- initActionType() - Method in class org.apache.oozie.action.hadoop.FsActionExecutor
-
Initialize Action.
- initActionType() - Method in class org.apache.oozie.action.hadoop.GitActionExecutor
-
- initActionType() - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- initActionType() - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- initActionType() - Method in class org.apache.oozie.action.ssh.SshActionExecutor
-
Initialize Action.
- initalized - Static variable in class org.apache.oozie.util.XConfiguration
-
- initEvaluators() - Method in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
Initialize all the required EL Evaluators.
- INITIAL_WAIT_TIME - Static variable in class org.apache.oozie.service.JPAService
-
- initialize(Configuration) - Static method in class org.apache.oozie.compression.CodecFactory
-
Initialize the codec factory to maintain list of codecs
- initialize(String, boolean) - Method in class org.apache.oozie.util.OozieRollingPolicy
-
- initInstance - Variable in class org.apache.oozie.coord.SyncCoordDataset
-
- inject(String) - Method in class org.apache.oozie.util.db.RuntimeExceptionInjector
-
- injectCallback(ActionExecutor.Context, Configuration) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- injectCallback(ActionExecutor.Context, Configuration) - Method in class org.apache.oozie.action.hadoop.MapReduceActionExecutor
-
- injectCallback(ActionExecutor.Context, Configuration) - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- injectDefaults(Configuration, Configuration) - Static method in class org.apache.oozie.util.XConfiguration
-
Injects configuration key/value pairs from one configuration to another if the key does not exist in the target
configuration.
- injectInline(Element, Configuration) - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- injectParent(String, Configuration) - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- injectRecovery(String, Configuration) - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- injectSuperParent(WorkflowJob, Configuration, Configuration) - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- input(String) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicBuilder.CoordInputDependencyBuilder
-
Construct input function
- input(String) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicBuilder
-
Input function of input-logic
- input(AbstractCoordInputDependency, String, int, int) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
Evaluate input function with min and wait
- INPUT_LOGIC - Static variable in interface org.apache.oozie.coord.input.logic.CoordInputLogicEvaluator
-
- InputLogicParser - Class in org.apache.oozie.coord.input.logic
-
Parses xml into jexl expression
- InputLogicParser() - Constructor for class org.apache.oozie.coord.input.logic.InputLogicParser
-
- inputWait(String) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicBuilder.CoordInputDependencyBuilder
-
Construct wait function
- inputWait(int) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicBuilder.CoordInputDependencyBuilder
-
Construct wait function
- insert(JsonBean) - Method in class org.apache.oozie.executor.jpa.QueryExecutor
-
- insert(WorkflowInstance) - Method in class org.apache.oozie.workflow.lite.DBLiteWorkflowLib
-
Save the Workflow Instance for the given Workflow Application.
- insert(WorkflowInstance) - Method in interface org.apache.oozie.workflow.WorkflowLib
-
Insert a workflow instance in storage.
- insertAction(WorkflowActionBean) - Method in class org.apache.oozie.store.WorkflowStore
-
Create a new Action record in the ACTIONS table with the given Bean.
- insertCallableIntoInterruptMap(XCallable<?>) - Method in class org.apache.oozie.service.CallableQueueService
-
insert a new callable in the Interrupt Command Map add a new element to
the list or create a new list accordingly
- insertInto(Schema.Table) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Return a new Insert Statement
- insertList - Variable in class org.apache.oozie.command.TransitionXCommand
-
- insertSLAEvent(SLAEventBean) - Method in class org.apache.oozie.store.SLAStore
-
Deprecated.
Create an SLAEventBeane.
- insertWorkflow(WorkflowJobBean) - Method in class org.apache.oozie.store.WorkflowStore
-
Create a Workflow and return a WorkflowJobBean.
- INSTANCE_SEPARATOR - Static variable in class org.apache.oozie.coord.CoordELFunctions
-
- INSTR_CHECK_ACTIONS_COUNTER - Static variable in class org.apache.oozie.service.ActionCheckerService
-
- INSTR_CHECK_COORD_ACTIONS_COUNTER - Static variable in class org.apache.oozie.service.ActionCheckerService
-
- INSTR_FAILED_AUTH_COUNTER - Static variable in class org.apache.oozie.service.AuthorizationService
-
- INSTR_FAILED_JOBS_COUNTER_NAME - Static variable in class org.apache.oozie.command.wf.WorkflowXCommand
-
- INSTR_KILLED_JOBS_COUNTER_NAME - Static variable in class org.apache.oozie.command.wf.WorkflowXCommand
-
- INSTR_SUCCEEDED_JOBS_COUNTER_NAME - Static variable in class org.apache.oozie.command.wf.WorkflowXCommand
-
- instrument(Instrumentation) - Method in class org.apache.oozie.service.ActionService
-
- instrument(Instrumentation) - Method in class org.apache.oozie.service.CallableQueueService
-
Instruments the callable queue service.
- instrument(Instrumentation) - Method in class org.apache.oozie.service.ConfigurationService
-
Instruments the configuration service.
- instrument(Instrumentation) - Method in class org.apache.oozie.service.DBLiteWorkflowStoreService
-
- instrument(Instrumentation) - Method in class org.apache.oozie.service.JobsConcurrencyService
-
Instruments the jobs concurrency service.
- instrument(Instrumentation) - Method in class org.apache.oozie.service.JPAService
-
- instrument(Instrumentation) - Method in class org.apache.oozie.service.MemoryLocksService
-
Instruments the memory locks service.
- instrument(Instrumentation) - Method in class org.apache.oozie.service.SchemaCheckerService
-
- instrument(Instrumentation) - Method in class org.apache.oozie.service.ShareLibService
-
Instruments the log service.
- instrument(Instrumentation) - Method in class org.apache.oozie.service.XLogService
-
Instruments the log service.
- instrument(Instrumentation) - Method in class org.apache.oozie.service.XLogStreamingService
-
Instruments the log streaming service.
- instrument(Instrumentation) - Method in class org.apache.oozie.service.ZKJobsConcurrencyService
-
Instruments the zk jobs concurrency service.
- instrument(Instrumentation) - Method in class org.apache.oozie.service.ZKLocksService
-
Instruments the zookeeper locks service.
- instrument(Instrumentation) - Method in class org.apache.oozie.service.ZKXLogStreamingService
-
Instruments the log streaming service.
- instrument(Instrumentation) - Method in interface org.apache.oozie.util.Instrumentable
-
Set the system instrumentation.
- Instrumentable - Interface in org.apache.oozie.util
-
Managed entities (like services) that implement this interface are injected with the system
Instrumentation
object.
- instrumentation - Variable in class org.apache.oozie.command.XCommand
-
- instrumentation - Static variable in class org.apache.oozie.service.InstrumentationService
-
Deprecated.
- Instrumentation - Class in org.apache.oozie.util
-
- Instrumentation() - Constructor for class org.apache.oozie.util.Instrumentation
-
Deprecated.
Instrumentation constructor.
- Instrumentation.Counter - Class in org.apache.oozie.util
-
Deprecated.
Counter Instrumentation element.
- Instrumentation.Cron - Class in org.apache.oozie.util
-
Deprecated.
Cron is a stopwatch that can be started/stopped several times.
- Instrumentation.Element<T> - Interface in org.apache.oozie.util
-
Deprecated.
Gives access to a snapshot of an Instrumentation element (Counter, Timer).
- Instrumentation.Timer - Class in org.apache.oozie.util
-
Deprecated.
Timer Instrumentation element.
- Instrumentation.Variable<T> - Interface in org.apache.oozie.util
-
Deprecated.
Interface for instrumentation variables.
- INSTRUMENTATION_GROUP - Static variable in class org.apache.oozie.command.XCommand
-
- INSTRUMENTATION_GROUP - Static variable in class org.apache.oozie.service.ActionCheckerService
-
- INSTRUMENTATION_GROUP - Static variable in class org.apache.oozie.service.AuthorizationService
-
- INSTRUMENTATION_GROUP - Static variable in class org.apache.oozie.service.MemoryLocksService
-
- INSTRUMENTATION_GROUP - Static variable in class org.apache.oozie.servlet.JsonRestServlet
-
Name of the instrumentation group for the WS layer, value is 'webservices'.
- INSTRUMENTATION_GROUP - Static variable in class org.apache.oozie.sla.SLACalculatorMemory
-
- INSTRUMENTATION_LOG_NAME - Static variable in class org.apache.oozie.util.XLog
-
- InstrumentationService - Class in org.apache.oozie.service
-
- InstrumentationService() - Constructor for class org.apache.oozie.service.InstrumentationService
-
Deprecated.
- InstrumentUtils - Class in org.apache.oozie.util
-
Instrument utilities.
- InstrumentUtils() - Constructor for class org.apache.oozie.util.InstrumentUtils
-
- INT_DEFAULT - Static variable in class org.apache.oozie.util.ConfigUtils
-
- inTerminalState() - Method in class org.apache.oozie.WorkflowActionBean
-
Return whether workflow action in terminal state or not
- inTerminalState() - Method in class org.apache.oozie.WorkflowJobBean
-
- intern(String) - Static method in class org.apache.oozie.util.StringUtils
-
Return the internalized string, or null if the given string is null.
- INTERNAL_VERSION_ID - Static variable in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
- interpret(JexlNode) - Method in class org.apache.oozie.coord.input.logic.OozieJexlInterpreter
-
- invokeAll(List<CallableQueueService.CallableWrapper<T>>) - Method in class org.apache.oozie.service.CallableQueueService
-
- IOUtils - Class in org.apache.oozie.util
-
IO Utility methods.
- IOUtils() - Constructor for class org.apache.oozie.util.IOUtils
-
- IS_RESOLVED - Static variable in class org.apache.oozie.coord.CoordELConstants
-
- isActionList() - Method in class org.apache.oozie.util.XLogFilter
-
- isActive() - Method in class org.apache.oozie.command.SkipCommitFaultInjection
-
- isActive(String) - Static method in class org.apache.oozie.FaultInjection
-
- isActive() - Method in class org.apache.oozie.FaultInjection
-
- isActive() - Method in class org.apache.oozie.store.Store
-
Check if transaction is active
- isAdmin(String) - Method in class org.apache.oozie.service.AuthorizationService
-
Check if the user has admin privileges.
- isAllServerRequest(Map<String, String[]>) - Method in class org.apache.oozie.service.JobsConcurrencyService
-
Checks if rest request is for all server.
- isAllServerRequest(Map<String, String[]>) - Method in class org.apache.oozie.service.ZKJobsConcurrencyService
-
Checks if rest request is for all server.
- isAuditLogEnabled() - Method in class org.apache.oozie.service.XLogService
-
- isAuthorizationEnabled() - Method in class org.apache.oozie.service.AuthorizationService
-
Return if security is enabled or not.
- isAuthorizedSystemInfo() - Method in class org.apache.oozie.service.AuthorizationService
-
- isAvailable() - Method in class org.apache.oozie.coord.input.dependency.CoordInputInstance
-
Checks if is available.
- isBackwardSupportForCoordStatus() - Static method in class org.apache.oozie.util.ConfigUtils
-
- isCancelled() - Method in class org.apache.oozie.service.AsyncXCommandExecutor.AccessibleRunnableScheduledFuture
-
- isChangeInDependency(StringBuilder, String, StringBuilder, boolean) - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- isChangeInDependency(StringBuilder, String, StringBuilder, boolean) - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Checks if is change in dependency.
- isChangeInDependency(StringBuilder, String, StringBuilder, boolean) - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- isClosed() - Method in class org.apache.oozie.store.Store
-
- isClosed() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- isComplete() - Method in class org.apache.oozie.WorkflowActionBean
-
Return if the action is complete.
- isCompleted(String) - Method in class org.apache.oozie.action.ActionExecutor
-
Return if the external status indicates that the action has completed.
- isCompleted(String) - Method in class org.apache.oozie.action.control.ControlNodeActionExecutor
-
- isCompleted(String) - Method in class org.apache.oozie.action.decision.DecisionActionExecutor
-
- isCompleted(String) - Method in class org.apache.oozie.action.email.EmailActionExecutor
-
- isCompleted(String) - Method in class org.apache.oozie.action.hadoop.FsActionExecutor
-
- isCompleted(String) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- isCompleted(String) - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- isCompleted(String) - Method in class org.apache.oozie.action.ssh.SshActionExecutor
-
- isCompressionEnabled() - Static method in class org.apache.oozie.compression.CodecFactory
-
Check whether compression is enabled or not
- isConnectionInitialized() - Method in interface org.apache.oozie.jms.ConnectionContext
-
Checks whether connection is initialized or not
- isConnectionInitialized() - Method in class org.apache.oozie.jms.DefaultConnectionContext
-
- isCritical() - Method in class org.apache.oozie.BundleActionBean
-
Return if the action is critical.
- isDataSetResolved(String) - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- isDataSetResolved(String) - Method in class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- isDebug() - Method in class org.apache.oozie.util.XLogUserFilterParam
-
Checks if is debug.
- isDebugEnabled() - Method in class org.apache.oozie.util.XLog
-
Return if debug logging is enabled.
- isDebugMode() - Method in class org.apache.oozie.util.XLogFilter
-
- isDependencyMet - Variable in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- isDependencyMet() - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- isDependencyMet() - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Checks if dependencies are meet.
- isDependencyMet() - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- isDependencyMet() - Method in class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- isDetached(Object) - Method in class org.apache.oozie.store.Store
-
- isDone() - Method in class org.apache.oozie.service.AsyncXCommandExecutor.AccessibleRunnableScheduledFuture
-
- isDoneMaterialization() - Method in class org.apache.oozie.CoordinatorJobBean
-
Return if the action is done with materialization
- isDSTChangeDay(Calendar) - Static method in class org.apache.oozie.util.DateUtils
-
Determine whether a specific date is on DST change day
- isEmpty() - Method in interface org.apache.oozie.event.EventQueue
-
Find out if queue is empty
- isEmpty() - Method in class org.apache.oozie.event.MemoryEventQueue
-
- isEmpty() - Method in interface org.apache.oozie.sla.SLACalculator
-
- isEmpty() - Method in class org.apache.oozie.sla.SLACalculatorMemory
-
- isEnabled() - Static method in class org.apache.oozie.service.EventHandlerService
-
- isEnabled() - Static method in class org.apache.oozie.service.InstrumentationService
-
Deprecated.
Returns if the InstrumentationService is enabled or not.
- isEnabled() - Static method in class org.apache.oozie.service.MetricsInstrumentationService
-
Returns if the MetricsInstrumentationService is enabled or not.
- isEnabled() - Static method in class org.apache.oozie.sla.service.SLAService
-
- isEnded() - Method in class org.apache.oozie.command.sla.SLAJobEventXCommand
-
- isEnded() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
Returns whether setEndData has been called or not.
- isEndMiss() - Method in class org.apache.oozie.command.sla.SLAJobEventXCommand
-
- isEndState() - Method in enum org.apache.oozie.workflow.WorkflowInstance.Status
-
Return if the status if an end state (it cannot change anymore).
- isEqual(Schema.Column, Object) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Generate Condition statement for equality check
- isErrorEnabled() - Method in class org.apache.oozie.util.XLog
-
Return if error logging is enabled.
- isErrorLogEnabled() - Method in class org.apache.oozie.service.XLogService
-
- isExecuted() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
Returns whether setExecutionData has been called or not.
- isExecutionComplete() - Method in class org.apache.oozie.WorkflowActionBean
-
Return if the action execution is complete.
- isFatalEnabled() - Method in class org.apache.oozie.util.XLog
-
Return if fatal logging is enabled.
- isFilterPresent() - Method in class org.apache.oozie.util.XLogFilter
-
- isHighlyAvailableMode() - Method in class org.apache.oozie.service.JobsConcurrencyService
-
Check if it is running in HA mode
- isHighlyAvailableMode() - Method in class org.apache.oozie.service.ZKJobsConcurrencyService
-
Return if it is running in HA mode
- isHsqlConnection(Connection) - Static method in class org.apache.oozie.util.db.Schema
-
Checks if the given connection's driver is HSQL Database Driver
- isInfoEnabled() - Method in class org.apache.oozie.util.XLog
-
Return if info logging is enabled.
- isInputLogicSpecified(String) - Static method in class org.apache.oozie.coord.CoordUtils
-
- isInputLogicSpecified(Element) - Static method in class org.apache.oozie.coord.CoordUtils
-
- isInputWaitElapsed(int) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
- isInputWaitElapsed(int) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseThree
-
- isJobEnded() - Method in class org.apache.oozie.command.sla.SLACoordActionJobHistoryXCommand
-
- isJobEnded() - Method in class org.apache.oozie.command.sla.SLAJobHistoryXCommand
-
Checks if is job ended.
- isJobEnded() - Method in class org.apache.oozie.command.sla.SLAWorkflowActionJobHistoryXCommand
-
- isJobEnded() - Method in class org.apache.oozie.command.sla.SLAWorkflowJobHistoryXCommand
-
- isJobIdForThisServer(String) - Method in class org.apache.oozie.service.JobsConcurrencyService
-
Check to see if jobId should be processed by this server.
- isJobIdForThisServer(String) - Method in class org.apache.oozie.service.ZKJobsConcurrencyService
-
Check to see if jobId should be processed by this server.
- isJobIdInHistorySet(String) - Method in class org.apache.oozie.sla.SLACalculatorMemory
-
- isJobIdInSLAMap(String) - Method in class org.apache.oozie.sla.SLACalculatorMemory
-
- isJobInfoEnabled() - Static method in class org.apache.oozie.action.hadoop.OozieJobInfo
-
- isJobRequest() - Method in class org.apache.oozie.command.bundle.BundleSLAAlertsXCommand
-
- isJobRequest() - Method in class org.apache.oozie.command.coord.CoordSLAAlertsXCommand
-
- isJobRequest() - Method in class org.apache.oozie.command.SLAAlertsXCommand
-
- isKnownPublisher(URI) - Method in class org.apache.oozie.service.HCatAccessorService
-
Determine whether a given source URI publishes JMS messages
- isLeader() - Method in class org.apache.oozie.service.JobsConcurrencyService
-
Check to see if this server is the first server.
- isLeader() - Method in class org.apache.oozie.service.ZKJobsConcurrencyService
-
Check to see if this server is the leader server.
- isLike(Schema.Column, String) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Generate condition statement for IS LIKE
- isLocalFile(String) - Static method in class org.apache.oozie.util.FSUtils
-
- isLocalFile(Path) - Static method in class org.apache.oozie.util.FSUtils
-
- isLockRequired() - Method in class org.apache.oozie.command.BulkJobsXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BulkBundleXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleCoordSubmitXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleJobChangeXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleJobResumeXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleJobSuspendXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleJobsXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleJobXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleKillXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundlePauseXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleRerunXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleStartXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleStatusUpdateXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleSubmitXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.bundle.BundleUnpauseXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.BulkCoordXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordActionCheckXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordActionInfoXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordActionMissingDependenciesXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordActionReadyXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordActionsIgnoreXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordActionsKillXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordActionSkipXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordActionStartXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordActionTimeOutXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordActionUpdateXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordChangeXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordJobsXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordJobXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordKillXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordMaterializeTransitionXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordPauseXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordRerunXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordResumeXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordSuspendXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordUnpauseXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordUpdateXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.CoordWfActionInfoXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.coord.SLAEventsXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.NotificationXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.PurgeXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.SchemaCheckXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.sla.SLAJobEventXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.sla.SLAJobHistoryXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.SLAAlertsXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.ActionCheckXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.ActionEndXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.ActionKillXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.ActionStartXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.BulkWorkflowXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.CompletedActionXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.DefinitionXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.ExternalIdXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.JobsXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.JobXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.KillXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.ReRunXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.ResumeXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.SignalXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.SubmitMRXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.SubmitScriptLanguageXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.SubmitSqoopXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.SubmitXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.SuspendXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.WfEndXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.WorkflowActionInfoXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.wf.WorkflowActionRetryInfoXCommand
-
- isLockRequired() - Method in class org.apache.oozie.command.XCommand
-
Indicate if the the command requires locking.
- isLogEnabled() - Method in class org.apache.oozie.util.XLogAuditStreamer
-
- isLogEnabled() - Method in class org.apache.oozie.util.XLogErrorStreamer
-
- isLogEnabled() - Method in class org.apache.oozie.util.XLogStreamer
-
- isLogOverEnable() - Method in class org.apache.oozie.service.XLogUtil
-
- isMainDone(RunningJob) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
- isMainSuccessful(RunningJob) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
- isMember(String, String[], String) - Static method in class org.apache.oozie.util.ParamChecker
-
Check whether an item is a member of an array of string
- isMySqlConnection(Connection) - Static method in class org.apache.oozie.util.db.Schema
-
Checks if the given connection's driver is MySQL Database Driver
- isNotEqual(Schema.Column, Object) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Generate InEquality Condition statement
- isNotLike(Schema.Column, String) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Generates condition statement for IS NOT LIKE
- isNotLocalFile(String) - Static method in class org.apache.oozie.util.FSUtils
-
- isNotNull(Schema.Column) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Generate condition statement for IS NOT NULL
- isNull(Schema.Column) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Generate condition statement for IS NULL
- ISO8601_UTC_MASK - Static variable in class org.apache.oozie.util.DateUtils
-
- isPausedState() - Method in class org.apache.oozie.command.bundle.BundleStatusTransitXCommand
-
- isPausedState() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- isPausedState() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
Checks if job is in paused state.
- isPending() - Method in class org.apache.oozie.BundleActionBean
-
Return if the action is pending.
- isPending() - Method in class org.apache.oozie.BundleJobBean
-
Return if the action is pending.
- isPending() - Method in class org.apache.oozie.CoordinatorActionBean
-
Return if the action is pending.
- isPending() - Method in class org.apache.oozie.CoordinatorJobBean
-
Return if the action is pending.
- isPending() - Method in class org.apache.oozie.WorkflowActionBean
-
Return if the action is pending.
- isPeriodic() - Method in class org.apache.oozie.service.AsyncXCommandExecutor.AccessibleRunnableScheduledFuture
-
- isPhaseTwoEvaluation() - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult
-
- isPrimaryKey() - Method in enum org.apache.oozie.store.OozieSchema.OozieColumn
-
- isPrimaryKey() - Method in interface org.apache.oozie.util.db.Schema.Column
-
Returns if the field is a primary key or not
- isReadOnly() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- isRegisteredForNotification(HCatURI) - Method in class org.apache.oozie.service.HCatAccessorService
-
Check if we are already listening to the JMS topic for the table in the given hcatURI
- isReQueueRequired() - Method in class org.apache.oozie.command.sla.SLAJobEventXCommand
-
- isReQueueRequired() - Method in class org.apache.oozie.command.sla.SLAJobHistoryXCommand
-
- isReQueueRequired() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
- isReQueueRequired() - Method in class org.apache.oozie.command.XCommand
-
Indicate if the the command requires to requeue itself if the lock is not acquired.
- isResolved() - Method in class org.apache.oozie.coord.input.dependency.CoordUnResolvedInputDependency
-
- isResolvedDependencyMeet() - Method in class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- isRetry() - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Return if the executor invocation is a retry or not.
- isRetry() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- isRetryOrManual() - Method in class org.apache.oozie.WorkflowActionBean
-
Return if the action is START_RETRY or START_MANUAL or END_RETRY or
END_MANUAL.
- isRunningState() - Method in class org.apache.oozie.command.bundle.BundleStatusTransitXCommand
-
- isRunningState() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- isRunningState() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
Checks if job is in running state.
- isSecurityEnabled() - Method in class org.apache.oozie.service.AuthorizationService
-
Deprecated.
- isShouldEndWF() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- isShutDown() - Method in class org.apache.oozie.service.AsyncXCommandExecutor
-
- isSlaAlertDisabled(CoordinatorActionBean, String, Configuration) - Static method in class org.apache.oozie.coord.CoordUtils
-
Check if sla alert is disabled for action.
- isSSLEnabled() - Static method in class org.apache.oozie.servlet.ServicesLoader
-
- isStarted() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
Returns whether setStartData has been called or not.
- isStarted() - Static method in class org.apache.oozie.local.LocalOozie
-
- isSupportedApptype(String) - Method in class org.apache.oozie.service.EventHandlerService
-
- isSuspended() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- isSuspendedState() - Method in class org.apache.oozie.command.bundle.BundleStatusTransitXCommand
-
- isSuspendedState() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- isSuspendedState() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
Checks if is in suspended state.
- isSymlink(FileSystem, Path) - Static method in class org.apache.oozie.util.FSUtils
-
- isTerminalState() - Method in class org.apache.oozie.command.bundle.BundleStatusTransitXCommand
-
- isTerminalState() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- isTerminalState() - Method in class org.apache.oozie.command.StatusTransitXCommand
-
Checks if job is in terminal state.
- isTerminalStatus() - Method in class org.apache.oozie.BundleActionBean
-
- isTerminalStatus() - Method in class org.apache.oozie.BundleJobBean
-
- isTerminalStatus() - Method in class org.apache.oozie.CoordinatorActionBean
-
- isTerminalStatus() - Method in class org.apache.oozie.CoordinatorJobBean
-
- isTerminalWithFailure() - Method in class org.apache.oozie.CoordinatorActionBean
-
Return if the action is complete with failure.
- isTerminalWithFailure() - Method in class org.apache.oozie.WorkflowActionBean
-
Return if the action is complete with failure.
- isTerminated() - Method in class org.apache.oozie.service.AsyncXCommandExecutor
-
- isTimeout() - Method in class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
Returns true if timeout period has been reached
- isTraceEnabled() - Method in class org.apache.oozie.util.XLog
-
Return if trace logging is enabled.
- isTriggeringEvent(Appender, LoggingEvent, String, long) - Method in class org.apache.oozie.util.OozieRollingPolicy
-
- isTrue() - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult
-
- isUnResolvedDependencyMet() - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- isUnResolvedDependencyMet() - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Checks if is unresolved dependencies met.
- isUnResolvedDependencyMet() - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- isUnResolvedDependencyMet() - Method in class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- isUserInGroup(String, String) - Method in class org.apache.oozie.service.AuthorizationService
-
Check if the user belongs to the group or not.
- isUserRetry() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
Return if the executor invocation is a user retry or not.
- isUserRetry() - Method in class org.apache.oozie.WorkflowActionBean
-
Return true if the action is USER_RETRY
- isV1CoordjobKillable(CoordinatorJobBean) - Static method in class org.apache.oozie.util.StatusUtils
-
If namespace 0.1 is used and backward support is true, SUCCEEDED coord job can be killed
- isValid(String) - Method in class org.apache.oozie.service.CallbackService
-
Return if a callback URL is valid or not.
- isValid(int) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- isValidIdentifier(String) - Static method in class org.apache.oozie.util.ParamChecker
-
Return if the specified token is a valid Java identifier.
- isWaiting() - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult
-
- isWarnEnabled() - Method in class org.apache.oozie.util.XLog
-
Return if warn logging is enabled.
- isWrapperFor(Class<?>) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- iterator() - Method in interface org.apache.oozie.sla.SLACalculator
-
- iterator() - Method in class org.apache.oozie.sla.SLACalculatorMemory
-
- iterator() - Method in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
- Pair<T,S> - Class in org.apache.oozie.util
-
Utility class for holding a pair of data
- Pair(T, S) - Constructor for class org.apache.oozie.util.Pair
-
- ParamChecker - Class in org.apache.oozie.util
-
Utility class to check common parameter preconditions.
- ParamChecker() - Constructor for class org.apache.oozie.util.ParamChecker
-
- ParameterInfo(String, Class, boolean, List<String>) - Constructor for class org.apache.oozie.servlet.JsonRestServlet.ParameterInfo
-
Creates a ParameterInfo with querystring parameter definition.
- ParameterVerifier - Class in org.apache.oozie.util
-
Utility class to parse and verify the <parameters> section in a workflow or coordinator job
- ParameterVerifier() - Constructor for class org.apache.oozie.util.ParameterVerifier
-
- ParameterVerifierException - Exception in org.apache.oozie.util
-
- ParameterVerifierException(XException) - Constructor for exception org.apache.oozie.util.ParameterVerifierException
-
Create a ParameterHandler exception from a XException.
- ParameterVerifierException(ErrorCode, Object...) - Constructor for exception org.apache.oozie.util.ParameterVerifierException
-
Create a ParameterHandler exception.
- PARENT_ID - Static variable in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- parentId - Variable in class org.apache.oozie.executor.jpa.WorkflowJobsBasicInfoFromParentId
-
- parse(Element) - Method in class org.apache.oozie.coord.input.logic.InputLogicParser
-
Parses the xml.
- parse(Element, String, String, String) - Method in class org.apache.oozie.coord.input.logic.InputLogicParser
-
- parse(ResultSet) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Create the ResultSetReader
object that has the methods to access the data from the result set
- parseBulkFilter(String) - Static method in class org.apache.oozie.BundleEngine
-
Parse filter string to a map with key = filter name and values = filter values
Allowed keys are defined as constants on top
- parseChangeValue(String) - Static method in class org.apache.oozie.util.JobUtils
-
This Function will parse the value of the changed values in key value manner.
- parseDateOozieTZ(String) - Static method in class org.apache.oozie.util.DateUtils
-
Parses a datetime in ISO8601 format in the Oozie processing timezone.
- parseDateUTC(String) - Static method in class org.apache.oozie.util.DateUtils
-
Parses a datetime in ISO8601 format in UTC timezone
- parseDef(Configuration) - Method in class org.apache.oozie.service.LiteWorkflowAppService
-
Parse workflow definition.
- parseDef(Configuration, Configuration) - Method in class org.apache.oozie.service.LiteWorkflowAppService
-
- parseDef(String, Configuration) - Method in class org.apache.oozie.service.LiteWorkflowAppService
-
- parseDef(String, Configuration, Configuration) - Method in class org.apache.oozie.service.LiteWorkflowAppService
-
- parseDef(Configuration) - Method in class org.apache.oozie.service.WorkflowAppService
-
Parse workflow definition.
- parseDef(Configuration, Configuration) - Method in class org.apache.oozie.service.WorkflowAppService
-
Parse workflow definition along with config-default.xml config
- parseDef(String, Configuration) - Method in class org.apache.oozie.service.WorkflowAppService
-
Parse workflow definition.
- parseDef(String, Configuration, Configuration) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowLib
-
- parseDef(String, Configuration, Configuration) - Method in interface org.apache.oozie.workflow.WorkflowLib
-
Parse a workflow application definition.
- parseFilter(String) - Method in class org.apache.oozie.DagEngine
-
Validate a jobs filter.
- parseFilter(String) - Static method in class org.apache.oozie.FilterParser
-
Parse filter string to a map with key = filter name and values = filter values
- parseFilter(String, Set<String>) - Method in class org.apache.oozie.servlet.SLAServlet
-
- parseFilter(String) - Static method in class org.apache.oozie.util.JobsFilterUtils
-
- parseJobFilter(String) - Method in class org.apache.oozie.CoordinatorEngine
-
- parseJobXmlAndConfiguration(ActionExecutor.Context, Element, Path, Configuration) - Static method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- parseJobXmlAndConfiguration(ActionExecutor.Context, Element, Path, Configuration, boolean) - Static method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- parseNextLogLine() - Method in class org.apache.oozie.util.SimpleTimestampedMessageParser
-
This implementation simply returns the next line from the Reader.
- parseNextLogLine() - Method in class org.apache.oozie.util.TimestampedMessageParser
-
Reads the next line from the Reader and checks if it matches the filter.
- parseOneArg(String) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
- parseOneStringArg(String) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
- parseWithName(Element, String) - Method in class org.apache.oozie.coord.input.logic.InputLogicParser
-
Parses the xml with name.
- parseXml(String) - Static method in class org.apache.oozie.util.XmlUtils
-
Parse a string assuming it is a valid XML document and return an JDOM Element for it.
- parseXml(InputStream) - Static method in class org.apache.oozie.util.XmlUtils
-
Parse a inputstream assuming it is a valid XML document and return an JDOM Element for it.
- partitionAvailable(String, String, String, Map<String, String>) - Method in class org.apache.oozie.service.PartitionDependencyManagerService
-
Mark a partition dependency as available
- PartitionDependencyManagerService - Class in org.apache.oozie.service
-
Module that functions like a caching service to maintain partition dependency mappings
- PartitionDependencyManagerService() - Constructor for class org.apache.oozie.service.PartitionDependencyManagerService
-
- pathExists(String, Configuration, String) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
- pathExists(String, Configuration) - Static method in class org.apache.oozie.command.coord.CoordCommandUtils
-
- pathExists(CoordinatorActionBean, String, Configuration, String) - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- pathExists(String, Configuration) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseOne
-
- pathExists(String, Configuration) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorPhaseThree
-
- pauseChildren() - Method in class org.apache.oozie.command.bundle.BundlePauseXCommand
-
- pauseChildren() - Method in class org.apache.oozie.command.coord.CoordPauseXCommand
-
- pauseChildren() - Method in class org.apache.oozie.command.PauseTransitionXCommand
-
pause actions associated with the job
- PauseTransitionXCommand - Class in org.apache.oozie.command
-
Transition command for pause the job.
- PauseTransitionXCommand(String, String, int) - Constructor for class org.apache.oozie.command.PauseTransitionXCommand
-
- PauseTransitRunnable() - Constructor for class org.apache.oozie.service.PauseTransitService.PauseTransitRunnable
-
- PauseTransitService - Class in org.apache.oozie.service
-
PauseTransitService is the runnable which is scheduled to run at the configured interval, it checks all bundles to
see if they should be paused, un-paused or started.
- PauseTransitService() - Constructor for class org.apache.oozie.service.PauseTransitService
-
- PauseTransitService.PauseTransitRunnable - Class in org.apache.oozie.service
-
PauseTransitRunnable is the runnable which is scheduled to run at the configured interval, it checks all bundles
to see if they should be paused, un-paused or started.
- PB - Static variable in class org.apache.oozie.util.ELConstantsFunctions
-
PetaByte constant (1024 TB).
- PB - Static variable in class org.apache.oozie.util.PropertiesUtils
-
- peek() - Method in interface org.apache.oozie.event.EventQueue
-
Read topmost event from queue but do not pop from it
- peek() - Method in class org.apache.oozie.event.MemoryEventQueue
-
- peek() - Method in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
Retrieve, but does not remove, the head of this queue, or returns null if this queue is empty.
- performWrites() - Method in class org.apache.oozie.command.bundle.BundleJobResumeXCommand
-
- performWrites() - Method in class org.apache.oozie.command.bundle.BundleJobSuspendXCommand
-
- performWrites() - Method in class org.apache.oozie.command.bundle.BundleKillXCommand
-
- performWrites() - Method in class org.apache.oozie.command.bundle.BundlePauseXCommand
-
- performWrites() - Method in class org.apache.oozie.command.bundle.BundleRerunXCommand
-
- performWrites() - Method in class org.apache.oozie.command.bundle.BundleStartXCommand
-
- performWrites() - Method in class org.apache.oozie.command.bundle.BundleSubmitXCommand
-
- performWrites() - Method in class org.apache.oozie.command.bundle.BundleUnpauseXCommand
-
- performWrites() - Method in class org.apache.oozie.command.coord.CoordActionsIgnoreXCommand
-
- performWrites() - Method in class org.apache.oozie.command.coord.CoordActionsKillXCommand
-
- performWrites() - Method in class org.apache.oozie.command.coord.CoordKillXCommand
-
- performWrites() - Method in class org.apache.oozie.command.coord.CoordMaterializeTransitionXCommand
-
- performWrites() - Method in class org.apache.oozie.command.coord.CoordPauseXCommand
-
- performWrites() - Method in class org.apache.oozie.command.coord.CoordRerunXCommand
-
- performWrites() - Method in class org.apache.oozie.command.coord.CoordResumeXCommand
-
- performWrites() - Method in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- performWrites() - Method in class org.apache.oozie.command.coord.CoordSuspendXCommand
-
- performWrites() - Method in class org.apache.oozie.command.coord.CoordUnpauseXCommand
-
- performWrites() - Method in class org.apache.oozie.command.TransitionXCommand
-
This will be used to perform atomically all the writes within this command.
- persist(WorkflowActionNode) - Method in interface org.apache.oozie.util.graph.GraphRenderer
-
- persist(WorkflowActionNode) - Method in class org.apache.oozie.util.graph.GraphvizRenderer
-
- PersistenceExceptionSubclassFilterRetryPredicate - Class in org.apache.oozie.util.db
-
- PersistenceExceptionSubclassFilterRetryPredicate() - Constructor for class org.apache.oozie.util.db.PersistenceExceptionSubclassFilterRetryPredicate
-
- ph1_coord_absolute_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_actionId_echo() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_actualTime_echo_wrap() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_current_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_currentRange_echo(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_databaseIn_echo(String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
Echo the same EL function without evaluating anything
- ph1_coord_databaseOut_echo(String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
- ph1_coord_dataIn_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_dataInPartitionFilter_echo(String, String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
- ph1_coord_dataInPartitionMax_echo(String, String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
- ph1_coord_dataInPartitionMin_echo(String, String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
- ph1_coord_dataInPartitions_echo(String, String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
- ph1_coord_dataOut_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_dataOutPartitions_echo(String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
- ph1_coord_dataOutPartitionValue_echo(String, String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
- ph1_coord_dateOffset_echo(String, String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_dateTzOffset_echo(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_days(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Used in defining the frequency in 'day' unit.
- ph1_coord_daysInMonth_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_endOfDays(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Used in defining the frequency in 'day' unit and specify the "end of day" property.
- ph1_coord_endOfDays_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_endOfMonths(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Used in defining the frequency in 'month' unit and specify the "end of month" property.
- ph1_coord_endOfMonths_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_endOfWeeks(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Used in defining the frequency in 'week' unit and specify the "end of
week" property.
- ph1_coord_endOfWeeks_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_epochTime_echo(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_formatTime_echo(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_future_echo(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_futureRange_echo(String, String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_hours(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Used in defining the frequency in 'hour' unit.
- ph1_coord_hoursInDay_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_latest_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_latestRange_echo(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_minutes(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Used in defining the frequency in 'minute' unit.
- ph1_coord_months(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Used in defining the frequency in 'month' unit.
- ph1_coord_name_echo() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_nominalTime_echo() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_nominalTime_echo_fixed() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_nominalTime_echo_wrap() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_offset_echo(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph1_coord_tableIn_echo(String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
- ph1_coord_tableOut_echo(String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
- ph1_coord_tzOffset_echo() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_absolute_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_absolute_range(String, int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_actionId() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Return Action Id.
- ph2_coord_actualTime() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Return Action Start time.
- ph2_coord_current(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Determine the date-time in Oozie processing timezone of n-th dataset instance.
- ph2_coord_current_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_currentRange(int, int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Determine the date-time in Oozie processing timezone of current dataset instances
from start to end offsets from the nominal time.
- ph2_coord_currentRange_echo(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_dateOffset(String, int, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Returns a date string that is offset from 'strBaseDate' by the amount specified.
- ph2_coord_dateTzOffset(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Returns a date string that is offset from 'strBaseDate' by the difference from Oozie processing timezone to the given
timezone.
- ph2_coord_daysInMonth(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Calculate number of days in one month for n-th dataset instance.
- ph2_coord_endOfDays_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_endOfMonths_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_endOfWeeks_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_epochTime(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Convert from standard date-time formatting to a Unix epoch time.
- ph2_coord_formatTime(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Convert from standard date-time formatting to a desired format.
- ph2_coord_future_echo(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_futureRange_echo(String, String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_hoursInDay(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Determine how many hours is on the date of n-th dataset instance.
- ph2_coord_latest_echo(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_latestRange_echo(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_name() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Return Job Name.
- ph2_coord_nominalTime() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Return nominal time or Action Creation Time.
- ph2_coord_offset(int, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Determine the date-time in Oozie processing timezone of the given offset from the dataset effective nominal time.
- ph2_coord_offset_echo(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph2_coord_tzOffset() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Calculate the difference of timezone offset in minutes between dataset and coordinator job.
- ph3_coord_actionId() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph3_coord_actualTime() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph3_coord_databaseIn(String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
Extract the hcat DB name from the URI-template associate with
'dataInName'.
- ph3_coord_databaseOut(String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
Extract the hcat DB name from the URI-template associate with
'dataOutName'.
- ph3_coord_dataIn(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Used to specify a list of URI's that are used as input dir to the workflow job.
- ph3_coord_dataInPartitionFilter(String, String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
Used to specify the HCat partition filter which is input dependency for workflow job.
- ph3_coord_dataInPartitionMax(String, String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
Used to specify the MINIMUM value of an HCat partition which is input dependency for workflow job.
- ph3_coord_dataInPartitionMin(String, String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
Used to specify the MAXIMUM value of an HCat partition which is input dependency for workflow job.
- ph3_coord_dataInPartitions(String, String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
Used to specify the entire HCat partition defining input for workflow job.
- ph3_coord_dataOut(String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Used to specify a list of URI's that are output dir of the workflow job.
- ph3_coord_dataOutPartitions(String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
Used to specify the entire HCat partition defining output for workflow job.
- ph3_coord_dataOutPartitionValue(String, String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
Used to specify the HCat partition's value defining output for workflow job.
- ph3_coord_dateOffset(String, int, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph3_coord_dateTzOffset(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph3_coord_daysInMonth(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph3_coord_epochTime(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph3_coord_formatTime(String, String) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph3_coord_future(int, int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Determine the date-time in Oozie processing timezone of n-th future available dataset instance
from nominal Time but not beyond the instance specified as 'instance.
- ph3_coord_futureRange(int, int, int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Determine the date-time in Oozie processing timezone of the future available dataset instances
from start to end offsets from nominal Time but not beyond the instance specified as 'instance'.
- ph3_coord_hoursInDay(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph3_coord_latest(int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Determine the date-time in Oozie processing timezone of n-th latest available dataset instance.
- ph3_coord_latestRange(int, int) - Static method in class org.apache.oozie.coord.CoordELFunctions
-
Determine the date-time in Oozie processing timezone of latest available dataset instances
from start to end offsets from the nominal time.
- ph3_coord_name() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph3_coord_nominalTime() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- ph3_coord_tableIn(String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
Extract the hcat Table name from the URI-template associate with
'dataInName'.
- ph3_coord_tableOut(String) - Static method in class org.apache.oozie.coord.HCatELFunctions
-
Extract the hcat Table name from the URI-template associate with
'dataOutName'.
- ph3_coord_tzOffset() - Static method in class org.apache.oozie.coord.CoordELFunctions
-
- PigActionExecutor - Class in org.apache.oozie.action.hadoop
-
- PigActionExecutor() - Constructor for class org.apache.oozie.action.hadoop.PigActionExecutor
-
- poll() - Method in interface org.apache.oozie.event.EventQueue
-
Fetch single event from queue
- poll() - Method in class org.apache.oozie.event.MemoryEventQueue
-
- poll() - Method in class org.apache.oozie.util.PollablePriorityDelayQueue
-
Retrieve and remove the head of this queue if it is eligible to poll.
- poll() - Method in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
Retrieve and remove the head of this queue, or return null if this queue has no elements with an expired
delay.
- poll(long, TimeUnit) - Method in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
Retrieve and removes the head of this queue, waiting up to the
specified wait time if necessary for an element to become available.
- PollablePriorityDelayQueue<E> - Class in org.apache.oozie.util
-
- PollablePriorityDelayQueue(int, long, TimeUnit, int) - Constructor for class org.apache.oozie.util.PollablePriorityDelayQueue
-
- pollBatch() - Method in interface org.apache.oozie.event.EventQueue
-
Fetch events from queue in batch
- pollBatch() - Method in class org.apache.oozie.event.MemoryEventQueue
-
- populateOozieMode(JSONObject) - Method in class org.apache.oozie.servlet.BaseAdminServlet
-
- populateOozieMode(JSONObject) - Method in class org.apache.oozie.servlet.V0AdminServlet
-
- populateOozieMode(JSONObject) - Method in class org.apache.oozie.servlet.V1AdminServlet
-
- PreconditionException - Exception in org.apache.oozie.command
-
- PreconditionException(XException) - Constructor for exception org.apache.oozie.command.PreconditionException
-
Create a verifyXCommand exception for verify conditions purposes.
- PreconditionException(ErrorCode, Object...) - Constructor for exception org.apache.oozie.command.PreconditionException
-
Create a verifyXCommand exception for verify conditions purposes.
- prepare(PreparedStatement) - Method in class org.apache.oozie.util.db.SqlStatement
-
Assign the values to Prepared Statement.
- prepare(Connection) - Method in class org.apache.oozie.util.db.SqlStatement
-
Prepare the SQL Statement.
- prepareActionDir(FileSystem, ActionExecutor.Context) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- prepareAndSetValues(Connection) - Method in class org.apache.oozie.util.db.SqlStatement
-
Prepare the SQL Statement that is generated and assign the values to prepared statement.
- prepareCall(String) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- prepareCall(String, int, int) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- prepareCall(String, int, int, int) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- prepareForBatch(Connection, List<? extends Map<Object, Object>>, PreparedStatement) - Method in class org.apache.oozie.util.db.SqlStatement
-
Preparing Multiple statements for batch execution.
- prepareStatement(String) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- prepareStatement(String, int, int) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- prepareStatement(String, int, int, int) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- prepareStatement(String, int) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- prepareStatement(String, int[]) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- prepareStatement(String, String[]) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- prettyPrint(Element) - Static method in class org.apache.oozie.util.XmlUtils
-
Return a pretty print string for a JDOM Element.
- prettyPrint(String) - Static method in class org.apache.oozie.util.XmlUtils
-
Return a pretty print string for a XML string.
- prettyPrint(Configuration) - Static method in class org.apache.oozie.util.XmlUtils
-
Return a pretty print string for a Configuration object.
- prevPending - Variable in class org.apache.oozie.command.bundle.BundleRerunXCommand
-
- prevPending - Variable in class org.apache.oozie.command.coord.CoordRerunXCommand
-
- prevStatus - Variable in class org.apache.oozie.command.RerunTransitionXCommand
-
- PRIORITIES - Static variable in class org.apache.oozie.service.CallableQueueService
-
- priorities - Variable in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
- PriorityComparator() - Constructor for class org.apache.oozie.service.AsyncXCommandExecutor.PriorityComparator
-
- PriorityDelayQueue<E> - Class in org.apache.oozie.util
-
- PriorityDelayQueue(int, long, TimeUnit, int) - Constructor for class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
Create a PriorityDelayQueue
.
- PriorityDelayQueue.QueueElement<E> - Class in org.apache.oozie.util
-
Deprecated.
Element wrapper required by the queue.
- process(Message) - Method in class org.apache.oozie.dependency.hcat.HCatMessageHandler
-
Process JMS message produced by HCat.
- process(Message) - Method in interface org.apache.oozie.jms.MessageHandler
-
Process a generic JMS message.
- processCallback(String, String, Properties) - Method in class org.apache.oozie.DagEngine
-
Process an action callback.
- processRemaining(Writer, XLogStreamer) - Method in class org.apache.oozie.util.TimestampedMessageParser
-
Streams log messages to the passed in Writer, with zero bytes already
written
- propertiesToString(Properties) - Static method in class org.apache.oozie.util.PropertiesUtils
-
- PropertiesUtils - Class in org.apache.oozie.util
-
- PropertiesUtils() - Constructor for class org.apache.oozie.util.PropertiesUtils
-
- proxyConf - Variable in class org.apache.oozie.command.NotificationXCommand
-
- ProxyUserService - Class in org.apache.oozie.service
-
The ProxyUserService checks if a user of a request has proxyuser privileges.
- ProxyUserService() - Constructor for class org.apache.oozie.service.ProxyUserService
-
- purge(long, int) - Method in class org.apache.oozie.store.WorkflowStore
-
Purge the Workflows Completed older than given days.
- PURGE_COMMAND_ENABLED - Static variable in class org.apache.oozie.service.PurgeService
-
- PURGE_INTERVAL - Static variable in class org.apache.oozie.service.ShareLibService
-
- PURGE_LIMIT - Static variable in class org.apache.oozie.service.PurgeService
-
- PURGE_OLD_COORD_ACTION - Static variable in class org.apache.oozie.service.PurgeService
-
- PurgeService - Class in org.apache.oozie.service
-
The PurgeService schedules purging of completed jobs and associated action older than a specified age for workflow,
coordinator and bundle.
- PurgeService() - Constructor for class org.apache.oozie.service.PurgeService
-
- PurgeXCommand - Class in org.apache.oozie.command
-
This class is used to purge workflows, coordinators, and bundles.
- PurgeXCommand(int, int, int, int) - Constructor for class org.apache.oozie.command.PurgeXCommand
-
- PurgeXCommand(int, int, int, int, boolean) - Constructor for class org.apache.oozie.command.PurgeXCommand
-
- put(PriorityDelayQueue.QueueElement<E>) - Method in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
Insert the specified element into this queue, waiting if necessary
for space to become available.
- SAFE_MODE_DELAY - Static variable in class org.apache.oozie.service.CallableQueueService
-
- Sampler(Instrumentation.Variable<Long>, Histogram) - Constructor for class org.apache.oozie.util.MetricsInstrumentation.Sampler
-
- SASLOwnerACLProvider() - Constructor for class org.apache.oozie.util.ZKUtils.SASLOwnerACLProvider
-
- SAX_FEATURE_DISALLOW_DOCTYPE_DECL - Static variable in class org.apache.oozie.util.graph.GraphGenerator
-
- SAX_FEATURE_EXTERNAL_GENERAL_ENTITIES - Static variable in class org.apache.oozie.util.graph.GraphGenerator
-
- SAX_FEATURE_EXTERNAL_PARAMETER_ENTITIES - Static variable in class org.apache.oozie.util.graph.GraphGenerator
-
- sb - Variable in class org.apache.oozie.util.db.SqlStatement.Condition
-
- sb - Variable in class org.apache.oozie.util.db.SqlStatement
-
- schedule(Callable<Void>, long, long, SchedulerService.Unit) - Method in class org.apache.oozie.service.SchedulerService
-
Schedule a Callable for execution.
- schedule(Runnable, long, long, SchedulerService.Unit) - Method in class org.apache.oozie.service.SchedulerService
-
Schedule a Runnable for execution.
- schedule(Runnable, long, SchedulerService.Unit) - Method in class org.apache.oozie.service.SchedulerService
-
Schedule a Runnable for execution.
- ScheduledXCallable(CallableQueueService.CallableWrapper<?>) - Constructor for class org.apache.oozie.service.AsyncXCommandExecutor.ScheduledXCallable
-
- SCHEDULER_THREADS - Static variable in class org.apache.oozie.service.SchedulerService
-
- SchedulerService - Class in org.apache.oozie.service
-
This service executes scheduled Runnables and Callables at regular intervals.
- SchedulerService() - Constructor for class org.apache.oozie.service.SchedulerService
-
- SchedulerService.Unit - Enum in org.apache.oozie.service
-
- Schema - Class in org.apache.oozie.util.db
-
- Schema() - Constructor for class org.apache.oozie.util.db.Schema
-
- Schema.Column - Interface in org.apache.oozie.util.db
-
Interface or table columns
- Schema.DBType - Enum in org.apache.oozie.util.db
-
DB types
- Schema.Index - Interface in org.apache.oozie.util.db
-
Interface for Index
- Schema.Table - Interface in org.apache.oozie.util.db
-
Interface for DB Table
- SchemaCheckerService - Class in org.apache.oozie.service
-
- SchemaCheckerService() - Constructor for class org.apache.oozie.service.SchemaCheckerService
-
- SchemaCheckXCommand - Class in org.apache.oozie.command
-
- SchemaCheckXCommand(String, String, String, String, boolean) - Constructor for class org.apache.oozie.command.SchemaCheckXCommand
-
- SchemaService - Class in org.apache.oozie.service
-
Service that loads Oozie workflow definition schema and registered extension
schemas.
- SchemaService() - Constructor for class org.apache.oozie.service.SchemaService
-
- SchemaService.SchemaName - Enum in org.apache.oozie.service
-
- SCP_COMMAND_BASE - Static variable in class org.apache.oozie.action.ssh.SshActionExecutor
-
- ScriptLanguageActionExecutor - Class in org.apache.oozie.action.hadoop
-
- ScriptLanguageActionExecutor(String) - Constructor for class org.apache.oozie.action.hadoop.ScriptLanguageActionExecutor
-
- SEARCH_TEXT - Static variable in class org.apache.oozie.util.XLogUserFilterParam
-
- selectAllFrom(Schema.Table...) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Return a Select All Statement
- selectColumns(Schema.Column...) - Static method in class org.apache.oozie.util.db.SqlStatement
-
Return a Select Statement
- sendErrorResponse(HttpServletResponse, int, String, String) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Sends a error response.
- sendInstrumentationResponse(HttpServletResponse, Instrumentation) - Method in class org.apache.oozie.servlet.BaseAdminServlet
-
- sendInstrumentationResponse(HttpServletResponse, Instrumentation) - Method in class org.apache.oozie.servlet.V2AdminServlet
-
- sendJMSMessage(SLAMessage, String, String, String) - Method in class org.apache.oozie.jms.JMSSLAEventListener
-
- sendJsonResponse(HttpServletResponse, int, JsonBean, String) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Sends a JSON response.
- sendJsonResponse(HttpServletResponse, int, JSONStreamAware) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
- sendMail(String) - Method in class org.apache.oozie.service.AbandonedCoordCheckerService.AbandonedCoordCheckerRunnable
-
- sendMessage(Map<String, String>, String, String, String) - Method in class org.apache.oozie.jms.JMSJobEventListener
-
- sendMetricsResponse(HttpServletResponse) - Method in class org.apache.oozie.servlet.BaseAdminServlet
-
- sendMetricsResponse(HttpServletResponse) - Method in class org.apache.oozie.servlet.V0AdminServlet
-
- sendMetricsResponse(HttpServletResponse) - Method in class org.apache.oozie.servlet.V1AdminServlet
-
- sendMetricsResponse(HttpServletResponse) - Method in class org.apache.oozie.servlet.V2AdminServlet
-
- sendNotification() - Method in class org.apache.oozie.command.NotificationXCommand
-
- sendSLANotification(SLAEvent) - Method in class org.apache.oozie.jms.JMSSLAEventListener
-
- SEPARATOR - Static variable in class org.apache.oozie.action.hadoop.OozieJobInfo
-
- serialize() - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- serialize() - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Serialize.
- serialize() - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- serialize(ServiceInstance<T>) - Method in class org.apache.oozie.util.FixedJsonInstanceSerializer
-
- SERVER_SERVER_AUTH_TYPE - Static variable in class org.apache.oozie.util.AuthUrlClient
-
- SERVER_SERVER_CONNECTION_TIMEOUT_SECONDS - Static variable in class org.apache.oozie.util.AuthUrlClient
-
- Service - Interface in org.apache.oozie.service
-
A service is component managed by the
Services
singleton.
- service(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Dispatches to super after loginfo and intrumentation handling.
- ServiceException - Exception in org.apache.oozie.service
-
- ServiceException(XException) - Constructor for exception org.apache.oozie.service.ServiceException
-
Create an service exception from a XException.
- ServiceException(ErrorCode, Object...) - Constructor for exception org.apache.oozie.service.ServiceException
-
Create a service exception.
- Services - Class in org.apache.oozie.service
-
Services is a singleton that manages the lifecycle of all registered
Services
.
- Services() - Constructor for class org.apache.oozie.service.Services
-
Create a services.
- ServicesLoader - Class in org.apache.oozie.servlet
-
Webapp context listener that initializes Oozie
Services
.
- ServicesLoader() - Constructor for class org.apache.oozie.servlet.ServicesLoader
-
- ServletUtilities - Class in org.apache.oozie.servlet
-
- ServletUtilities() - Constructor for class org.apache.oozie.servlet.ServletUtilities
-
- SESSION_OPTS - Static variable in class org.apache.oozie.service.JMSAccessorService
-
- set(Credentials, Configuration, String, String) - Method in class org.apache.oozie.action.hadoop.HCatCredentialHelper
-
This Function will set the HCat token to the credentials
- set(String, Object) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorUtil.OozieJexlParser
-
- set(String, String) - Static method in class org.apache.oozie.service.ConfigurationService
-
- set(Schema.Column, Object) - Method in class org.apache.oozie.util.db.SqlStatement.Update
-
SET clause for update statement
- setAction(CoordinatorActionBean) - Method in class org.apache.oozie.client.rest.BulkResponseImpl
-
Sets the coord action comprising this bulk response object
- setAction(WorkflowActionBean) - Method in class org.apache.oozie.CoordinatorWfActionBean
-
- setActionCompletionData(ActionExecutor.Context, FileSystem) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
Sets some data for the action on completion
- setActionId(String) - Method in class org.apache.oozie.coord.SyncCoordAction
-
- setActionInfo(WorkflowInstance, WorkflowAction) - Static method in class org.apache.oozie.DagELFunctions
-
- setActionList(boolean) - Method in class org.apache.oozie.util.XLogFilter
-
- setActionNumber(int) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setActionNumber(int) - Method in class org.apache.oozie.CoordinatorWfActionBean
-
- setActions(List<CoordinatorActionBean>) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setActions(List<WorkflowActionBean>) - Method in class org.apache.oozie.WorkflowJobBean
-
- setActionTokenProperties(Configuration) - Method in class org.apache.oozie.action.hadoop.DistcpActionExecutor
-
Extracts information required for DistCp action between secure clusters (in the same or distinct Kerberos realms)
- setActionTokenProperties(Configuration) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
Subclasses may override this method in order to take additional actions required for obtaining credential token(s).
- setActionXml(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setActionXmlBlob(StringBlob) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setActualDuration(long) - Method in class org.apache.oozie.sla.SLACalcStatus
-
- setActualDuration(long) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setActualEnd(Date) - Method in class org.apache.oozie.sla.SLACalcStatus
-
- setActualEnd(Date) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setActualStart(Date) - Method in class org.apache.oozie.sla.SLACalcStatus
-
- setActualStart(Date) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setActualTime(Date) - Method in class org.apache.oozie.coord.SyncCoordAction
-
- setAlertContact(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setAlertContact(String) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setAlertEvents(String) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setAlertFrequency(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setAlertPercentage(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setAllowSafeModeChanges(boolean) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Enable HTTP POST/PUT/DELETE methods while in safe mode.
- setAllVars(Map<String, String>) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- setAllVars(Map<String, String>) - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Add a set of variables in the context of the instance.
- setAppName(String) - Method in class org.apache.oozie.BundleJobBean
-
Set bundleName
- setAppName(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setAppName(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setAppName(String) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setAppName(String) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setAppName(String) - Method in class org.apache.oozie.WorkflowJobBean
-
- setAppNamespace(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set app namespce
- setAppPath(String) - Method in class org.apache.oozie.BundleJobBean
-
Set bundlePath
- setAppPath(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setAppPath(String) - Method in class org.apache.oozie.WorkflowJobBean
-
- setAppType(SLAEvent.SlaAppType) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setAppType(AppType) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setAppType(AppType) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setAppType(SLAEvent.SlaAppType) - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- setAppTypes(Set<String>) - Method in class org.apache.oozie.service.EventHandlerService
-
- setAppTypeStr(String) - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- setAutoCommit(boolean) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setAvailability(boolean) - Method in class org.apache.oozie.coord.input.dependency.CoordInputInstance
-
- setBoolean(String, boolean) - Static method in class org.apache.oozie.service.ConfigurationService
-
- setBundle(BundleJobBean) - Method in class org.apache.oozie.client.rest.BulkResponseImpl
-
Sets the bundle comprising this bulk response object
- setBundleActionId(String) - Method in class org.apache.oozie.BundleActionBean
-
bundleActionId to set
- setBundleId(String) - Method in class org.apache.oozie.BundleActionBean
-
Set the Bundle Id.
- setBundleId(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setBytes(byte[]) - Method in class org.apache.oozie.BinaryBlob
-
Set bytes
- setCatalog(String) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setClientInfo(String, String) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setClientInfo(Properties) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setConcurrency(int) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setConf(String) - Method in class org.apache.oozie.BundleJobBean
-
Set conf
- setConf(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setConf(Configuration) - Static method in class org.apache.oozie.util.DateUtils
-
Configures the Datetime parsing with Oozie processing timezone.
- setConf(String) - Method in class org.apache.oozie.WorkflowActionBean
-
- setConf(String) - Method in class org.apache.oozie.WorkflowJobBean
-
- setConfBlob(StringBlob) - Method in class org.apache.oozie.BundleJobBean
-
- setConfBlob(StringBlob) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setConfBlob(StringBlob) - Method in class org.apache.oozie.WorkflowActionBean
-
- setConfBlob(StringBlob) - Method in class org.apache.oozie.WorkflowJobBean
-
- setConsoleUrl(String) - Method in class org.apache.oozie.BundleJobBean
-
Set consoleUrl
- setConsoleUrl(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setConsoleUrl(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set the coordinate application console URL.
- setConsoleUrl(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set console URL
- setConsoleUrl(String) - Method in class org.apache.oozie.WorkflowJobBean
-
Set the workflow job console URL.
- setCoordId(String) - Method in class org.apache.oozie.BundleActionBean
-
Set the coordinator Id.
- setCoordinator(CoordinatorJobBean) - Method in class org.apache.oozie.client.rest.BulkResponseImpl
-
Sets the coordinator comprising this bulk response object
- setCoordJobs(List<CoordinatorJobBean>) - Method in class org.apache.oozie.BundleJobBean
-
Set coordJobs
- setCoordName(String) - Method in class org.apache.oozie.BundleActionBean
-
Set the Coordinator name.
- setCpuMonitorTime(String) - Method in class org.apache.oozie.servlet.JVMInfo
-
- setCreatedConf(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setCreatedConfBlob(StringBlob) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setCreatedTime(Date) - Method in class org.apache.oozie.BundleJobBean
-
- setCreatedTime(Date) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setCreatedTime(Date) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set created time
- setCreatedTime(Date) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setCreatedTime(Date) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setCreatedTime(Date) - Method in class org.apache.oozie.WorkflowActionBean
-
- setCreatedTime(Date) - Method in class org.apache.oozie.WorkflowJobBean
-
- setCreatedTimestamp(Timestamp) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setCreatedTimestamp(Timestamp) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setCred(String) - Method in class org.apache.oozie.WorkflowActionBean
-
- setCredentialTokens(Credentials, Configuration, ActionExecutor.Context, WorkflowAction, Map<String, CredentialsProperties>) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- setCritical() - Method in class org.apache.oozie.BundleActionBean
-
Set that this bundle action is critical.
- setData(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set data
- setDataBlob(StringBlob) - Method in class org.apache.oozie.WorkflowActionBean
-
- setDataSets(String) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult
-
- setDateInput(Date) - Method in class org.apache.oozie.executor.jpa.CoordJobsToBeMaterializedJPAExecutor
-
- setDbPredicate(Predicate) - Static method in class org.apache.oozie.util.db.FailingDBHelperForTest
-
change the used predicate value
- setDelay(long, TimeUnit) - Method in class org.apache.oozie.util.PriorityDelayQueue.QueueElement
-
Deprecated.
Set the delay of the element.
- setDeleteList(Collection<String>) - Method in class org.apache.oozie.executor.jpa.BundleJobsDeleteJPAExecutor
-
Sets the delete list for BundleJobBeans
- setDeleteList(Collection<String>) - Method in class org.apache.oozie.executor.jpa.CoordActionsDeleteJPAExecutor
-
Sets the delete list for CoordinatorActionBeans
- setDeleteList(Collection<String>) - Method in class org.apache.oozie.executor.jpa.CoordJobsDeleteJPAExecutor
-
Sets the delete list for CoordinatorJobBeans
- setDeleteList(Collection<String>) - Method in class org.apache.oozie.executor.jpa.WorkflowJobsDeleteJPAExecutor
-
Sets the delete list for WorkflowJobBeans
- setDependencyMap(Map<String, List<CoordInputInstance>>) - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- setDependencyMet(boolean) - Method in class org.apache.oozie.coord.input.dependency.AbstractCoordInputDependency
-
- setDependencyMet(boolean) - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Sets the dependency meet.
- setDependencyMet(boolean) - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- setDescendingOrder(boolean) - Method in class org.apache.oozie.executor.jpa.sla.SLASummaryGetForFilterJPAExecutor
-
- setDevContact(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setDoneFlag(String) - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- setDoneMaterialization() - Method in class org.apache.oozie.CoordinatorJobBean
-
Set doneMaterialization to true
- setDoneMaterialization(int) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set doneMaterialization
- setEndData(WorkflowAction.Status, String) - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Set the action end completion information for a completed action.
- setEndData(WorkflowAction.Status, String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- setEndData(WorkflowAction.Status, String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set the completion information for an action end.
- setEnded(boolean) - Method in class org.apache.oozie.command.sla.SLAJobEventXCommand
-
- setEndMiss(boolean) - Method in class org.apache.oozie.command.sla.SLAJobEventXCommand
-
- setEndOfDuration(TimeUnit) - Method in class org.apache.oozie.coord.SyncCoordAction
-
- setEndOfDuration(TimeUnit) - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- setEndTime(Date) - Method in class org.apache.oozie.BundleJobBean
-
- setEndTime(Date) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setEndTime(Date) - Method in class org.apache.oozie.WorkflowActionBean
-
Set end time
- setEndTime(Date) - Method in class org.apache.oozie.WorkflowJobBean
-
- setEndTimestamp(Timestamp) - Method in class org.apache.oozie.BundleJobBean
-
- setEndTimestamp(Timestamp) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set end timestamp
- setErrorCode(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setErrorCode(String) - Method in class org.apache.oozie.event.CoordinatorActionEvent
-
- setErrorCode(String) - Method in class org.apache.oozie.event.WorkflowActionEvent
-
- setErrorCode(String) - Method in class org.apache.oozie.event.WorkflowJobEvent
-
- setErrorInfo(String, String) - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
- setErrorInfo(String, String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- setErrorInfo(String, String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setErrorInfo(String, String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set the error Info
- setErrorMessage(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setErrorMessage(String) - Method in class org.apache.oozie.event.CoordinatorActionEvent
-
- setErrorMessage(String) - Method in class org.apache.oozie.event.WorkflowActionEvent
-
- setErrorMessage(String) - Method in class org.apache.oozie.event.WorkflowJobEvent
-
- setEvent_id(long) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setEventProcessed(int) - Method in class org.apache.oozie.sla.SLACalcStatus
-
- setEventProcessed(int) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setEventStatus(SLAEvent.EventStatus) - Method in class org.apache.oozie.sla.SLACalcStatus
-
- setEventStatus(SLAEvent.EventStatus) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setEventType(String) - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- setExceptionListener(ExceptionListener) - Method in interface org.apache.oozie.jms.ConnectionContext
-
Set the exception Listener
- setExceptionListener(ExceptionListener) - Method in class org.apache.oozie.jms.DefaultConnectionContext
-
- setExecution(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set execution order
- setExecutionData(String, Properties) - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Set the action execution completion information for an action.
- setExecutionData(String, Properties) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- setExecutionData(String, Properties) - Method in class org.apache.oozie.WorkflowActionBean
-
Set the completion information for an action start.
- setExecutionOrder(CoordinatorJob.Execution) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set order
- setExecutionPath(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set the node execution path.
- setExecutionStats(String) - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Set execution statistics information for a particular action.
- setExecutionStats(String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- setExecutionStats(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set the action statistics info for the workflow action.
- setExpectedDuration(String, SLARegistrationBean) - Static method in class org.apache.oozie.sla.SLAOperations
-
- setExpectedDuration(long) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setExpectedDuration(long) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setExpectedEnd(Date) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setExpectedEnd(String, Date, SLARegistrationBean) - Static method in class org.apache.oozie.sla.SLAOperations
-
- setExpectedEnd(Date) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setExpectedEnd(Date) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setExpectedEnd(Date) - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- setExpectedStart(Date) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setExpectedStart(String, Date, SLARegistrationBean) - Static method in class org.apache.oozie.sla.SLAOperations
-
- setExpectedStart(Date) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setExpectedStart(Date) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setExpectedStart(Date) - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- setExternalChildIDs(String) - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Set external child IDs for a particular action (Eg: pig).
- setExternalChildIDs(String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- setExternalChildIDs(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set the external child IDs for the workflow action.
- setExternalChildIDsBlob(StringBlob) - Method in class org.apache.oozie.WorkflowActionBean
-
Set external child ids
- setExternalId(String) - Method in class org.apache.oozie.BundleJobBean
-
Set externalId
- setExternalId(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setExternalId(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setExternalId(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set external Id
- setExternalId(String) - Method in class org.apache.oozie.WorkflowJobBean
-
- setExternalStatus(String) - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Sets the external status for the action in context.
- setExternalStatus(String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- setExternalStatus(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setExternalStatus(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set external status
- setFileNamePattern(String) - Method in class org.apache.oozie.util.OozieRollingPolicy
-
- setFilterPattern(Pattern) - Method in class org.apache.oozie.util.XLogFilter
-
- setFrequency(String) - Method in class org.apache.oozie.coord.SyncCoordAction
-
- setFrequency(int) - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- setFrequency(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setGroup(String) - Method in class org.apache.oozie.BundleJobBean
-
Set group
- setGroup(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setGroup(String) - Method in class org.apache.oozie.WorkflowJobBean
-
- setGroupName(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setHadoopId(String) - Method in class org.apache.oozie.event.WorkflowActionEvent
-
- setHoldability(int) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setId(String) - Method in class org.apache.oozie.BundleJobBean
-
Set id
- setId(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setId(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setId(String) - Method in class org.apache.oozie.sla.SLACalcStatus
-
- setId(String) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setId(String) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setId(String) - Method in class org.apache.oozie.WorkflowActionBean
-
- setId(String) - Method in class org.apache.oozie.WorkflowJobBean
-
- setInitInstance(Date) - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- setInterruptMode(boolean) - Method in class org.apache.oozie.command.XCommand
-
set the mode of execution for the callable.
- setInterruptMode(boolean) - Method in interface org.apache.oozie.util.XCallable
-
set the mode of execution for the callable.
- setJNDIProperties(Properties) - Method in class org.apache.oozie.client.rest.JMSConnectionInfoBean
-
Set the JNDI properties for jms connection
- setJob(Job) - Method in class org.apache.oozie.command.bundle.BundleJobSuspendXCommand
-
- setJob(Job) - Method in class org.apache.oozie.command.TransitionXCommand
-
Set the Job for the command.
- setJobData(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setJobData(String) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setJobId(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setJobId(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set the job id.
- setJobInfo(boolean) - Static method in class org.apache.oozie.action.hadoop.OozieJobInfo
-
- setJobStatus(SLAEvent.Status) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setJobStatus(Job.Status) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- setJobStatus(String) - Method in class org.apache.oozie.sla.SLACalcStatus
-
- setJobStatus(String) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setJobStatus(SLAEvent.Status) - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- setJobStatusStr(String) - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- setJobXml(String) - Method in class org.apache.oozie.BundleJobBean
-
- setJobXml(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set job xml
- setJobXmlBlob(StringBlob) - Method in class org.apache.oozie.BundleJobBean
-
- setJobXmlBlob(StringBlob) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setKickoffTime(Date) - Method in class org.apache.oozie.BundleJobBean
-
- setKickoffTimestamp(Timestamp) - Method in class org.apache.oozie.BundleJobBean
-
- setLastActionNumber(int) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setLastActionTime(Date) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setLastActionTimestamp(Timestamp) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set last action timestamp
- setLastCheckTime(Date) - Method in class org.apache.oozie.WorkflowActionBean
-
Sets the action last check time
- setLastModifiedTime(Date) - Method in class org.apache.oozie.BundleActionBean
-
Set Last modified time.
- setLastModifiedTime(Date) - Method in class org.apache.oozie.BundleJobBean
-
- setLastModifiedTime(Date) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setLastModifiedTime(Date) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set last modified time
- setLastModifiedTime(Date) - Method in class org.apache.oozie.sla.SLACalcStatus
-
- setLastModifiedTime(Date) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setLastModifiedTime(Date) - Method in class org.apache.oozie.WorkflowJobBean
-
- setLastModifiedTimestamp(Timestamp) - Method in class org.apache.oozie.BundleActionBean
-
Set Last modified time.
- setLastModifiedTimestamp(Timestamp) - Method in class org.apache.oozie.BundleJobBean
-
- setLastModifiedTimestamp(Timestamp) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set last modified timestamp
- setLastSeqId(long) - Method in class org.apache.oozie.command.coord.SLAEventsXCommand
-
Set lastSeqId
- setLibFilesArchives(ActionExecutor.Context, Element, Path, Configuration) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- setLimit(int) - Method in class org.apache.oozie.executor.jpa.CoordJobsToBeMaterializedJPAExecutor
-
- setLine(String) - Method in class org.apache.oozie.util.LogLine
-
- setListInConf(String, Element, Configuration, String, boolean) - Method in class org.apache.oozie.action.hadoop.ShellActionExecutor
-
This method read a list of tag from an XML element and set the
Configuration accordingly
- setLocation(Point) - Method in class org.apache.oozie.util.graph.WorkflowActionNode
-
- setLogInfo() - Method in class org.apache.oozie.command.coord.CoordActionCheckXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.coord.CoordActionReadyXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.coord.CoordActionSkipXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.coord.CoordActionStartXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.coord.CoordActionTimeOutXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.coord.CoordActionUpdateXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.coord.CoordChangeXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.NotificationXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.SLAAlertsXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.wf.ActionCheckXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.wf.ActionEndXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.wf.ActionKillXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.wf.ActionStartXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.wf.CompletedActionXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.wf.DefinitionXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.wf.KillXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.wf.ReRunXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.wf.ResumeXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.wf.SignalXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.wf.SuspendXCommand
-
- setLogInfo() - Method in class org.apache.oozie.command.XCommand
-
Set the thread local logInfo with the context of this command and reset log prefix.
- setLogInfo(String) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Set the thread local log info with the given information.
- setLogInfo(CoordinatorJobBean) - Static method in class org.apache.oozie.util.LogUtils
-
Set the thread local log info with the context of the given coordinator bean.
- setLogInfo(CoordinatorActionBean) - Static method in class org.apache.oozie.util.LogUtils
-
Set the thread local log info with the context of the given coordinator action bean.
- setLogInfo(WorkflowJobBean) - Static method in class org.apache.oozie.util.LogUtils
-
Set the thread local log info with the context of the given workflow bean.
- setLogInfo(WorkflowActionBean) - Static method in class org.apache.oozie.util.LogUtils
-
Set the thread local log info with the context of the given action bean.
- setLogInfo(WorkflowAction) - Static method in class org.apache.oozie.util.LogUtils
-
- setLogInfo(String) - Static method in class org.apache.oozie.util.LogUtils
-
Set the thread local log info with the given id.
- setLogInfo(BundleJobBean) - Static method in class org.apache.oozie.util.LogUtils
-
Set the thread local log info with the context of the given bundle bean.
- setLogInfo(XLog, String, String, String) - Static method in class org.apache.oozie.util.LogUtils
-
- setLogLevel(String) - Method in class org.apache.oozie.util.XLogFilter
-
- setLogParts(ArrayList<String>) - Method in class org.apache.oozie.util.LogLine
-
- setLogPrefix(XLog, Event) - Static method in class org.apache.oozie.util.LogUtils
-
- setLogToken(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set the job log token.
- setLogToken(String) - Method in class org.apache.oozie.WorkflowJobBean
-
- setMatchedPattern(LogLine.MATCHED_PATTERN) - Method in class org.apache.oozie.util.LogLine
-
- setMatThrottling(int) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setMaxHistory(int) - Method in class org.apache.oozie.util.OozieRollingPolicy
-
- setMaxRetries(int) - Method in class org.apache.oozie.action.ActionExecutor
-
Set the maximum number of retries for the action executor.
- setMissingDependencies(String) - Method in interface org.apache.oozie.coord.input.dependency.CoordInputDependency
-
Sets the missing dependencies.
- setMissingDependencies(String) - Method in class org.apache.oozie.coord.input.dependency.CoordOldInputDependency
-
- setMissingDependencies(String) - Method in class org.apache.oozie.coord.input.dependency.CoordPullInputDependency
-
- setMissingDependencies(String) - Method in class org.apache.oozie.coord.input.dependency.CoordPushInputDependency
-
- setMissingDependencies(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setMissingDependenciesBlob(StringBlob) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setMissingDeps(String) - Method in class org.apache.oozie.event.CoordinatorActionEvent
-
- setMsgPrefix(String) - Method in class org.apache.oozie.util.XLog
-
Set the common prefix.
- setMsgType(Event.MessageType) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setName(String) - Method in class org.apache.oozie.action.hadoop.CredentialsProperties
-
Set the name
- setName(String) - Method in class org.apache.oozie.coord.SyncCoordAction
-
- setName(String) - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- setName(String) - Method in class org.apache.oozie.util.graph.WorkflowActionNode
-
- setName(String) - Method in class org.apache.oozie.WorkflowActionBean
-
- setNetworkTimeout(Executor, int) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setNextMaterializedTime(Date) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setNextMaterializedTimestamp(Timestamp) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set next materialized timestamp
- setNominalTime(Date) - Method in class org.apache.oozie.coord.SyncCoordAction
-
- setNominalTime(Date) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setNominalTime(Date) - Method in class org.apache.oozie.event.CoordinatorActionEvent
-
- setNominalTime(String, SLARegistrationBean) - Static method in class org.apache.oozie.sla.SLAOperations
-
- setNominalTime(Date) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setNominalTime(Date) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setNotificationMsg(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setNotificationMsg(String) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setNullReason(String) - Method in class org.apache.oozie.CoordinatorWfActionBean
-
- setNumActions(int) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setOozieDbName(String) - Static method in class org.apache.oozie.store.OozieSchema
-
- setOozieHome() - Static method in class org.apache.oozie.service.Services
-
- setOozieMode(HttpServletRequest, HttpServletResponse, String) - Method in class org.apache.oozie.servlet.BaseAdminServlet
-
- setOozieMode(HttpServletRequest, HttpServletResponse, String) - Method in class org.apache.oozie.servlet.V0AdminServlet
-
- setOozieMode(HttpServletRequest, HttpServletResponse, String) - Method in class org.apache.oozie.servlet.V1AdminServlet
-
- setOrigJobXml(String) - Method in class org.apache.oozie.BundleJobBean
-
- setOrigJobXml(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set original job xml
- setOrigJobXmlBlob(StringBlob) - Method in class org.apache.oozie.BundleJobBean
-
- setOrigJobXmlBlob(StringBlob) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setParameter(String, String) - Method in class org.apache.oozie.util.XLog.Info
-
Set a parameter value in the LogInfo
context.
- setParameter(String, String) - Method in class org.apache.oozie.util.XLogFilter
-
- setParameters(XLog.Info) - Method in class org.apache.oozie.util.XLog.Info
-
Set all the parameter values from the given LogInfo
.
- setParentClientId(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setParentId(String) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setParentId(String) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setParentId(String) - Method in class org.apache.oozie.WorkflowJobBean
-
Set parent id for the workflow.
- setParentSlaId(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setPauseTime(Date) - Method in class org.apache.oozie.BundleJobBean
-
- setPauseTime(Date) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setPauseTimestamp(Timestamp) - Method in class org.apache.oozie.BundleJobBean
-
- setPending(int) - Method in class org.apache.oozie.BundleActionBean
-
Set some actions are in progress for particular bundle action.
- setPending() - Method in class org.apache.oozie.BundleJobBean
-
Set pending to true
- setPending(int) - Method in class org.apache.oozie.BundleJobBean
-
Set pending value
- setPending(int) - Method in class org.apache.oozie.CoordinatorActionBean
-
Set some actions are in progress for particular coordinator action.
- setPending() - Method in class org.apache.oozie.CoordinatorJobBean
-
Set pending to true
- setPending() - Method in class org.apache.oozie.WorkflowActionBean
-
Set the action as pending and the current time as pending.
- setPending(int) - Method in class org.apache.oozie.WorkflowActionBean
-
Set pending flag
- setPendingAge(Date) - Method in class org.apache.oozie.WorkflowActionBean
-
Set a time when the action will be pending, normally a time in the
future.
- setPendingOnly() - Method in class org.apache.oozie.WorkflowActionBean
-
Set the action pending flag to true.
- setPigScript(Configuration, String, String[], String[]) - Static method in class org.apache.oozie.action.hadoop.PigActionExecutor
-
- setPriority(int) - Method in class org.apache.oozie.util.PriorityDelayQueue.QueueElement
-
Deprecated.
Sets the priority of the element.
- setProperties(HashMap<String, String>) - Method in class org.apache.oozie.action.hadoop.CredentialsProperties
-
Set the properties
- setProtoActionConf(String) - Method in class org.apache.oozie.WorkflowJobBean
-
- setProtoActionConfBlob(StringBlob) - Method in class org.apache.oozie.WorkflowJobBean
-
- setPullDependencies(CoordInputDependency) - Method in class org.apache.oozie.coord.SyncCoordAction
-
- setPullInputDependencies(CoordInputDependency) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setPushDependencies(CoordInputDependency) - Method in class org.apache.oozie.coord.SyncCoordAction
-
- setPushInputDependencies(CoordInputDependency) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setPushMissingDependencies(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setPushMissingDependenciesBlob(StringBlob) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setQaContact(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setReadOnly(boolean) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setRerunTime(Date) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setResolved(boolean) - Method in class org.apache.oozie.coord.input.dependency.CoordUnResolvedInputDependency
-
- setResolvedList(List<String>) - Method in class org.apache.oozie.coord.input.dependency.CoordUnResolvedInputDependency
-
- setRestrictParser(boolean) - Method in class org.apache.oozie.util.XConfiguration
-
Restrict the parser
- setRestrictSystemProperties(boolean) - Method in class org.apache.oozie.util.XConfiguration
-
Restrict reading property from System.getProperty()
- setRetries(int) - Method in class org.apache.oozie.WorkflowActionBean
-
- setRetry(int) - Method in class org.apache.oozie.command.NotificationXCommand
-
- setRetryInterval(long) - Method in class org.apache.oozie.action.ActionExecutor
-
Sets the retry interval for the action executor.
- setRetryPolicy(ActionExecutor.RETRYPOLICY) - Method in class org.apache.oozie.action.ActionExecutor
-
Sets the retry policy for the action executor.
- setRun(int) - Method in class org.apache.oozie.WorkflowJobBean
-
- setRunConf(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setRunConfBlob(StringBlob) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setSavepoint() - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setSavepoint(String) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setScheduler(ScheduledExecutorService) - Method in class org.apache.oozie.util.Instrumentation
-
Deprecated.
Set the scheduler instance to handle the samplers.
- setScheduler(ScheduledExecutorService) - Method in class org.apache.oozie.util.MetricsInstrumentation
-
Set the scheduler instance to handle the samplers.
- setSchema(String) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setSeContact(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setService(Class<? extends Service>) - Method in class org.apache.oozie.service.Services
-
Set a service programmatically.
- setShouldEndWF(boolean) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- setSignalValue(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set the signal value for the action.
- setSlaConfig(String) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setSlaId(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setSLARegistrationBean(SLARegistrationBean) - Method in class org.apache.oozie.sla.SLACalcStatus
-
- setSLAStatus(SLAEvent.SLAStatus) - Method in class org.apache.oozie.sla.SLACalcStatus
-
- setSLAStatus(SLAEvent.SLAStatus) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setSlaXml(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setSlaXml(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set sla xml
- setSlaXml(String) - Method in class org.apache.oozie.WorkflowActionBean
-
- setSlaXml(String) - Method in class org.apache.oozie.WorkflowJobBean
-
- setSlaXmlBlob(StringBlob) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setSlaXmlBlob(StringBlob) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setSlaXmlBlob(StringBlob) - Method in class org.apache.oozie.WorkflowActionBean
-
- setSlaXmlBlob(StringBlob) - Method in class org.apache.oozie.WorkflowJobBean
-
- setSortbyColumn(String) - Method in class org.apache.oozie.executor.jpa.sla.SLASummaryGetForFilterJPAExecutor
-
- setStartData(String, String, String) - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Set the action tracking information for an successfully started action.
- setStartData(String, String, String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- setStartData(String, String, String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set a tracking information for an action, and set the action status to
WorkflowAction.Status.DONE
- setStartTime(Date) - Method in class org.apache.oozie.BundleJobBean
-
Set startTime
- setStartTime() - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
Setting the start time of the action
- setStartTime(Date) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setStartTime(Date) - Method in class org.apache.oozie.WorkflowActionBean
-
Set start time
- setStartTime(Date) - Method in class org.apache.oozie.WorkflowJobBean
-
- setStartTimestamp(Timestamp) - Method in class org.apache.oozie.BundleJobBean
-
- setStartTimestamp(Timestamp) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set start timestamp
- setStats(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set stats
- setStatsBlob(StringBlob) - Method in class org.apache.oozie.WorkflowActionBean
-
- setStatus(Job.Status) - Method in class org.apache.oozie.BundleActionBean
-
Set the Status of the Bundle Action
- setStatus(Job.Status) - Method in class org.apache.oozie.BundleJobBean
-
Set status
- setStatus(String) - Method in class org.apache.oozie.BundleJobBean
-
Set status
- setStatus(CoordInputLogicEvaluatorResult.STATUS) - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult
-
- setStatus(CoordinatorAction.Status) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setStatus(Job.Status) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setStatus(Job.Status) - Method in class org.apache.oozie.event.BundleJobEvent
-
- setStatus(CoordinatorAction.Status) - Method in class org.apache.oozie.event.CoordinatorActionEvent
-
- setStatus(Job.Status) - Method in class org.apache.oozie.event.CoordinatorJobEvent
-
- setStatus(WorkflowAction.Status) - Method in class org.apache.oozie.event.WorkflowActionEvent
-
- setStatus(WorkflowJob.Status) - Method in class org.apache.oozie.event.WorkflowJobEvent
-
- setStatus(WorkflowAction.Status) - Method in class org.apache.oozie.util.graph.WorkflowActionNode
-
- setStatus(WorkflowInstance.Status) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- setStatus(WorkflowAction.Status) - Method in class org.apache.oozie.WorkflowActionBean
-
Set status of job
- setStatus(WorkflowJob.Status) - Method in class org.apache.oozie.WorkflowJobBean
-
- setStatusStr(String) - Method in class org.apache.oozie.BundleActionBean
-
Set the Status of the Bundle Action
- setStatusStr(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setStatusStr(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set status
- setStatusStr(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set status
- setStatusStr(String) - Method in class org.apache.oozie.WorkflowJobBean
-
- setStatusTimestamp(Date) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setStatusTimestamp(Date) - Method in class org.apache.oozie.SLAEventBean
-
Deprecated.
- setStreaming(Configuration, String, String, String, String[], String[]) - Static method in class org.apache.oozie.action.hadoop.MapReduceActionExecutor
-
- setString(String) - Method in class org.apache.oozie.StringBlob
-
Set string
- setSuspendedTime(Date) - Method in class org.apache.oozie.BundleJobBean
-
- setSuspendedTime(Date) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set suspended time
- setSuspendedTimestamp(Timestamp) - Method in class org.apache.oozie.BundleJobBean
-
- setSuspendedTimestamp(Timestamp) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set suspended timestamp
- setSystemMode(OozieClient.SYSTEM_MODE) - Method in class org.apache.oozie.service.Services
-
Set and set system mode.
- setThreadSortOrder(String) - Method in class org.apache.oozie.servlet.JVMInfo
-
- setTimeOut(int) - Method in class org.apache.oozie.BundleJobBean
-
Set timeOut
- setTimeOut(int) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setTimeout(int) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setTimeUnit(BundleJob.Timeunit) - Method in class org.apache.oozie.BundleJobBean
-
Set timeUnit
- setTimeUnit(TimeUnit) - Method in class org.apache.oozie.coord.SyncCoordAction
-
- setTimeUnit(TimeUnit) - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- setTimeUnit(CoordinatorJob.Timeunit) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setTimeUnitStr(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
Set time unit
- setTimeZone(TimeZone) - Method in class org.apache.oozie.coord.SyncCoordAction
-
- setTimeZone(TimeZone) - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- setTimeZone(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setTopicPatternProperties(Properties) - Method in class org.apache.oozie.client.rest.JMSConnectionInfoBean
-
Set the topic pattern properties
- setTopicPrefix(String) - Method in class org.apache.oozie.client.rest.JMSConnectionInfoBean
-
Sets the topic prefix
- setTrackerUri(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setTrackerUri(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set tracker uri
- setTransactionIsolation(int) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setTransientVar(String, Object) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- setTransientVar(String, Object) - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- setTransientVar(String, Object) - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Set a transient variable in the context of the instance.
- setTransition(String) - Method in class org.apache.oozie.WorkflowActionBean
-
Set transition
- setTruncatedMessage(String) - Method in class org.apache.oozie.util.XLogFilter
-
- setType(String) - Method in class org.apache.oozie.action.hadoop.CredentialsProperties
-
Set the type
- setType(String) - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- setType(String) - Method in class org.apache.oozie.CoordinatorActionBean
-
- setType(String) - Method in class org.apache.oozie.util.graph.WorkflowActionNode
-
- setType(String) - Method in class org.apache.oozie.WorkflowActionBean
-
- setTypeMap(Map<String, Class<?>>) - Method in class org.apache.oozie.util.db.FailingConnectionWrapper
-
- setupClasspath(Map<String, String>, Configuration) - Static method in class org.apache.oozie.util.ClasspathUtils
-
- setupLauncherConf(Configuration, Element, Path, ActionExecutor.Context) - Method in class org.apache.oozie.action.hadoop.ScriptLanguageActionExecutor
-
- setupLauncherInfo(Configuration, String, String, Path, String, Configuration, String) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
- setupLauncherURIHandlerConf(Configuration) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
- setupMainArguments(Configuration, String[]) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
- setupMainClass(Configuration, String) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
- setupMaxExternalStatsSize(Configuration, int) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
Set the maximum value of stats data
- setupMaxFSGlob(Configuration, int) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
Set the maximum number of globbed files/dirs
- setupMaxOutputData(Configuration, int) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
- setupRemote(String, ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.ssh.SshActionExecutor
-
Do ssh action execution setup on remote host.
- setUpstreamApps(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setUpstreamApps(String) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setupYarnRestartHandling(Configuration, Configuration, String, long) - Static method in class org.apache.oozie.action.hadoop.LauncherHelper
-
- setUriTemplate(String) - Method in class org.apache.oozie.coord.SyncCoordDataset
-
- setUriTemplate(String) - Method in class org.apache.oozie.dependency.ActionDependency
-
- setUser(String) - Method in class org.apache.oozie.BundleJobBean
-
Set user
- setUser(String) - Method in class org.apache.oozie.client.rest.JsonSLAEvent
-
Deprecated.
- setUser(String) - Method in class org.apache.oozie.CoordinatorJobBean
-
- setUser(String) - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- setUser(String) - Method in class org.apache.oozie.sla.SLASummaryBean
-
- setUser(String) - Method in class org.apache.oozie.WorkflowJobBean
-
- setUserLogFilter(XLogUserFilterParam) - Method in class org.apache.oozie.util.XLogFilter
-
- setUserRetryCount(int) - Method in class org.apache.oozie.WorkflowActionBean
-
- setUserRetryInterval(int) - Method in class org.apache.oozie.WorkflowActionBean
-
- setUserRetryMax(int) - Method in class org.apache.oozie.WorkflowActionBean
-
Set user retry max
- setUserRetryPolicy(String) - Method in class org.apache.oozie.workflow.lite.NodeDef
-
- setUsingMiniYarnCluster(boolean) - Static method in class org.apache.oozie.util.ClasspathUtils
-
- setValue(Object, Object) - Method in class org.apache.oozie.util.db.SqlStatement
-
Replace the place holders with actual values in the sql statement
- setVar(String, String) - Method in interface org.apache.oozie.action.ActionExecutor.Context
-
Set a workflow action variable.
- setVar(String, String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
- setVar(String, String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ForkedActionExecutorContext
-
- setVar(String, String) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- setVar(String, String) - Method in interface org.apache.oozie.workflow.lite.NodeHandler.Context
-
- setVar(String, String) - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Set a variable in the context of the instance.
- setVariable(String, Object) - Method in class org.apache.oozie.util.ELEvaluator.Context
-
Add a variable to the context.
- setVariable(String, Object) - Method in class org.apache.oozie.util.ELEvaluator
-
Convenience method that sets a variable in the EL evaluator context.
- setVariables(Map<String, Object>) - Method in class org.apache.oozie.util.ELEvaluator.Context
-
Add variables to the context.
- setVarToWorkflow(String, String) - Method in class org.apache.oozie.command.wf.ActionXCommand.ActionExecutorContext
-
This is not thread safe, don't use if workflowjob is shared among multiple actions command
- setWfInstanceBlob(BinaryBlob) - Method in class org.apache.oozie.WorkflowJobBean
-
- setWorkflowInstance(WorkflowInstance) - Method in class org.apache.oozie.WorkflowJobBean
-
- SHARE_LIB_CONF_PREFIX - Static variable in class org.apache.oozie.service.ShareLibService
-
- SHARE_LIB_PREFIX - Static variable in class org.apache.oozie.service.ShareLibService
-
- SHARELIB_MAPPING_FILE - Static variable in class org.apache.oozie.service.ShareLibService
-
- ShareLibService - Class in org.apache.oozie.service
-
- ShareLibService() - Constructor for class org.apache.oozie.service.ShareLibService
-
- ShellActionExecutor - Class in org.apache.oozie.action.hadoop
-
- ShellActionExecutor() - Constructor for class org.apache.oozie.action.hadoop.ShellActionExecutor
-
- ShellSplitter - Class in org.apache.oozie.action.hadoop
-
- ShellSplitter() - Constructor for class org.apache.oozie.action.hadoop.ShellSplitter
-
- ShellSplitterException - Exception in org.apache.oozie.action.hadoop
-
- ShellSplitterException(String) - Constructor for exception org.apache.oozie.action.hadoop.ShellSplitterException
-
- ShellSplitterException(String, Throwable) - Constructor for exception org.apache.oozie.action.hadoop.ShellSplitterException
-
- SHIP_LAUNCHER_JAR - Static variable in class org.apache.oozie.service.ShareLibService
-
- SHOULD_END - Static variable in class org.apache.oozie.sla.SLAOperations
-
- SHOULD_START - Static variable in class org.apache.oozie.sla.SLAOperations
-
- shouldAddScriptToCache() - Method in class org.apache.oozie.action.hadoop.Hive2ActionExecutor
-
- shouldAddScriptToCache() - Method in class org.apache.oozie.action.hadoop.HiveActionExecutor
-
- shouldAddScriptToCache() - Method in class org.apache.oozie.action.hadoop.ScriptLanguageActionExecutor
-
- shouldFlushOutput(int) - Method in class org.apache.oozie.util.XLogAuditStreamer
-
- shouldFlushOutput(int) - Method in class org.apache.oozie.util.XLogStreamer
-
- shutdown() - Method in class org.apache.oozie.service.AsyncXCommandExecutor
-
- signal(String, String) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- signal(String, String) - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Signal the instance that a node has completed.
- SignalXCommand - Class in org.apache.oozie.command.wf
-
- SignalXCommand(String, int, String) - Constructor for class org.apache.oozie.command.wf.SignalXCommand
-
- SignalXCommand(String, String) - Constructor for class org.apache.oozie.command.wf.SignalXCommand
-
- SimpleHCatDependencyCache - Class in org.apache.oozie.dependency.hcat
-
- SimpleHCatDependencyCache() - Constructor for class org.apache.oozie.dependency.hcat.SimpleHCatDependencyCache
-
- SimpleTimestampedMessageParser - Class in org.apache.oozie.util
-
- SimpleTimestampedMessageParser(BufferedReader, XLogFilter) - Constructor for class org.apache.oozie.util.SimpleTimestampedMessageParser
-
- SITE_CONFIG_FILE - Static variable in class org.apache.oozie.service.ConfigurationService
-
- size() - Method in interface org.apache.oozie.event.EventQueue
-
Get current queue size
- size() - Method in class org.apache.oozie.event.MemoryEventQueue
-
- size() - Method in class org.apache.oozie.lock.MemoryLocks
-
Return the number of active locks.
- size() - Method in interface org.apache.oozie.sla.SLACalculator
-
- size() - Method in class org.apache.oozie.sla.SLACalculatorMemory
-
- size() - Method in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
Return the number of elements in the queue.
- sizes() - Method in class org.apache.oozie.util.PriorityDelayQueue
-
Deprecated.
Return the number of elements on each priority sub-queue.
- SKIP_COMMIT_FAULT_INJECTION_CLASS - Static variable in class org.apache.oozie.service.JPAService
-
- SkipCommitFaultInjection - Class in org.apache.oozie.command
-
- SkipCommitFaultInjection() - Constructor for class org.apache.oozie.command.SkipCommitFaultInjection
-
- SLA_CONF_EXT_SCHEMAS - Static variable in class org.apache.oozie.service.SchemaService
-
- SLA_CONF_SCHEMAS - Static variable in class org.apache.oozie.service.SchemaService
-
- SLA_DEFAULT_MAXEVENTS - Static variable in class org.apache.oozie.command.coord.SLAEventsXCommand
-
- SLA_ENTITYKEY_PREFIX - Static variable in class org.apache.oozie.sla.SLACalcStatus
-
- SLA_MAP - Static variable in class org.apache.oozie.sla.SLACalculatorMemory
-
- SLA_NAME_SPACE_URI - Static variable in class org.apache.oozie.service.SchemaService
-
Deprecated.
- SLA_NAMESPACE_URI_2 - Static variable in class org.apache.oozie.service.SchemaService
-
- SLAAlertsXCommand - Class in org.apache.oozie.command
-
- SLAAlertsXCommand(String, String, String) - Constructor for class org.apache.oozie.command.SLAAlertsXCommand
-
- SLACalcStatus - Class in org.apache.oozie.sla
-
Class used by SLAService to store SLA objects and perform calculations and
sla decisions
- SLACalcStatus(SLARegistrationBean) - Constructor for class org.apache.oozie.sla.SLACalcStatus
-
- SLACalcStatus(SLASummaryBean, SLARegistrationBean) - Constructor for class org.apache.oozie.sla.SLACalcStatus
-
- SLACalcStatus(SLASummaryBean) - Constructor for class org.apache.oozie.sla.SLACalcStatus
-
- SLACalcStatus(SLACalcStatus) - Constructor for class org.apache.oozie.sla.SLACalcStatus
-
copy constructor
- SLACalcStatus() - Constructor for class org.apache.oozie.sla.SLACalcStatus
-
- SLACalculator - Interface in org.apache.oozie.sla
-
- SLACalculatorMemory - Class in org.apache.oozie.sla
-
Implementation class for SLACalculator that calculates SLA related to
start/end/duration of jobs using a memory-based map
- SLACalculatorMemory() - Constructor for class org.apache.oozie.sla.SLACalculatorMemory
-
- SLACalculatorMemory.HistoryPurgeWorker - Class in org.apache.oozie.sla
-
- slaChange(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- slaConfigMapToString() - Method in class org.apache.oozie.sla.SLARegistrationBean
-
- SLACoordActionJobEventXCommand - Class in org.apache.oozie.command.sla
-
- SLACoordActionJobEventXCommand(SLACalcStatus, long) - Constructor for class org.apache.oozie.command.sla.SLACoordActionJobEventXCommand
-
- SLACoordActionJobHistoryXCommand - Class in org.apache.oozie.command.sla
-
- SLACoordActionJobHistoryXCommand(String) - Constructor for class org.apache.oozie.command.sla.SLACoordActionJobHistoryXCommand
-
- SLADbOperations - Class in org.apache.oozie.util.db
-
Deprecated.
- SLADbOperations() - Constructor for class org.apache.oozie.util.db.SLADbOperations
-
Deprecated.
- SLADbXOperations - Class in org.apache.oozie.util.db
-
Deprecated.
- SLADbXOperations() - Constructor for class org.apache.oozie.util.db.SLADbXOperations
-
Deprecated.
- slaDisableAlert(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- SLAEmailEventListener - Class in org.apache.oozie.sla.listener
-
- SLAEmailEventListener() - Constructor for class org.apache.oozie.sla.listener.SLAEmailEventListener
-
- SLAEmailEventListener.EmailField - Enum in org.apache.oozie.sla.listener
-
- slaEnableAlert(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- SLAEventBean - Class in org.apache.oozie
-
Deprecated.
- SLAEventBean() - Constructor for class org.apache.oozie.SLAEventBean
-
Deprecated.
- SLAEventInsertJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Deprecated.
- SLAEventInsertJPAExecutor(SLAEventBean) - Constructor for class org.apache.oozie.executor.jpa.SLAEventInsertJPAExecutor
-
Deprecated.
- SLAEventListener - Class in org.apache.oozie.sla.listener
-
Event listener for SLA related events, defining methods corresponding to
SLA mets/misses
- SLAEventListener() - Constructor for class org.apache.oozie.sla.listener.SLAEventListener
-
- SLAEventsGetForFilterJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Deprecated.
- SLAEventsGetForFilterJPAExecutor(long, int, Map<String, List<String>>, long[]) - Constructor for class org.apache.oozie.executor.jpa.SLAEventsGetForFilterJPAExecutor
-
Deprecated.
- SLAEventsGetForSeqIdJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Deprecated.
- SLAEventsGetForSeqIdJPAExecutor(long, int, long[]) - Constructor for class org.apache.oozie.executor.jpa.SLAEventsGetForSeqIdJPAExecutor
-
Deprecated.
- SLAEventsGetJPAExecutor - Class in org.apache.oozie.executor.jpa
-
Deprecated.
- SLAEventsGetJPAExecutor() - Constructor for class org.apache.oozie.executor.jpa.SLAEventsGetJPAExecutor
-
Deprecated.
- SLAEventsXCommand - Class in org.apache.oozie.command.coord
-
The command to get a list of SLAEvents which are greater than given seqId.
- SLAEventsXCommand(long, int, Map<String, List<String>>) - Constructor for class org.apache.oozie.command.coord.SLAEventsXCommand
-
- SLAJobEventListener - Class in org.apache.oozie.sla.listener
-
- SLAJobEventListener() - Constructor for class org.apache.oozie.sla.listener.SLAJobEventListener
-
- SLAJobEventXCommand - Class in org.apache.oozie.command.sla
-
- SLAJobEventXCommand(SLACalcStatus, long) - Constructor for class org.apache.oozie.command.sla.SLAJobEventXCommand
-
- SLAJobHistoryXCommand - Class in org.apache.oozie.command.sla
-
- SLAJobHistoryXCommand(String) - Constructor for class org.apache.oozie.command.sla.SLAJobHistoryXCommand
-
- SLAOperations - Class in org.apache.oozie.sla
-
- SLAOperations() - Constructor for class org.apache.oozie.sla.SLAOperations
-
- SLARegistrationBean - Class in org.apache.oozie.sla
-
- SLARegistrationBean() - Constructor for class org.apache.oozie.sla.SLARegistrationBean
-
- SLARegistrationBean(JSONObject) - Constructor for class org.apache.oozie.sla.SLARegistrationBean
-
- SLARegistrationQueryExecutor - Class in org.apache.oozie.executor.jpa
-
Query Executor for SLA Event
- SLARegistrationQueryExecutor.SLARegQuery - Enum in org.apache.oozie.executor.jpa
-
- SLAService - Class in org.apache.oozie.sla.service
-
- SLAService() - Constructor for class org.apache.oozie.sla.service.SLAService
-
- SLAServlet - Class in org.apache.oozie.servlet
-
- SLAServlet() - Constructor for class org.apache.oozie.servlet.SLAServlet
-
- SLAServlet(String, JsonRestServlet.ResourceInfo...) - Constructor for class org.apache.oozie.servlet.SLAServlet
-
- SLAStore - Class in org.apache.oozie.store
-
Deprecated.
- SLAStore() - Constructor for class org.apache.oozie.store.SLAStore
-
Deprecated.
- SLAStore(Store) - Constructor for class org.apache.oozie.store.SLAStore
-
Deprecated.
- SLAStoreService - Class in org.apache.oozie.service
-
- SLAStoreService() - Constructor for class org.apache.oozie.service.SLAStoreService
-
- SLASummaryBean - Class in org.apache.oozie.sla
-
- SLASummaryBean() - Constructor for class org.apache.oozie.sla.SLASummaryBean
-
- SLASummaryBean(SLACalcStatus) - Constructor for class org.apache.oozie.sla.SLASummaryBean
-
- SLASummaryGetForFilterJPAExecutor - Class in org.apache.oozie.executor.jpa.sla
-
Load the list of SLASummaryBean (for dashboard) and return the list.
- SLASummaryGetForFilterJPAExecutor(int) - Constructor for class org.apache.oozie.executor.jpa.sla.SLASummaryGetForFilterJPAExecutor
-
- SLASummaryGetRecordsOnRestartJPAExecutor - Class in org.apache.oozie.executor.jpa.sla
-
Load the list of SLASummaryBean when Oozie restarts and return the list.
- SLASummaryGetRecordsOnRestartJPAExecutor(int) - Constructor for class org.apache.oozie.executor.jpa.sla.SLASummaryGetRecordsOnRestartJPAExecutor
-
- SLASummaryQueryExecutor - Class in org.apache.oozie.executor.jpa
-
Query Executor for SLA Event
- SLASummaryQueryExecutor.SLASummaryQuery - Enum in org.apache.oozie.executor.jpa
-
- SLAWorkflowActionJobEventXCommand - Class in org.apache.oozie.command.sla
-
- SLAWorkflowActionJobEventXCommand(SLACalcStatus, long) - Constructor for class org.apache.oozie.command.sla.SLAWorkflowActionJobEventXCommand
-
- SLAWorkflowActionJobHistoryXCommand - Class in org.apache.oozie.command.sla
-
- SLAWorkflowActionJobHistoryXCommand(String) - Constructor for class org.apache.oozie.command.sla.SLAWorkflowActionJobHistoryXCommand
-
- SLAWorkflowJobEventXCommand - Class in org.apache.oozie.command.sla
-
- SLAWorkflowJobEventXCommand(SLACalcStatus, long) - Constructor for class org.apache.oozie.command.sla.SLAWorkflowJobEventXCommand
-
- SLAWorkflowJobHistoryXCommand - Class in org.apache.oozie.command.sla
-
- SLAWorkflowJobHistoryXCommand(String) - Constructor for class org.apache.oozie.command.sla.SLAWorkflowJobHistoryXCommand
-
- SLAXCommandFactory - Class in org.apache.oozie.sla
-
A factory for creating SLACommand objects.
- SLAXCommandFactory() - Constructor for class org.apache.oozie.sla.SLAXCommandFactory
-
- SMTP_CONNECTION_TIMEOUT - Static variable in class org.apache.oozie.sla.listener.SLAEmailEventListener
-
- SMTP_TIMEOUT - Static variable in class org.apache.oozie.sla.listener.SLAEmailEventListener
-
- SPARK_CLASS - Static variable in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- SPARK_CONFIGURATIONS - Static variable in class org.apache.oozie.service.SparkConfigurationService
-
- SPARK_CONFIGURATIONS_BLACKLIST - Static variable in class org.apache.oozie.service.SparkConfigurationService
-
- SPARK_CONFIGURATIONS_IGNORE_SPARK_YARN_JAR - Static variable in class org.apache.oozie.service.SparkConfigurationService
-
- SPARK_DEFAULT_OPTS - Static variable in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- SPARK_JAR - Static variable in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- SPARK_JOB_NAME - Static variable in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- SPARK_MAIN_CLASS_NAME - Static variable in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- SPARK_MASTER - Static variable in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- SPARK_MODE - Static variable in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- SPARK_OPTS - Static variable in class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- SparkActionExecutor - Class in org.apache.oozie.action.hadoop
-
- SparkActionExecutor() - Constructor for class org.apache.oozie.action.hadoop.SparkActionExecutor
-
- SparkConfigurationService - Class in org.apache.oozie.service
-
- SparkConfigurationService() - Constructor for class org.apache.oozie.service.SparkConfigurationService
-
- splitLogMessage(String) - Method in class org.apache.oozie.util.TimestampedMessageParser
-
Splits the log message into parts
- splitLogMessage(String) - Method in class org.apache.oozie.util.XLogFilter
-
Splits the log line into timestamp, logLevel and remaining log message.
- splitLogMessage(LogLine, Pattern) - Method in class org.apache.oozie.util.XLogFilter
-
If logLine
matches with splitPattern
,
Split the log line into timestamp, logLevel and remaining log
message.
Record the parts of message in logLine
to avoid regex
matching in future.
Record the pattern to which logLine
has matched.
- splitsMatches(LogLine) - Method in class org.apache.oozie.util.XLogFilter
-
Checks if the logLevel and logMessage goes through the logFilter.
- SqlStatement - Class in org.apache.oozie.util.db
-
The SqlStatement
is used to generate SQL Statements.
- SqlStatement() - Constructor for class org.apache.oozie.util.db.SqlStatement
-
- SqlStatement.Condition - Class in org.apache.oozie.util.db
-
Construct the condition statement that will be used in the where clause
- SqlStatement.Delete - Class in org.apache.oozie.util.db
-
SQL Statement generator for DELETE Statements
- SqlStatement.Insert - Class in org.apache.oozie.util.db
-
INSERT Statement generator
- SqlStatement.ResultSetReader - Class in org.apache.oozie.util.db
-
ResultSetReader
is used to parse the result set and gives methods for getting appropriate type of
data given the column name
- SqlStatement.Select - Class in org.apache.oozie.util.db
-
Select Statement generator.
- SqlStatement.Update - Class in org.apache.oozie.util.db
-
UPDATE SQL Statement generator
- SqoopActionExecutor - Class in org.apache.oozie.action.hadoop
-
- SqoopActionExecutor() - Constructor for class org.apache.oozie.action.hadoop.SqoopActionExecutor
-
- SSH_COMMAND_BASE - Static variable in class org.apache.oozie.action.ssh.SshActionExecutor
-
- SSH_COMMAND_OPTIONS - Static variable in class org.apache.oozie.action.ssh.SshActionExecutor
-
- SshActionExecutor - Class in org.apache.oozie.action.ssh
-
Ssh action executor.
- SshActionExecutor() - Constructor for class org.apache.oozie.action.ssh.SshActionExecutor
-
- start(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.ActionExecutor
-
Start an action.
- start(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.control.ControlNodeActionExecutor
-
- start(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.decision.DecisionActionExecutor
-
- start(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.email.EmailActionExecutor
-
- start(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.hadoop.FsActionExecutor
-
- start(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- start(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- start(ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.ssh.SshActionExecutor
-
Start the ssh action execution.
- start(String) - Method in class org.apache.oozie.BaseEngine
-
Start a job.
- start(String) - Method in class org.apache.oozie.BundleEngine
-
- start(String) - Method in class org.apache.oozie.CoordinatorEngine
-
Deprecated.
- start(String) - Method in class org.apache.oozie.DagEngine
-
Start a job.
- start() - Static method in class org.apache.oozie.local.LocalOozie
-
Start LocalOozie.
- start(NodeHandler.Context) - Method in class org.apache.oozie.service.LiteWorkflowStoreService.LiteActionHandler
-
- start(NodeHandler.Context) - Method in class org.apache.oozie.service.LiteWorkflowStoreService.LiteDecisionHandler
-
- start() - Method in class org.apache.oozie.test.EmbeddedServletContainer
-
Start the servlet container.
- start() - Method in class org.apache.oozie.util.ChildReaper
-
The reaper must be started
- start() - Method in class org.apache.oozie.util.Instrumentation.Cron
-
Deprecated.
Start the cron.
- start(NodeHandler.Context) - Method in class org.apache.oozie.workflow.lite.ActionNodeHandler
-
- start(NodeHandler.Context) - Method in class org.apache.oozie.workflow.lite.DecisionNodeHandler
-
- start() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- START - Static variable in class org.apache.oozie.workflow.lite.StartNodeDef
-
Reserved name fo the start node.
- start() - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Start the instance.
- START_DATA_MISSING - Static variable in class org.apache.oozie.command.coord.CoordActionStartXCommand
-
- START_DATA_MISSING - Static variable in class org.apache.oozie.command.wf.ActionStartXCommand
-
- START_TIME - Static variable in class org.apache.oozie.util.XLogUserFilterParam
-
- StartActionExecutor - Class in org.apache.oozie.action.control
-
Action executor for START control node.
- StartActionExecutor() - Constructor for class org.apache.oozie.action.control.StartActionExecutor
-
- StartChildren() - Method in class org.apache.oozie.command.bundle.BundleStartXCommand
-
- StartChildren() - Method in class org.apache.oozie.command.StartTransitionXCommand
-
Start actions associated with the job
- startCron() - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Start the request instrumentation cron.
- startDocument() - Method in class org.apache.oozie.util.graph.WorkflowGraphHandler
-
- startElement(String, String, String, Attributes) - Method in class org.apache.oozie.util.graph.WorkflowGraphHandler
-
- startForkedActions(List<WorkflowActionBean>) - Method in class org.apache.oozie.command.wf.SignalXCommand
-
- startForkedActionsByQueuing(List<WorkflowActionBean>) - Method in class org.apache.oozie.command.wf.SignalXCommand
-
- startJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- startJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- StartNodeDef - Class in org.apache.oozie.workflow.lite
-
Workflow lite start node definition.
- StartNodeDef() - Constructor for class org.apache.oozie.workflow.lite.StartNodeDef
-
Default constructor.
- StartNodeDef(Class<? extends ControlNodeHandler>, String) - Constructor for class org.apache.oozie.workflow.lite.StartNodeDef
-
Create a start node definition.
- StartNodeDef.StartNodeHandler - Class in org.apache.oozie.workflow.lite
-
Start node handler.
- StartNodeHandler() - Constructor for class org.apache.oozie.workflow.lite.StartNodeDef.StartNodeHandler
-
- startSLAWorker() - Method in class org.apache.oozie.sla.service.SLAService
-
- startTime - Variable in class org.apache.oozie.service.UUIDService
-
- StartTransitionXCommand - Class in org.apache.oozie.command
-
Transition command for start the job.
- StartTransitionXCommand(String, String, int) - Constructor for class org.apache.oozie.command.StartTransitionXCommand
-
- StartTransitionXCommand(String, String, int, boolean) - Constructor for class org.apache.oozie.command.StartTransitionXCommand
-
- StartXCommand - Class in org.apache.oozie.command.wf
-
Starting the command.
- StartXCommand(String) - Constructor for class org.apache.oozie.command.wf.StartXCommand
-
- stateChanged(CuratorFramework, ConnectionState) - Method in class org.apache.oozie.event.listener.ZKConnectionListener
-
- StatusTransitRunnable() - Constructor for class org.apache.oozie.service.StatusTransitService.StatusTransitRunnable
-
- StatusTransitService - Class in org.apache.oozie.service
-
StateTransitService is scheduled to run at the configured interval.
- StatusTransitService() - Constructor for class org.apache.oozie.service.StatusTransitService
-
- StatusTransitService.StatusTransitRunnable - Class in org.apache.oozie.service
-
StateTransitRunnable is the runnable which is scheduled to run at the configured interval.
- StatusTransitXCommand - Class in org.apache.oozie.command
-
StatusTransitXCommand is super class for Status Transit Command, it defines layout for Status Transit Commands.
- StatusTransitXCommand(String, String, int) - Constructor for class org.apache.oozie.command.StatusTransitXCommand
-
Instantiates a new status transit x command.
- StatusUpdateXCommand - Class in org.apache.oozie.command
-
Transition command for update status.
- StatusUpdateXCommand(String, String, int) - Constructor for class org.apache.oozie.command.StatusUpdateXCommand
-
- StatusUpdateXCommand(String, String, int, boolean) - Constructor for class org.apache.oozie.command.StatusUpdateXCommand
-
- StatusUtils - Class in org.apache.oozie.util
-
- StatusUtils() - Constructor for class org.apache.oozie.util.StatusUtils
-
- STD - Static variable in class org.apache.oozie.util.XLog
-
Mask for logging to the standard log.
- stop() - Static method in class org.apache.oozie.local.LocalOozie
-
Stop LocalOozie.
- stop() - Method in class org.apache.oozie.test.EmbeddedServletContainer
-
Stop the servlet container.
- stop() - Method in class org.apache.oozie.util.Instrumentation.Cron
-
Deprecated.
Stops the cron.
- stop() - Method in class org.apache.oozie.util.Instrumentation
-
Deprecated.
- stop() - Method in class org.apache.oozie.util.MetricsInstrumentation
-
Reporting final metrics into the server before stopping
- stopCron() - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Stop the request instrumentation cron.
- Store - Class in org.apache.oozie.store
-
- Store() - Constructor for class org.apache.oozie.store.Store
-
create a fresh transaction
- Store(Store) - Constructor for class org.apache.oozie.store.Store
-
Use an existing transaction for cross store operations
- StoreException - Exception in org.apache.oozie.store
-
- StoreException(XException) - Constructor for exception org.apache.oozie.store.StoreException
-
Create an store exception from a XException.
- StoreException(ErrorCode, Object...) - Constructor for exception org.apache.oozie.store.StoreException
-
Create a store exception.
- StoreService - Class in org.apache.oozie.service
-
Base service for persistency of jobs and actions.
- StoreService() - Constructor for class org.apache.oozie.service.StoreService
-
- StoreStatusFilter - Class in org.apache.oozie.store
-
- StoreStatusFilter() - Constructor for class org.apache.oozie.store.StoreStatusFilter
-
- storeToDB(String, Element, CoordinatorJobBean) - Method in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
Write a coordinator job into database
- storeToDB(String, Element, CoordinatorJobBean) - Method in class org.apache.oozie.command.coord.CoordUpdateXCommand
-
- STREAM_BUFFER_LEN - Static variable in class org.apache.oozie.util.XLogAuditStreamer
-
- STREAM_BUFFER_LEN - Static variable in class org.apache.oozie.util.XLogErrorStreamer
-
- STREAM_BUFFER_LEN - Static variable in class org.apache.oozie.util.XLogStreamer
-
- streamAuditLog(String, Writer, Map<String, String[]>) - Method in class org.apache.oozie.BaseEngine
-
Stream Audit log of a job.
- streamErrorLog(String, Writer, Map<String, String[]>) - Method in class org.apache.oozie.BaseEngine
-
Stream error log of a job.
- streamJobAuditLog(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- streamJobAuditLog(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- streamJobAuditLog(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- streamJobErrorLog(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- streamJobErrorLog(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- streamJobErrorLog(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V2JobServlet
-
- streamJobGraph(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- streamJobGraph(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- streamJobLog(XLogStreamer, String, Writer) - Method in class org.apache.oozie.BaseEngine
-
Stream job log.
- streamJobLog(XLogStreamer, String, Writer) - Method in class org.apache.oozie.BundleEngine
-
- streamJobLog(XLogStreamer, String, Writer) - Method in class org.apache.oozie.CoordinatorEngine
-
- streamJobLog(XLogStreamer, String, Writer) - Method in class org.apache.oozie.DagEngine
-
- streamJobLog(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- streamJobLog(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- streamLog(String, Writer, Map<String, String[]>) - Method in class org.apache.oozie.BaseEngine
-
Stream the log of a job.
- streamLog(String, String, String, Writer, Map<String, String[]>) - Method in class org.apache.oozie.CoordinatorEngine
-
Add list of actions to the filter based on conditions
- streamLog(XLogStreamer, Date, Date, Writer) - Method in class org.apache.oozie.service.XLogStreamingService
-
Stream the log of a job.
- streamLog(XLogStreamer, Date, Date, Writer, boolean) - Method in class org.apache.oozie.service.XLogStreamingService
-
Stream log.
- streamLog(XLogStreamer, Date, Date, Writer) - Method in class org.apache.oozie.service.ZKXLogStreamingService
-
Stream the log of a job.
- streamLog(Writer, Date, Date) - Method in class org.apache.oozie.util.XLogStreamer
-
Gets the files that are modified between startTime and endTime in the given logPath and streams the log after
applying the filters.
- streamLog(Writer, Date, Date, boolean) - Method in class org.apache.oozie.util.XLogStreamer
-
Gets the files that are modified between startTime and endTime in the given logPath and streams the log after
applying the filters
- STRING_DEFAULT - Static variable in class org.apache.oozie.util.ConfigUtils
-
- StringBlob - Class in org.apache.oozie
-
StringBlob to maintain compress and uncompressed data
- StringBlob(byte[]) - Constructor for class org.apache.oozie.StringBlob
-
Construct string blob from compressed byte array
- StringBlob(String) - Constructor for class org.apache.oozie.StringBlob
-
Construct StringBlob with uncompressed string
- StringBlobValueHandler - Class in org.apache.oozie.executor.jpa
-
- StringBlobValueHandler() - Constructor for class org.apache.oozie.executor.jpa.StringBlobValueHandler
-
- StringSerializationUtil - Class in org.apache.oozie.util
-
This class provides a workaround for the 64k limit for string in DataOutput.
- stringToProperties(String) - Static method in class org.apache.oozie.util.PropertiesUtils
-
- StringUtils - Class in org.apache.oozie.util
-
Utility methods for working with
String
objects.
- StringUtils() - Constructor for class org.apache.oozie.util.StringUtils
-
- submit() - Method in class org.apache.oozie.command.bundle.BundleSubmitXCommand
-
- submit() - Method in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- submit() - Method in class org.apache.oozie.command.coord.CoordUpdateXCommand
-
- submit() - Method in class org.apache.oozie.command.SubmitTransitionXCommand
-
Submit the job
- SUBMIT_DAY - Static variable in class org.apache.oozie.coord.CoordELConstants
-
- SUBMIT_DAYS - Static variable in class org.apache.oozie.coord.CoordELConstants
-
- SUBMIT_DAYS - Static variable in class org.apache.oozie.util.ELConstantsFunctions
-
- SUBMIT_HOUR - Static variable in class org.apache.oozie.coord.CoordELConstants
-
- SUBMIT_HOURS - Static variable in class org.apache.oozie.coord.CoordELConstants
-
- SUBMIT_HOURS - Static variable in class org.apache.oozie.util.ELConstantsFunctions
-
- SUBMIT_MINUTE - Static variable in class org.apache.oozie.coord.CoordELConstants
-
- SUBMIT_MINUTES - Static variable in class org.apache.oozie.coord.CoordELConstants
-
- SUBMIT_MINUTES - Static variable in class org.apache.oozie.util.ELConstantsFunctions
-
- SUBMIT_MONTH - Static variable in class org.apache.oozie.coord.CoordELConstants
-
- SUBMIT_YEAR - Static variable in class org.apache.oozie.coord.CoordELConstants
-
- SubmitHiveXCommand - Class in org.apache.oozie.command.wf
-
- SubmitHiveXCommand(Configuration) - Constructor for class org.apache.oozie.command.wf.SubmitHiveXCommand
-
- submitHttpJob(Configuration, String) - Method in class org.apache.oozie.DagEngine
-
Submit a pig/hive/mapreduce job through HTTP.
- SubmitHttpXCommand - Class in org.apache.oozie.command.wf
-
- SubmitHttpXCommand(String, String, Configuration) - Constructor for class org.apache.oozie.command.wf.SubmitHttpXCommand
-
- submitJob(Configuration, boolean) - Method in class org.apache.oozie.BaseEngine
-
Submit a job.
- submitJob(Configuration, boolean) - Method in class org.apache.oozie.BundleEngine
-
- submitJob() - Method in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- submitJob(Configuration, boolean) - Method in class org.apache.oozie.CoordinatorEngine
-
- submitJob(Configuration, boolean) - Method in class org.apache.oozie.DagEngine
-
Submit a workflow job.
- submitJob(HttpServletRequest, Configuration) - Method in class org.apache.oozie.servlet.V0JobsServlet
-
v0 service implementation to submit a workflow job
- submitJob(HttpServletRequest, Configuration) - Method in class org.apache.oozie.servlet.V1JobsServlet
-
v1 service implementation to submit a job, either workflow or coordinator
- submitJobFromCoordinator(Configuration, String) - Method in class org.apache.oozie.DagEngine
-
Submit a workflow through a coordinator.
- submitLauncher(FileSystem, ActionExecutor.Context, WorkflowAction) - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- SubmitMRXCommand - Class in org.apache.oozie.command.wf
-
- SubmitMRXCommand(Configuration) - Constructor for class org.apache.oozie.command.wf.SubmitMRXCommand
-
- SubmitPigXCommand - Class in org.apache.oozie.command.wf
-
- SubmitPigXCommand(Configuration) - Constructor for class org.apache.oozie.command.wf.SubmitPigXCommand
-
- SubmitScriptLanguageXCommand - Class in org.apache.oozie.command.wf
-
- SubmitScriptLanguageXCommand(String, String, Configuration) - Constructor for class org.apache.oozie.command.wf.SubmitScriptLanguageXCommand
-
- SubmitSqoopXCommand - Class in org.apache.oozie.command.wf
-
- SubmitSqoopXCommand(Configuration) - Constructor for class org.apache.oozie.command.wf.SubmitSqoopXCommand
-
- SubmitTransitionXCommand - Class in org.apache.oozie.command
-
Base class for submit transition command.
- SubmitTransitionXCommand(String, String, int) - Constructor for class org.apache.oozie.command.SubmitTransitionXCommand
-
- SubmitTransitionXCommand(String, String, int, boolean) - Constructor for class org.apache.oozie.command.SubmitTransitionXCommand
-
- SubmitXCommand - Class in org.apache.oozie.command.wf
-
- SubmitXCommand(Configuration) - Constructor for class org.apache.oozie.command.wf.SubmitXCommand
-
Constructor to create the workflow Submit Command.
- SubmitXCommand(Configuration, String) - Constructor for class org.apache.oozie.command.wf.SubmitXCommand
-
Constructor for submitting wf through coordinator
- SubmitXCommand(boolean, Configuration) - Constructor for class org.apache.oozie.command.wf.SubmitXCommand
-
Constructor to create the workflow Submit Command.
- SUBWORKFLOW_DEPTH - Static variable in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- SUBWORKFLOW_MAX_DEPTH - Static variable in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- SUBWORKFLOW_RERUN - Static variable in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- SubWorkflowActionExecutor - Class in org.apache.oozie.action.oozie
-
- SubWorkflowActionExecutor() - Constructor for class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- SUCCEEDED - Static variable in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- SUPER_PARENT_ID - Static variable in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- SUPPORTED_FILESYSTEMS - Static variable in class org.apache.oozie.service.HadoopAccessorService
-
Supported filesystem schemes for namespace federation
- supportsConfigurationJobXML() - Method in class org.apache.oozie.action.ActionExecutor
-
Returns true if this action type supports a Configuration and JobXML.
- supportsConfigurationJobXML() - Method in class org.apache.oozie.action.hadoop.FsActionExecutor
-
- supportsConfigurationJobXML() - Method in class org.apache.oozie.action.hadoop.JavaActionExecutor
-
- supportsConfigurationJobXML() - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- suspend(String) - Method in class org.apache.oozie.BaseEngine
-
Suspend a job.
- suspend(String) - Method in class org.apache.oozie.BundleEngine
-
- suspend(String) - Method in class org.apache.oozie.CoordinatorEngine
-
- suspend(String) - Method in class org.apache.oozie.DagEngine
-
Suspend a job.
- suspend() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowInstance
-
- suspend() - Method in interface org.apache.oozie.workflow.WorkflowInstance
-
Suspend the instance.
- suspendChildren() - Method in class org.apache.oozie.command.bundle.BundleJobSuspendXCommand
-
- suspendChildren() - Method in class org.apache.oozie.command.coord.CoordSuspendXCommand
-
- suspendChildren() - Method in class org.apache.oozie.command.SuspendTransitionXCommand
-
Suspend all children of the job
- suspendJob(JPAService, WorkflowJobBean, String, String, List<BatchQueryExecutor.UpdateEntry>) - Static method in class org.apache.oozie.command.wf.SuspendXCommand
-
Suspend the workflow job and pending flag to false for the actions that are START_RETRY or START_MANUAL or
END_RETRY or END_MANUAL
- suspendJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobServlet
-
- suspendJob(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobServlet
-
- suspendJobs(String, int, int) - Method in class org.apache.oozie.BundleEngine
-
return a list of suspended Bundle job
- suspendJobs(String, int, int) - Method in class org.apache.oozie.CoordinatorEngine
-
return the jobs that've been suspended
- suspendJobs(String, int, int) - Method in class org.apache.oozie.DagEngine
-
return the jobs that've been suspended
- suspendJobs(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V0JobsServlet
-
service implementation to bulk suspend jobs
- suspendJobs(HttpServletRequest, HttpServletResponse) - Method in class org.apache.oozie.servlet.V1JobsServlet
-
service implementation to bulk suspend jobs
- SuspendTransitionXCommand - Class in org.apache.oozie.command
-
- SuspendTransitionXCommand(String, String, int) - Constructor for class org.apache.oozie.command.SuspendTransitionXCommand
-
- SuspendTransitionXCommand(String, String, int, boolean) - Constructor for class org.apache.oozie.command.SuspendTransitionXCommand
-
- SuspendXCommand - Class in org.apache.oozie.command.wf
-
- SuspendXCommand(String) - Constructor for class org.apache.oozie.command.wf.SuspendXCommand
-
- SyncCoordAction - Class in org.apache.oozie.coord
-
This class represents a Coordinator action.
- SyncCoordAction() - Constructor for class org.apache.oozie.coord.SyncCoordAction
-
- SyncCoordDataset - Class in org.apache.oozie.coord
-
This class is a bean to represent a dataset.
- SyncCoordDataset() - Constructor for class org.apache.oozie.coord.SyncCoordDataset
-
- SYSTEM_LIB_PATH - Static variable in class org.apache.oozie.service.WorkflowAppService
-
- V0AdminServlet - Class in org.apache.oozie.servlet
-
- V0AdminServlet() - Constructor for class org.apache.oozie.servlet.V0AdminServlet
-
- V0JobServlet - Class in org.apache.oozie.servlet
-
- V0JobServlet() - Constructor for class org.apache.oozie.servlet.V0JobServlet
-
- V0JobsServlet - Class in org.apache.oozie.servlet
-
- V0JobsServlet() - Constructor for class org.apache.oozie.servlet.V0JobsServlet
-
- V1AdminServlet - Class in org.apache.oozie.servlet
-
- V1AdminServlet(String) - Constructor for class org.apache.oozie.servlet.V1AdminServlet
-
- V1AdminServlet() - Constructor for class org.apache.oozie.servlet.V1AdminServlet
-
- V1JobServlet - Class in org.apache.oozie.servlet
-
- V1JobServlet() - Constructor for class org.apache.oozie.servlet.V1JobServlet
-
- V1JobServlet(String) - Constructor for class org.apache.oozie.servlet.V1JobServlet
-
- V1JobsServlet - Class in org.apache.oozie.servlet
-
- V1JobsServlet() - Constructor for class org.apache.oozie.servlet.V1JobsServlet
-
- V2AdminServlet - Class in org.apache.oozie.servlet
-
V2 admin servlet
- V2AdminServlet() - Constructor for class org.apache.oozie.servlet.V2AdminServlet
-
- V2JobServlet - Class in org.apache.oozie.servlet
-
- V2JobServlet() - Constructor for class org.apache.oozie.servlet.V2JobServlet
-
- V2SLAServlet - Class in org.apache.oozie.servlet
-
- V2SLAServlet() - Constructor for class org.apache.oozie.servlet.V2SLAServlet
-
- V2ValidateServlet - Class in org.apache.oozie.servlet
-
- V2ValidateServlet() - Constructor for class org.apache.oozie.servlet.V2ValidateServlet
-
- VALID_JOB_FILTERS - Static variable in class org.apache.oozie.CoordinatorEngine
-
- VALID_WORKFLOW_APP - Static variable in class org.apache.oozie.servlet.V2ValidateServlet
-
- validate(String) - Method in class org.apache.oozie.dependency.FSURIHandler
-
- validate(String) - Method in class org.apache.oozie.dependency.HCatURIHandler
-
- validate(String) - Method in interface org.apache.oozie.dependency.URIHandler
-
Check whether the URI is valid or not
- validate(String, String, String) - Method in class org.apache.oozie.service.ProxyUserService
-
Verifies a proxyuser.
- validate(String) - Method in class org.apache.oozie.servlet.V2ValidateServlet
-
- VALIDATE_FORK_JOIN - Static variable in class org.apache.oozie.workflow.lite.LiteWorkflowAppParser
-
- validateActionName(String) - Static method in class org.apache.oozie.util.ParamChecker
-
Check that the given string is a valid action name [a-zA-Z_][0-9a-zA-Z_\-]* and not longer than 128 chars.
- validateAndMail(ActionExecutor.Context, Element) - Method in class org.apache.oozie.action.email.EmailActionExecutor
-
- validateAndParse(Reader, Configuration) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowAppParser
-
- validateAndParse(Reader, Configuration, Configuration) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowAppParser
-
- validateAppPath(String, String) - Static method in class org.apache.oozie.servlet.ServletUtilities
-
accessory static method to check the app path parameter for the request
used only for job-related request and only one of them should exist
- validateAppPath(String, String, String) - Static method in class org.apache.oozie.servlet.ServletUtilities
-
accessory static method to check the app path parameter for the request
used only for job-related request and only one of them should exist
bundle appPath is also checked
- ValidateConnectionBean - Class in org.apache.oozie.util.db
-
- ValidateConnectionBean() - Constructor for class org.apache.oozie.util.db.ValidateConnectionBean
-
- validateContentType(HttpServletRequest, String) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Validate and return the content type of the request.
- validateData(String, SchemaService.SchemaName) - Static method in class org.apache.oozie.util.XmlUtils
-
- validateDateRange(Date, Date) - Method in class org.apache.oozie.util.XLogFilter
-
validate date range.
- validateInputLogic() - Method in class org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorUtil
-
Validate input logic.
- validateJobTracker(String) - Method in class org.apache.oozie.service.HadoopAccessorService
-
Validate Job tracker
- ValidateLibPath(String) - Static method in class org.apache.oozie.servlet.ServletUtilities
-
accessory static method to check the lib path parameter for the request
- validateLogLevel(String) - Method in class org.apache.oozie.util.XLogUserFilterParam
-
Validate log level.
- validateNameNode(String) - Method in class org.apache.oozie.service.HadoopAccessorService
-
Validate Namenode list
- validateRestUrl(String, String, Map<String, String[]>) - Method in class org.apache.oozie.servlet.JsonRestServlet
-
Validates REST URL using the ResourceInfos of the servlet.
- validateSearchText() - Method in class org.apache.oozie.util.XLogUserFilterParam
-
Validate search text.
- validateSLAChangeParam(Map<String, String>) - Method in class org.apache.oozie.command.SLAAlertsXCommand
-
- validateTransition(String, String) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowApp
-
- validateWorkflow(LiteWorkflowApp, boolean) - Method in class org.apache.oozie.workflow.lite.LiteWorkflowValidator
-
- validateWorkflowIntegrity() - Method in class org.apache.oozie.workflow.lite.LiteWorkflowApp
-
- validateXml(Schema, String) - Static method in class org.apache.oozie.util.XmlUtils
-
Schema validation for a given xml.
- value(Schema.Column, Object) - Method in class org.apache.oozie.util.db.SqlStatement.Insert
-
Set the VALUES that are to be inserted
- valueOf(String) - Static method in enum org.apache.oozie.action.ActionExecutor.RETRYPOLICY
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.action.ActionExecutorException.ErrorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.command.OperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult.STATUS
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.coord.TimeUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.CoordinatorEngine.FILTER_COMPARATORS
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.dependency.URIHandler.DependencyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.ErrorCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.executor.jpa.BundleActionQueryExecutor.BundleActionQuery
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.executor.jpa.BundleJobQueryExecutor.BundleJobQuery
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.executor.jpa.CoordActionQueryExecutor.CoordActionQuery
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.executor.jpa.CoordJobQueryExecutor.CoordJobQuery
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.executor.jpa.SLARegistrationQueryExecutor.SLARegQuery
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.executor.jpa.SLASummaryQueryExecutor.SLASummaryQuery
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.executor.jpa.WorkflowActionQueryExecutor.WorkflowActionQuery
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.executor.jpa.WorkflowJobQueryExecutor.WorkflowJobQuery
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.service.JMSTopicService.JobType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.service.JMSTopicService.TopicType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.service.MemoryLocksService.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.service.SchedulerService.Unit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.service.SchemaService.SchemaName
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.service.UUIDService.ApplicationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.sla.listener.SLAEmailEventListener.EmailField
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.store.OozieSchema.OozieColumn
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.store.OozieSchema.OozieIndex
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.store.OozieSchema.OozieTable
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.util.db.CompositeIndex
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.util.db.Schema.DBType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.util.graph.OutputFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.util.XLog.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.oozie.workflow.WorkflowInstance.Status
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.oozie.action.ActionExecutor.RETRYPOLICY
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.action.ActionExecutorException.ErrorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.command.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.coord.input.logic.CoordInputLogicEvaluatorResult.STATUS
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.coord.TimeUnit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.CoordinatorEngine.FILTER_COMPARATORS
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.dependency.URIHandler.DependencyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.ErrorCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.executor.jpa.BundleActionQueryExecutor.BundleActionQuery
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.executor.jpa.BundleJobQueryExecutor.BundleJobQuery
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.executor.jpa.CoordActionQueryExecutor.CoordActionQuery
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.executor.jpa.CoordJobQueryExecutor.CoordJobQuery
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.executor.jpa.SLARegistrationQueryExecutor.SLARegQuery
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.executor.jpa.SLASummaryQueryExecutor.SLASummaryQuery
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.executor.jpa.WorkflowActionQueryExecutor.WorkflowActionQuery
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.executor.jpa.WorkflowJobQueryExecutor.WorkflowJobQuery
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.service.JMSTopicService.JobType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.service.JMSTopicService.TopicType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.service.MemoryLocksService.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.service.SchedulerService.Unit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.service.SchemaService.SchemaName
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.service.UUIDService.ApplicationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.sla.listener.SLAEmailEventListener.EmailField
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.store.OozieSchema.OozieColumn
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.store.OozieSchema.OozieIndex
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.store.OozieSchema.OozieTable
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.util.db.CompositeIndex
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.util.db.Schema.DBType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.oozie.util.db.SqlStatement.Condition
-
- values - Variable in class org.apache.oozie.util.db.SqlStatement
-
- values() - Static method in enum org.apache.oozie.util.graph.OutputFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.util.XLog.Level
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.oozie.workflow.WorkflowInstance.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- verifyAndInjectSubworkflowDepth(Configuration, Configuration) - Method in class org.apache.oozie.action.oozie.SubWorkflowActionExecutor
-
- verifyConfigurationName() - Method in class org.apache.oozie.service.ConfigurationService
-
Verify the configuration is in oozie-default
- verifyParameters(Configuration, Element) - Static method in class org.apache.oozie.util.ParameterVerifier
-
Verify the parameters section (if supported in the schema)
- verifyPrecondition() - Method in class org.apache.oozie.command.BulkJobsXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BulkBundleXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleCoordSubmitXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleJobChangeXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleJobResumeXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleJobSuspendXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleJobsXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleJobXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleKillXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundlePauseXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleSLAChangeXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleStartXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleStatusTransitXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleStatusUpdateXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleSubmitXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.bundle.BundleUnpauseXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.BulkCoordXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordActionCheckXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordActionInfoXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordActionInputCheckXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordActionMissingDependenciesXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordActionReadyXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordActionsIgnoreXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordActionsKillXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordActionSkipXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordActionStartXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordActionTimeOutXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordActionUpdateXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordChangeXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordJobsXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordJobXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordKillXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordMaterializeTransitionXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordPauseXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordPushDependencyCheckXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordRerunXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordResumeXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordSLAChangeXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordStatusTransitXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordSubmitXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordSuspendXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordUnpauseXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordUpdateXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.CoordWfActionInfoXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.coord.SLAEventsXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.NotificationXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.PurgeXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.RerunTransitionXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.SchemaCheckXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.sla.SLAJobEventXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.sla.SLAJobHistoryXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.SLAAlertsXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.ActionCheckXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.ActionEndXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.ActionKillXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.ActionStartXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.BulkWorkflowXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.CompletedActionXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.DefinitionXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.ExternalIdXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.JobsXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.JobXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.KillXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.ReRunXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.ResumeXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.SignalXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.SubmitMRXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.SubmitScriptLanguageXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.SubmitSqoopXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.SubmitXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.SuspendXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.WfEndXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.WorkflowActionInfoXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.wf.WorkflowActionRetryInfoXCommand
-
- verifyPrecondition() - Method in class org.apache.oozie.command.XCommand
-
Verify the precondition for the command after a lock has been obtain, just before executing the command.
- VersionServlet - Class in org.apache.oozie.servlet
-
- VersionServlet() - Constructor for class org.apache.oozie.servlet.VersionServlet
-
- visit(ASTOrNode, Object) - Method in class org.apache.oozie.coord.input.logic.OozieJexlInterpreter
-
- visit(ASTAndNode, Object) - Method in class org.apache.oozie.coord.input.logic.OozieJexlInterpreter