Uses of Class
org.apache.falcon.FalconException

Packages that use FalconException
org.apache.falcon.catalog   
org.apache.falcon.cleanup   
org.apache.falcon.converter   
org.apache.falcon.entity   
org.apache.falcon.entity.parser   
org.apache.falcon.entity.store   
org.apache.falcon.entity.v0   
org.apache.falcon.expression   
org.apache.falcon.group   
org.apache.falcon.latedata   
org.apache.falcon.logging   
org.apache.falcon.rerun.handler   
org.apache.falcon.rerun.policy   
org.apache.falcon.rerun.queue   
org.apache.falcon.rerun.service   
org.apache.falcon.resource   
org.apache.falcon.resource.channel   
org.apache.falcon.service   
org.apache.falcon.update   
org.apache.falcon.util   
org.apache.falcon.workflow   
org.apache.falcon.workflow.engine   
 

Uses of FalconException in org.apache.falcon.catalog
 

Methods in org.apache.falcon.catalog that throw FalconException
 boolean HiveCatalogService.dropPartitions(String catalogUrl, String database, String tableName, Map<String,String> partitions)
           
abstract  boolean AbstractCatalogService.dropPartitions(String catalogUrl, String database, String tableName, Map<String,String> partitions)
          Drops a given partition.
static org.apache.hcatalog.api.HCatClient HiveCatalogService.get(org.apache.falcon.entity.v0.cluster.Cluster cluster)
           
static org.apache.hcatalog.api.HCatClient HiveCatalogService.get(String metastoreUrl)
           
static AbstractCatalogService CatalogServiceFactory.getCatalogService()
           
 CatalogPartition HiveCatalogService.getPartition(String catalogUrl, String database, String tableName, Map<String,String> partitionSpec)
           
abstract  CatalogPartition AbstractCatalogService.getPartition(String catalogUrl, String database, String tableName, Map<String,String> partitionSpec)
          Gets the partition.
 boolean HiveCatalogService.isAlive(String catalogBaseUrl)
           
abstract  boolean AbstractCatalogService.isAlive(String catalogBaseUrl)
          This method checks if the catalog service is alive.
 boolean HiveCatalogService.isTableExternal(String catalogUrl, String database, String tableName)
           
abstract  boolean AbstractCatalogService.isTableExternal(String catalogUrl, String database, String tableName)
          Returns if the table is external or not.
 List<CatalogPartition> HiveCatalogService.listPartitionsByFilter(String catalogUrl, String database, String tableName, String filter)
           
abstract  List<CatalogPartition> AbstractCatalogService.listPartitionsByFilter(String catalogUrl, String database, String tableName, String filter)
          List partitions by filter.
 boolean HiveCatalogService.tableExists(String catalogUrl, String database, String tableName)
           
abstract  boolean AbstractCatalogService.tableExists(String catalogUrl, String database, String tableName)
          This method checks if the given table exists in the catalog.
 

Uses of FalconException in org.apache.falcon.cleanup
 

Methods in org.apache.falcon.cleanup that throw FalconException
 void ProcessCleanupHandler.cleanup()
           
 void FeedCleanupHandler.cleanup()
           
abstract  void AbstractCleanupHandler.cleanup()
           
protected  void AbstractCleanupHandler.delete(org.apache.falcon.entity.v0.cluster.Cluster cluster, Entity entity, long retention)
           
protected  void AbstractCleanupHandler.delete(org.apache.falcon.entity.v0.cluster.Cluster cluster, Entity entity, long retention, FileStatus[] logs)
           
protected  FileStatus[] AbstractCleanupHandler.getAllLogs(org.apache.falcon.entity.v0.cluster.Cluster cluster, Entity entity)
           
protected  FileSystem AbstractCleanupHandler.getFileSystem(org.apache.falcon.entity.v0.cluster.Cluster cluster)
           
protected  long AbstractCleanupHandler.getRetention(Entity entity, Frequency.TimeUnit timeUnit)
           
 

Uses of FalconException in org.apache.falcon.converter
 

Methods in org.apache.falcon.converter that throw FalconException
 COORDINATORAPP OozieProcessMapper.createDefaultCoordinator(org.apache.falcon.entity.v0.cluster.Cluster cluster, Path bundlePath)
          Creates default oozie coordinator.
protected  void OozieProcessMapper.createWorkflow(org.apache.falcon.entity.v0.cluster.Cluster cluster, org.apache.falcon.entity.v0.process.Process process, org.apache.falcon.entity.v0.process.Workflow processWorkflow, String wfName, Path wfPath)
           
protected  List<COORDINATORAPP> OozieFeedMapper.getCoordinators(org.apache.falcon.entity.v0.cluster.Cluster cluster, Path bundlePath)
           
protected  List<COORDINATORAPP> OozieProcessMapper.getCoordinators(org.apache.falcon.entity.v0.cluster.Cluster cluster, Path bundlePath)
           
protected abstract  List<COORDINATORAPP> AbstractOozieEntityMapper.getCoordinators(org.apache.falcon.entity.v0.cluster.Cluster cluster, Path bundlePath)
           
protected  COORDINATORAPP AbstractOozieEntityMapper.getCoordinatorTemplate(String template)
           
protected  WORKFLOWAPP AbstractOozieEntityMapper.getWorkflowTemplate(String template)
           
 boolean AbstractOozieEntityMapper.map(org.apache.falcon.entity.v0.cluster.Cluster cluster, Path bundlePath)
           
protected  void AbstractOozieEntityMapper.marshal(org.apache.falcon.entity.v0.cluster.Cluster cluster, BUNDLEAPP bundle, Path outPath)
           
protected  String AbstractOozieEntityMapper.marshal(org.apache.falcon.entity.v0.cluster.Cluster cluster, COORDINATORAPP coord, Path outPath, String name)
           
protected  void AbstractOozieEntityMapper.marshal(org.apache.falcon.entity.v0.cluster.Cluster cluster, JAXBElement<?> jaxbElement, JAXBContext jaxbContext, Path outPath)
           
protected  void AbstractOozieEntityMapper.marshal(org.apache.falcon.entity.v0.cluster.Cluster cluster, WORKFLOWAPP workflow, Path outPath)
           
 

Uses of FalconException in org.apache.falcon.entity
 

Subclasses of FalconException in org.apache.falcon.entity
 class EntityNotRegisteredException
          Exception thrown by falcon when entity is not registered already in config store.
 

Methods in org.apache.falcon.entity that throw FalconException
static Storage FeedHelper.createReadOnlyStorage(org.apache.falcon.entity.v0.cluster.Cluster clusterEntity, org.apache.falcon.entity.v0.feed.Feed feed)
          Factory method to dole out a storage instance used for replication source.
static Storage FeedHelper.createStorage(org.apache.falcon.entity.v0.cluster.Cluster clusterEntity, org.apache.falcon.entity.v0.feed.Feed feed)
           
static Storage FeedHelper.createStorage(org.apache.falcon.entity.v0.feed.Cluster cluster, org.apache.falcon.entity.v0.feed.Feed feed)
           
static Storage FeedHelper.createStorage(org.apache.falcon.entity.v0.feed.Cluster cluster, org.apache.falcon.entity.v0.feed.Feed feed, org.apache.falcon.entity.v0.cluster.Cluster clusterEntity)
           
static Storage FeedHelper.createStorage(org.apache.falcon.entity.v0.feed.Feed feed)
           
static Storage FeedHelper.createStorage(String clusterName, org.apache.falcon.entity.v0.feed.Feed feed)
           
static boolean EntityUtil.equals(Entity lhs, Entity rhs)
           
static boolean EntityUtil.equals(Entity lhs, Entity rhs, String[] filterProps)
           
static String FeedHelper.evaluateClusterExp(org.apache.falcon.entity.v0.cluster.Cluster clusterEntity, String exp)
           
 boolean Storage.exists()
          Check if the storage, filesystem location or catalog table exists.
 boolean FileSystemStorage.exists()
           
 boolean CatalogStorage.exists()
           
static String EntityUtil.fromUTCtoURIDate(String utc)
           
 Date ExternalId.getDate()
           
static
<T extends Entity>
T
EntityUtil.getEntity(EntityType type, String entityName)
           
static
<T extends Entity>
T
EntityUtil.getEntity(String type, String entityName)
           
static org.apache.falcon.entity.v0.process.LateProcess EntityUtil.getLateProcess(Entity entity)
           
static Path EntityUtil.getLogPath(org.apache.falcon.entity.v0.cluster.Cluster cluster, Entity entity)
           
static org.apache.falcon.entity.v0.process.Retry EntityUtil.getRetry(Entity entity)
           
static Path EntityUtil.getStagingPath(org.apache.falcon.entity.v0.cluster.Cluster cluster, Entity entity)
           
static String EntityUtil.getStagingPath(Entity entity)
           
static Storage.TYPE FeedHelper.getStorageType(org.apache.falcon.entity.v0.feed.Feed feed)
           
static Storage.TYPE FeedHelper.getStorageType(org.apache.falcon.entity.v0.feed.Feed feed, org.apache.falcon.entity.v0.feed.Cluster cluster)
           
static Storage.TYPE FeedHelper.getStorageType(org.apache.falcon.entity.v0.feed.Feed feed, org.apache.falcon.entity.v0.cluster.Cluster clusterEntity)
           
static String EntityUtil.getWorkflowNameSuffix(String workflowName, Entity entity)
           
 boolean Storage.isIdentical(Storage toCompareAgainst)
          Check for equality of this instance against the one in question.
 boolean FileSystemStorage.isIdentical(Storage toCompareAgainst)
           
 boolean CatalogStorage.isIdentical(Storage toCompareAgainst)
           
static String EntityUtil.md5(Entity entity)
           
 void ColoClusterRelation.onChange(Entity oldEntity, Entity newEntity)
           
static Date EntityUtil.parseDateUTC(String dateStr)
           
static String EntityUtil.stringOf(Entity entity)
           
 

Uses of FalconException in org.apache.falcon.entity.parser
 

Subclasses of FalconException in org.apache.falcon.entity.parser
 class ValidationException
          ValidationException during parsing.
 

Methods in org.apache.falcon.entity.parser that throw FalconException
 T EntityParser.parse(InputStream xmlStream)
          Parses xml stream.
 T EntityParser.parseAndValidate(InputStream xmlStream)
           
 Entity EntityParser.parseAndValidate(String xmlString)
          Parses a sent XML and validates it using JAXB.
 void FeedEntityParser.validate(org.apache.falcon.entity.v0.feed.Feed feed)
           
 void ProcessEntityParser.validate(org.apache.falcon.entity.v0.process.Process process)
           
abstract  void EntityParser.validate(T entity)
           
protected  void EntityParser.validateEntitiesExist(List<Pair<EntityType,String>> entities)
           
protected  void EntityParser.validateEntityExists(EntityType type, String name)
           
static void CrossEntityValidations.validateFeedDefinedForCluster(org.apache.falcon.entity.v0.feed.Feed feed, String clusterName)
           
static void CrossEntityValidations.validateFeedRetentionPeriod(String startInstance, org.apache.falcon.entity.v0.feed.Feed feed, String clusterName)
           
static void CrossEntityValidations.validateInstance(org.apache.falcon.entity.v0.process.Process process, org.apache.falcon.entity.v0.process.Output output, org.apache.falcon.entity.v0.feed.Feed feed)
           
static void CrossEntityValidations.validateInstanceRange(org.apache.falcon.entity.v0.process.Process process, org.apache.falcon.entity.v0.process.Input input, org.apache.falcon.entity.v0.feed.Feed feed)
           
 

Uses of FalconException in org.apache.falcon.entity.store
 

Subclasses of FalconException in org.apache.falcon.entity.store
 class EntityAlreadyExistsException
          Exception to thrown when entity being sought for addition is already present in config store.
 class StoreAccessException
          Exception when there in issue accessing the persistent store.
 

Methods in org.apache.falcon.entity.store that throw FalconException
<T extends Entity>
T
ConfigurationStore.get(EntityType type, String name)
           
 void ConfigurationStore.init()
           
 void ConfigurationStore.initiateUpdate(Entity entity)
           
 void ConfigurationStore.publish(EntityType type, Entity entity)
           
 boolean ConfigurationStore.remove(EntityType type, String name)
          Remove an entity which is already stored in the config store.
 void ConfigurationStore.update(EntityType type, Entity entity)
           
 

Uses of FalconException in org.apache.falcon.entity.v0
 

Subclasses of FalconException in org.apache.falcon.entity.v0
 class UnschedulableEntityException
          This exception is thrown when Unschedulable entity like CLUSTER is tried with actions like Schedule, Suspend, Resume.
 

Methods in org.apache.falcon.entity.v0 that throw FalconException
 Set<Entity> EntityGraph.getDependents(Entity entity)
           
 void EntityGraph.onAdd(Entity entity, boolean ignoreFailure)
           
 void EntityGraph.onChange(Entity oldEntity, Entity newEntity)
           
 void EntityGraph.onRemove(Entity entity)
           
static Pair<String,EntityType>[] EntityIntegrityChecker.referencedBy(Entity entity)
           
 

Uses of FalconException in org.apache.falcon.expression
 

Methods in org.apache.falcon.expression that throw FalconException
<T> T
ExpressionHelper.evaluate(String expression, Class<T> clazz)
           
<T> T
ExpressionHelper.evaluateFullExpression(String expression, Class<T> clazz)
           
 

Uses of FalconException in org.apache.falcon.group
 

Methods in org.apache.falcon.group that throw FalconException
 boolean FeedGroup.canContainFeed(org.apache.falcon.entity.v0.feed.Feed feed)
           
 Set<FeedGroup> FeedGroupMap.getGroups(org.apache.falcon.entity.v0.feed.Feed feed)
           
 void FeedGroupMap.onAdd(Entity entity, boolean ignoreFailure)
           
 void FeedGroupMap.onChange(Entity oldEntity, Entity newEntity)
           
 void FeedGroupMap.onRemove(Entity entity)
           
 

Uses of FalconException in org.apache.falcon.latedata
 

Methods in org.apache.falcon.latedata that throw FalconException
 long LateDataHandler.computeStorageMetric(String feedUriTemplate, String feedStorageType, Configuration conf)
          This method computes the storage metrics for a given feed's instance or partition.
 

Uses of FalconException in org.apache.falcon.logging
 

Methods in org.apache.falcon.logging that throw FalconException
 String LogProvider.getResolvedRunId(FileSystem fs, org.apache.falcon.entity.v0.cluster.Cluster cluster, Entity entity, org.apache.falcon.resource.InstancesResult.Instance instance, String runId)
           
 org.apache.falcon.resource.InstancesResult.Instance LogProvider.populateLogUrls(Entity entity, org.apache.falcon.resource.InstancesResult.Instance instance, String runId)
           
 

Uses of FalconException in org.apache.falcon.rerun.handler
 

Methods in org.apache.falcon.rerun.handler that throw FalconException
static Configuration LateRerunHandler.getConfiguration(String storageEndpoint)
           
static Date LateRerunHandler.getCutOffTime(Entity entity, String nominalTime)
           
 Entity AbstractRerunHandler.getEntity(String entityType, String entityName)
           
 org.apache.falcon.entity.v0.process.Retry AbstractRerunHandler.getRetry(Entity entity)
           
 void RetryHandler.init(M aDelayQueue)
           
 void LateRerunHandler.init(M aDelayQueue)
           
 void AbstractRerunHandler.init(M aDelayQueue)
           
 boolean AbstractRerunHandler.offerToQueue(T event)
           
 void AbstractRerunHandler.reconnect()
           
 T AbstractRerunHandler.takeFromQueue()
           
 

Uses of FalconException in org.apache.falcon.rerun.policy
 

Methods in org.apache.falcon.rerun.policy that throw FalconException
 long FinalPolicy.getDelay(Frequency delay, Date nominalTime, Date cutOffTime)
           
 long ExpBackoffPolicy.getDelay(Frequency delay, Date nominalTime, Date cutOffTime)
           
abstract  long AbstractRerunPolicy.getDelay(Frequency delay, Date nominaltime, Date cutOffTime)
           
 long FinalPolicy.getDelay(Frequency delay, int eventNumber)
           
 long ExpBackoffPolicy.getDelay(Frequency delay, int eventNumber)
           
abstract  long AbstractRerunPolicy.getDelay(Frequency delay, int eventNumber)
           
 long AbstractRerunPolicy.getDurationInMilliSec(Frequency frequency)
           
 

Uses of FalconException in org.apache.falcon.rerun.queue
 

Methods in org.apache.falcon.rerun.queue that throw FalconException
abstract  boolean DelayedQueue.offer(T event)
           
 boolean ActiveMQueue.offer(T event)
           
 void InMemoryQueue.reconnect()
           
abstract  void DelayedQueue.reconnect()
           
 void ActiveMQueue.reconnect()
           
 T InMemoryQueue.take()
           
abstract  T DelayedQueue.take()
           
 T ActiveMQueue.take()
           
 

Uses of FalconException in org.apache.falcon.rerun.service
 

Methods in org.apache.falcon.rerun.service that throw FalconException
 void RetryService.destroy()
           
 void LateRunService.destroy()
           
 void RetryService.init()
           
 void LateRunService.init()
           
 

Uses of FalconException in org.apache.falcon.resource
 

Methods in org.apache.falcon.resource that throw FalconException
protected  Entity AbstractEntityManager.deserializeEntity(javax.servlet.http.HttpServletRequest request, EntityType entityType)
           
protected  org.apache.falcon.resource.AbstractEntityManager.EntityStatus AbstractEntityManager.getStatus(Entity entity, EntityType type)
           
protected  Entity AbstractEntityManager.submitInternal(javax.servlet.http.HttpServletRequest request, String type)
           
 

Uses of FalconException in org.apache.falcon.resource.channel
 

Methods in org.apache.falcon.resource.channel that throw FalconException
static Channel ChannelFactory.get(String serviceName, String colo)
           
protected  Method AbstractChannel.getMethod(Class service, String methodName, Object... args)
           
 void IPCChannel.init(String ignoreColo, String serviceName)
           
 void HTTPChannel.init(String colo, String serviceName)
           
 void Channel.init(String colo, String serviceName)
           
<T> T
IPCChannel.invoke(String methodName, Object... args)
           
<T> T
HTTPChannel.invoke(String methodName, Object... args)
           
<T> T
Channel.invoke(String methodName, Object... args)
           
 

Uses of FalconException in org.apache.falcon.service
 

Methods in org.apache.falcon.service that throw FalconException
 void SLAMonitoringService.afterDelete(Entity entity, String cluster)
           
 void SLAMonitoringService.afterResume(Entity entity, String cluster)
           
 void SLAMonitoringService.afterSchedule(Entity entity, String cluster)
           
 void SLAMonitoringService.afterSuspend(Entity entity, String cluster)
           
 void SLAMonitoringService.beforeDelete(Entity entity, String cluster)
           
 void SLAMonitoringService.beforeResume(Entity entity, String cluster)
           
 void SLAMonitoringService.beforeSchedule(Entity entity, String cluster)
           
 void SLAMonitoringService.beforeSuspend(Entity entity, String cluster)
           
 void FalconTopicSubscriber.closeSubscriber()
           
 void SLAMonitoringService.destroy()
           
 void ProcessSubscriberService.destroy()
           
 void ServiceInitializer.destroy()
           
 void LogCleanupService.destroy()
           
 void FalconService.destroy()
           
 void SLAMonitoringService.init()
           
 void ProcessSubscriberService.init()
           
 void LogCleanupService.init()
           
 void FalconService.init()
           
 FalconService Services.init(String serviceName)
           
 void ServiceInitializer.initialize()
           
 void SharedLibraryHostingService.onAdd(Entity entity, boolean ignoreFailure)
           
 void ConfigurationChangeListener.onAdd(Entity entity, boolean ignoreFailure)
           
 void SharedLibraryHostingService.onChange(Entity oldEntity, Entity newEntity)
           
 void ConfigurationChangeListener.onChange(Entity oldEntity, Entity newEntity)
           
 void SharedLibraryHostingService.onRemove(Entity entity)
           
 void ConfigurationChangeListener.onRemove(Entity entity)
           
static void SharedLibraryHostingService.pushLibsToHDFS(String src, Path target, org.apache.falcon.entity.v0.cluster.Cluster cluster, FalconPathFilter pathFilter)
           
 void Services.register(FalconService service)
           
 void FalconTopicSubscriber.startSubscriber()
           
 

Uses of FalconException in org.apache.falcon.update
 

Methods in org.apache.falcon.update that throw FalconException
static boolean UpdateHelper.shouldUpdate(Entity oldEntity, Entity newEntity, Entity affectedEntity)
           
static boolean UpdateHelper.shouldUpdate(Entity oldEntity, Entity newEntity, String cluster)
           
static boolean UpdateHelper.shouldUpdate(org.apache.falcon.entity.v0.feed.Feed oldFeed, org.apache.falcon.entity.v0.feed.Feed newFeed, org.apache.falcon.entity.v0.process.Process affectedProcess)
           
 

Uses of FalconException in org.apache.falcon.util
 

Methods in org.apache.falcon.util that throw FalconException
static
<T> T
ReflectionUtils.getInstance(String classKey)
           
static
<T> T
ReflectionUtils.getInstanceByClassName(String clazzName)
           
protected  void ApplicationProperties.init()
           
protected  void ApplicationProperties.loadProperties()
           
protected  void ApplicationProperties.loadProperties(String propertyFileName, String confDir)
          This method reads the given properties file in the following order: config.location & classpath.
 

Constructors in org.apache.falcon.util that throw FalconException
ApplicationProperties()
           
 

Uses of FalconException in org.apache.falcon.workflow
 

Methods in org.apache.falcon.workflow that throw FalconException
protected  Properties OozieWorkflowBuilder.createAppProperties(String clusterName, Path bundlePath, String user)
           
static WorkflowBuilder<Entity> WorkflowBuilder.getBuilder(String engine, Entity entity)
           
 Date OozieFeedWorkflowBuilder.getNextStartTime(org.apache.falcon.entity.v0.feed.Feed feed, String cluster, Date now)
           
 Date OozieProcessWorkflowBuilder.getNextStartTime(org.apache.falcon.entity.v0.process.Process process, String cluster, Date now)
           
abstract  Date OozieWorkflowBuilder.getNextStartTime(T entity, String cluster, Date now)
           
static AbstractWorkflowEngine WorkflowEngineFactory.getWorkflowEngine()
           
 Properties OozieFeedWorkflowBuilder.newWorkflowSchedule(org.apache.falcon.entity.v0.feed.Feed feed, Date startDate, String clusterName, String user)
           
 Map<String,Properties> OozieFeedWorkflowBuilder.newWorkflowSchedule(org.apache.falcon.entity.v0.feed.Feed feed, List<String> clusters)
           
 Properties OozieProcessWorkflowBuilder.newWorkflowSchedule(org.apache.falcon.entity.v0.process.Process process, Date startDate, String clusterName, String user)
           
 Map<String,Properties> OozieProcessWorkflowBuilder.newWorkflowSchedule(org.apache.falcon.entity.v0.process.Process process, List<String> clusters)
           
abstract  Properties WorkflowBuilder.newWorkflowSchedule(T entity, Date startDate, String clusterName, String user)
           
abstract  Map<String,Properties> WorkflowBuilder.newWorkflowSchedule(T entity, List<String> clusters)
           
 

Uses of FalconException in org.apache.falcon.workflow.engine
 

Methods in org.apache.falcon.workflow.engine that throw FalconException
 void OozieHouseKeepingService.afterDelete(Entity entity, String clusterName)
           
 void WorkflowEngineActionListener.afterDelete(Entity entity, String cluster)
           
 void OozieHouseKeepingService.afterResume(Entity entity, String cluster)
           
 void WorkflowEngineActionListener.afterResume(Entity entity, String cluster)
           
 void OozieHouseKeepingService.afterSchedule(Entity entity, String cluster)
           
 void WorkflowEngineActionListener.afterSchedule(Entity entity, String cluster)
           
 void OozieHouseKeepingService.afterSuspend(Entity entity, String cluster)
           
 void WorkflowEngineActionListener.afterSuspend(Entity entity, String cluster)
           
 void OozieHouseKeepingService.beforeDelete(Entity entity, String cluster)
           
 void WorkflowEngineActionListener.beforeDelete(Entity entity, String cluster)
           
 void OozieHouseKeepingService.beforeResume(Entity entity, String cluster)
           
 void WorkflowEngineActionListener.beforeResume(Entity entity, String cluster)
           
 void OozieHouseKeepingService.beforeSchedule(Entity entity, String cluster)
           
 void WorkflowEngineActionListener.beforeSchedule(Entity entity, String cluster)
           
 void OozieHouseKeepingService.beforeSuspend(Entity entity, String cluster)
           
 void WorkflowEngineActionListener.beforeSuspend(Entity entity, String cluster)
           
 String OozieWorkflowEngine.delete(Entity entity)
           
abstract  String AbstractWorkflowEngine.delete(Entity entity)
           
 String OozieWorkflowEngine.delete(Entity entity, String cluster)
           
abstract  String AbstractWorkflowEngine.delete(Entity entity, String cluster)
           
static OozieClient OozieClientFactory.get(org.apache.falcon.entity.v0.cluster.Cluster cluster)
           
static OozieClient OozieClientFactory.get(String cluster)
           
protected  Map<String,List<CoordinatorAction>> OozieWorkflowEngine.getCoordActions(Entity entity, Date start, Date end)
           
 org.apache.falcon.resource.InstancesResult OozieWorkflowEngine.getJobDetails(String cluster, String jobId)
           
abstract  org.apache.falcon.resource.InstancesResult AbstractWorkflowEngine.getJobDetails(String cluster, String jobId)
           
 org.apache.falcon.resource.InstancesResult OozieWorkflowEngine.getRunningInstances(Entity entity)
           
abstract  org.apache.falcon.resource.InstancesResult AbstractWorkflowEngine.getRunningInstances(Entity entity)
           
 org.apache.falcon.resource.InstancesResult OozieWorkflowEngine.getStatus(Entity entity, Date start, Date end)
           
abstract  org.apache.falcon.resource.InstancesResult AbstractWorkflowEngine.getStatus(Entity entity, Date start, Date end)
           
 Properties OozieWorkflowEngine.getWorkflowProperties(String cluster, String jobId)
           
abstract  Properties AbstractWorkflowEngine.getWorkflowProperties(String cluster, String jobId)
           
 String OozieWorkflowEngine.getWorkflowStatus(String cluster, String jobId)
           
abstract  String AbstractWorkflowEngine.getWorkflowStatus(String cluster, String jobId)
           
 boolean OozieWorkflowEngine.isActive(Entity entity)
           
abstract  boolean AbstractWorkflowEngine.isActive(Entity entity)
           
 boolean OozieWorkflowEngine.isAlive(org.apache.falcon.entity.v0.cluster.Cluster cluster)
           
abstract  boolean AbstractWorkflowEngine.isAlive(org.apache.falcon.entity.v0.cluster.Cluster cluster)
           
 boolean OozieWorkflowEngine.isSuspended(Entity entity)
           
abstract  boolean AbstractWorkflowEngine.isSuspended(Entity entity)
           
 org.apache.falcon.resource.InstancesResult OozieWorkflowEngine.killInstances(Entity entity, Date start, Date end, Properties props)
           
abstract  org.apache.falcon.resource.InstancesResult AbstractWorkflowEngine.killInstances(Entity entity, Date start, Date end, Properties props)
           
 void OozieWorkflowEngine.reRun(String cluster, String jobId, Properties props)
           
abstract  void AbstractWorkflowEngine.reRun(String cluster, String wfId, Properties props)
           
 org.apache.falcon.resource.InstancesResult OozieWorkflowEngine.reRunInstances(Entity entity, Date start, Date end, Properties props)
           
abstract  org.apache.falcon.resource.InstancesResult AbstractWorkflowEngine.reRunInstances(Entity entity, Date start, Date end, Properties props)
           
 String OozieWorkflowEngine.resume(Entity entity)
           
abstract  String AbstractWorkflowEngine.resume(Entity entity)
           
 org.apache.falcon.resource.InstancesResult OozieWorkflowEngine.resumeInstances(Entity entity, Date start, Date end, Properties props)
           
abstract  org.apache.falcon.resource.InstancesResult AbstractWorkflowEngine.resumeInstances(Entity entity, Date start, Date end, Properties props)
           
 void OozieWorkflowEngine.schedule(Entity entity)
           
abstract  void AbstractWorkflowEngine.schedule(Entity entity)
           
 String OozieWorkflowEngine.suspend(Entity entity)
           
abstract  String AbstractWorkflowEngine.suspend(Entity entity)
           
 org.apache.falcon.resource.InstancesResult OozieWorkflowEngine.suspendInstances(Entity entity, Date start, Date end, Properties props)
           
abstract  org.apache.falcon.resource.InstancesResult AbstractWorkflowEngine.suspendInstances(Entity entity, Date start, Date end, Properties props)
           
 void OozieWorkflowEngine.update(Entity oldEntity, Entity newEntity, String cluster)
           
abstract  void AbstractWorkflowEngine.update(Entity oldEntity, Entity newEntity, String cluster)
           
 



Copyright © 2013-2014 Apache Software Foundation. All Rights Reserved.