A B C D E F G H I J K L M O P Q R S T U V W Y 

A

AbstractBatchAppmaster - Class in org.springframework.yarn.batch.am
Base application master for running batch jobs.
AbstractBatchAppmaster() - Constructor for class org.springframework.yarn.batch.am.AbstractBatchAppmaster
 
AbstractBatchYarnContainer - Class in org.springframework.yarn.batch.container
Base implementation of YarnContainer extending AbstractIntegrationYarnContainer adding functionality for Spring Batch.
AbstractBatchYarnContainer() - Constructor for class org.springframework.yarn.batch.container.AbstractBatchYarnContainer
 
AbstractPartitioner - Class in org.springframework.yarn.batch.partition
Base class providing share functionality for batch Partitioner.
AbstractPartitioner() - Constructor for class org.springframework.yarn.batch.partition.AbstractPartitioner
 
AbstractPartitionHandler - Class in org.springframework.yarn.batch.partition
Base implementation of Spring Batch PartitionHandler handling partitioning for Yarn containers.
AbstractPartitionHandler() - Constructor for class org.springframework.yarn.batch.partition.AbstractPartitionHandler
Instantiates a new abstract partition handler.
AbstractPartitionHandler(BatchYarnAppmaster) - Constructor for class org.springframework.yarn.batch.partition.AbstractPartitionHandler
Instantiates a new abstract partition handler.
AbstractRemoteDao - Class in org.springframework.yarn.batch.repository
Base class for all daos handling remote calls through AppmasterScOperations.
AbstractRemoteDao() - Constructor for class org.springframework.yarn.batch.repository.AbstractRemoteDao
Default constructor.
AbstractRemoteDao(AppmasterMindScOperations) - Constructor for class org.springframework.yarn.batch.repository.AbstractRemoteDao
Constructor which sets the AppmasterMindScOperations.
add(JobRepositoryRemoteServiceInterceptor) - Method in class org.springframework.yarn.batch.repository.BatchAppmasterService.JobRepositoryServiceInterceptorList
Adds interceptor to the list.
add(StepExecution) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
addAll(Collection<StepExecution>) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
addInterceptor(JobRepositoryRemoteServiceInterceptor) - Method in class org.springframework.yarn.batch.repository.BatchAppmasterService
Add a service interceptor to the end of the list.
addPartitionedStepExecutionStateListener(PartitionedStepExecutionStateListener) - Method in class org.springframework.yarn.batch.am.AbstractBatchAppmaster
Adds the partitioned step execution state listener.
addPartitionedStepExecutionStateListener(PartitionedStepExecutionStateListener) - Method in interface org.springframework.yarn.batch.am.BatchYarnAppmaster
Adds the partitioned step execution state listener.
addStepSplits(StepExecution, String, Set<StepExecution>, Map<StepExecution, ContainerRequestHint>) - Method in class org.springframework.yarn.batch.am.AbstractBatchAppmaster
Adds the step splits.
addStepSplits(StepExecution, String, Set<StepExecution>, Map<StepExecution, ContainerRequestHint>) - Method in interface org.springframework.yarn.batch.am.BatchYarnAppmaster
Adds the step splits.
AddWithStepExecutionReq - Class in org.springframework.yarn.batch.repository.bindings.repo
AddWithStepExecutionReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.AddWithStepExecutionReq
 
AddWithStepExecutionRes - Class in org.springframework.yarn.batch.repository.bindings.repo
Response binding for JobRepository.add(StepExecution).
AddWithStepExecutionRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.AddWithStepExecutionRes
 
appmasterService() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
appmasterServiceClient() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 

B

BatchAppmaster - Class in org.springframework.yarn.batch.am
Implementation of application master which can be used to run Spring Batch jobs on Hadoop Yarn cluster.
BatchAppmaster() - Constructor for class org.springframework.yarn.batch.am.BatchAppmaster
 
BatchAppmasterService - Class in org.springframework.yarn.batch.repository
Application master service implementation which is used for remote Spring Batch steps to talk to Job Repository.
BatchAppmasterService() - Constructor for class org.springframework.yarn.batch.repository.BatchAppmasterService
 
BatchAppmasterService.JobRepositoryServiceInterceptorList - Class in org.springframework.yarn.batch.repository
Convenient wrapper for interceptor list.
BatchAppmasterService.JobRepositoryServiceInterceptorList() - Constructor for class org.springframework.yarn.batch.repository.BatchAppmasterService.JobRepositoryServiceInterceptorList
 
BatchMasterParser - Class in org.springframework.yarn.batch.config
Simple namespace parser for batch:master.
BatchMasterParser() - Constructor for class org.springframework.yarn.batch.config.BatchMasterParser
 
BatchNamespaceHandler - Class in org.springframework.yarn.batch.config
Handler for <yarn-batch> namespace.
BatchNamespaceHandler() - Constructor for class org.springframework.yarn.batch.config.BatchNamespaceHandler
 
BatchSystemConstants - Class in org.springframework.yarn.batch
Various constants throughout the batch package.
BatchSystemConstants() - Constructor for class org.springframework.yarn.batch.BatchSystemConstants
 
BatchYarnAppmaster - Interface in org.springframework.yarn.batch.am
Extended interface YarnAppmasters used with Spring Batch.
BeanFactoryStepLocator - Class in org.springframework.yarn.batch.support
A StepLocator implementation that just looks in its enclosing bean factory for components of type Step.
BeanFactoryStepLocator() - Constructor for class org.springframework.yarn.batch.support.BeanFactoryStepLocator
 
buildAddWithStepExecutionReq(StepExecution) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildCreateJobExecutionReq(String, JobParameters) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildCreateJobExecutionWithJobInstanceReq(JobInstance, JobParameters, String) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildCreateJobInstanceReq(String, JobParameters) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildFindJobInstancesByJobNameReq(String, int, int) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildFindRunningJobExecutionsReq(String) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildGetJobExecutionReq(Long) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildGetJobExecutionsReq(JobInstance) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildGetJobInstanceCountReq(String) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildGetJobInstanceReq(Long) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildGetJobInstancesReq(String, int, int) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
Builds request for getting a job instance by its name and paging info.
buildGetJobNamesReq() - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildGetLastJobExecutionReq(String, JobParameters) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildGetLastStepExecutionReq(JobInstance, String) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildGetStepExecutionCountReq(JobInstance, String) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildGetStepExecutionReq(Long, Long) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildIsJobInstanceExistsReq(String, JobParameters) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildSaveJobExecutionReq(JobExecution) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
buildUpdateExecutionContextReq(StepExecution) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
Builds request for updating execution context from a step execution.
buildUpdateExecutionContextReq(JobExecution) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
Builds request for updating execution context from a job execution.
buildUpdateWithStepExecutionReq(StepExecution) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 

C

checkResponseMayThrow(BaseResponseObject) - Method in class org.springframework.yarn.batch.repository.AbstractRemoteDao
Checks status of a response and throws an exception if response status message is set to 'error'.
clazz - Variable in class org.springframework.yarn.batch.repository.bindings.ExecutionContextType.ObjectEntry
 
close() - Method in class org.springframework.yarn.batch.item.DataStoreItemReader
 
commitCount - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
CompositePartitionedStepExecutionStateListener - Class in org.springframework.yarn.batch.listener
Composite listener for handling partitioned step state events.
CompositePartitionedStepExecutionStateListener() - Constructor for class org.springframework.yarn.batch.listener.CompositePartitionedStepExecutionStateListener
 
consumerEndpointFactoryBean() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
convertException(Exception) - Method in class org.springframework.yarn.batch.repository.AbstractRemoteDao
Converts given exception to Spring dao exception.
convertExecutionContext(ExecutionContext) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
convertExecutionContextType(ExecutionContextType) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
convertJobExecutionType(JobExecution) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
convertJobExecutionType(JobExecution, StepExecution) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
convertJobExecutionType(JobExecutionType) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
convertJobInstanceType(JobInstance) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
convertJobInstanceType(JobInstanceType) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
convertJobParameters(JobParameters) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
convertJobParametersType(JobParametersType) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
convertStepExecutionType(StepExecution) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
convertStepExecutionType(StepExecution, JobExecution) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
convertStepExecutionType(StepExecutionType) - Static method in class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
count - Variable in class org.springframework.yarn.batch.repository.bindings.exp.FindJobInstancesByJobNameReq
 
count - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstanceCountRes
 
count - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstancesReq
 
count - Variable in class org.springframework.yarn.batch.repository.bindings.repo.GetStepExecutionCountRes
 
createExecutionContext(Resource, Split) - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
Creates the execution context.
createExecutionContext(Path, Split) - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
Creates the execution context.
createJobExecution(String, JobParameters) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
createJobExecution(JobInstance, JobParameters, String) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
CreateJobExecutionReq - Class in org.springframework.yarn.batch.repository.bindings.repo
CreateJobExecutionReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.CreateJobExecutionReq
 
CreateJobExecutionRes - Class in org.springframework.yarn.batch.repository.bindings.repo
CreateJobExecutionRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.CreateJobExecutionRes
 
CreateJobExecutionWithJobInstanceReq - Class in org.springframework.yarn.batch.repository.bindings.repo
CreateJobExecutionWithJobInstanceReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.CreateJobExecutionWithJobInstanceReq
 
CreateJobExecutionWithJobInstanceRes - Class in org.springframework.yarn.batch.repository.bindings.repo
CreateJobExecutionWithJobInstanceRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.CreateJobExecutionWithJobInstanceRes
 
createJobInstance(String, JobParameters) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
CreateJobInstanceReq - Class in org.springframework.yarn.batch.repository.bindings.repo
CreateJobInstanceReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.CreateJobInstanceReq
 
CreateJobInstanceRes - Class in org.springframework.yarn.batch.repository.bindings.repo
CreateJobInstanceRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.CreateJobInstanceRes
 
createPartitions() - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
Creates the ExecutionContexts for partitions.
createPartitions() - Method in class org.springframework.yarn.batch.partition.SplitterPartitioner
 
createRequestData(Set<StepExecution>) - Method in class org.springframework.yarn.batch.partition.AbstractPartitionHandler
Subclass may override this method to assign a specific ContainerRequestHint to a StepExecution.
createRequestData(Set<StepExecution>) - Method in class org.springframework.yarn.batch.partition.SplitterPartitionHandler
 
createSplits(StepExecutionSplitter, StepExecution) - Method in class org.springframework.yarn.batch.partition.AbstractPartitionHandler
Creates the splits.
createSplits(StepExecutionSplitter, StepExecution) - Method in class org.springframework.yarn.batch.partition.SplitterPartitionHandler
 
createSplits(StepExecutionSplitter, StepExecution) - Method in class org.springframework.yarn.batch.partition.StaticPartitionHandler
 
createTime - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 

D

DataStoreItemReader<T> - Class in org.springframework.yarn.batch.item
Implementation of ItemReader able to read items from HDFS file splits.
DataStoreItemReader() - Constructor for class org.springframework.yarn.batch.item.DataStoreItemReader
Instantiates a new data store item reader.
DataStoreItemReader(DataStoreReader<T>) - Constructor for class org.springframework.yarn.batch.item.DataStoreItemReader
Instantiates a new data store item reader.
DefaultBatchYarnContainer - Class in org.springframework.yarn.batch.container
Default implementation of AbstractBatchYarnContainer to handle Spring Batch remote steps.
DefaultBatchYarnContainer() - Constructor for class org.springframework.yarn.batch.container.DefaultBatchYarnContainer
 
defaultPortExposingTcpSocketSupport() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
directChannel() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
directChannel() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
doStart() - Method in class org.springframework.yarn.batch.am.BatchAppmaster
 
doStop() - Method in class org.springframework.yarn.batch.am.BatchAppmaster
 

E

EnableYarnBatchProcessing - Annotation Type in org.springframework.yarn.batch.config
Enabled Spring Batch processing used with Yarn Appmaster.
EnableYarnRemoteBatchProcessing - Annotation Type in org.springframework.yarn.batch.config
Enabled Spring Batch processing used with Yarn Container.
endTime - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
endTime - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
executeJob(Job, JobParameters) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
 
executionContext - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
executionContext - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
ExecutionContextType - Class in org.springframework.yarn.batch.repository.bindings
Binding for ExecutionContext.
ExecutionContextType() - Constructor for class org.springframework.yarn.batch.repository.bindings.ExecutionContextType
 
ExecutionContextType.ObjectEntry - Class in org.springframework.yarn.batch.repository.bindings
 
ExecutionContextType.ObjectEntry() - Constructor for class org.springframework.yarn.batch.repository.bindings.ExecutionContextType.ObjectEntry
 
ExecutionContextType.ObjectEntry(Object, String) - Constructor for class org.springframework.yarn.batch.repository.bindings.ExecutionContextType.ObjectEntry
 
executionId - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobExecutionReq
 
exitStatus - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
exitStatus - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 

F

filterCount - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
findJobInstancesByJobName(String, int, int) - Method in class org.springframework.yarn.batch.repository.RemoteJobExplorer
 
FindJobInstancesByJobNameReq - Class in org.springframework.yarn.batch.repository.bindings.exp
FindJobInstancesByJobNameReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.FindJobInstancesByJobNameReq
 
FindJobInstancesByJobNameRes - Class in org.springframework.yarn.batch.repository.bindings.exp
FindJobInstancesByJobNameRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.FindJobInstancesByJobNameRes
 
findRunningJobExecutions(String) - Method in class org.springframework.yarn.batch.repository.RemoteJobExplorer
 
FindRunningJobExecutionsReq - Class in org.springframework.yarn.batch.repository.bindings.exp
FindRunningJobExecutionsReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.FindRunningJobExecutionsReq
 
FindRunningJobExecutionsRes - Class in org.springframework.yarn.batch.repository.bindings.exp
FindRunningJobExecutionsRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.FindRunningJobExecutionsRes
 

G

get(BaseObject) - Method in class org.springframework.yarn.batch.repository.JobRepositoryService
 
getAppmasterScOperations() - Method in class org.springframework.yarn.batch.repository.AbstractRemoteDao
Gets the AppmasterMindScOperations for this implementation.
getConfiguration() - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
Gets the hadoop configuration.
getId() - Method in class org.springframework.yarn.batch.repository.bindings.repo.AddWithStepExecutionRes
 
getId() - Method in class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithJobExecutionRes
 
getId() - Method in class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithStepExecutionRes
 
getInterceptors() - Method in class org.springframework.yarn.batch.repository.BatchAppmasterService
Exposes the interceptor list for subclasses.
getJobExecution() - Method in class org.springframework.yarn.batch.event.JobExecutionEvent
Gets the job execution for this event.
getJobExecution(Long) - Method in class org.springframework.yarn.batch.repository.RemoteJobExplorer
 
GetJobExecutionReq - Class in org.springframework.yarn.batch.repository.bindings.exp
GetJobExecutionReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobExecutionReq
 
GetJobExecutionRes - Class in org.springframework.yarn.batch.repository.bindings.exp
Response binding for JobExplorer.getJobExecution(Long).
GetJobExecutionRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobExecutionRes
 
getJobExecutions(JobInstance) - Method in class org.springframework.yarn.batch.repository.RemoteJobExplorer
 
GetJobExecutionsReq - Class in org.springframework.yarn.batch.repository.bindings.exp
GetJobExecutionsReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobExecutionsReq
 
GetJobExecutionsRes - Class in org.springframework.yarn.batch.repository.bindings.exp
GetJobExecutionsRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobExecutionsRes
 
getJobExplorer() - Method in class org.springframework.yarn.batch.container.AbstractBatchYarnContainer
Gets the job explorer.
getJobExplorer() - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
 
getJobInstance(Long) - Method in class org.springframework.yarn.batch.repository.RemoteJobExplorer
 
getJobInstanceCount(String) - Method in class org.springframework.yarn.batch.repository.RemoteJobExplorer
 
GetJobInstanceCountReq - Class in org.springframework.yarn.batch.repository.bindings.exp
GetJobInstanceCountReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstanceCountReq
 
GetJobInstanceCountRes - Class in org.springframework.yarn.batch.repository.bindings.exp
GetJobInstanceCountRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstanceCountRes
 
GetJobInstanceReq - Class in org.springframework.yarn.batch.repository.bindings.exp
GetJobInstanceReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstanceReq
 
GetJobInstanceRes - Class in org.springframework.yarn.batch.repository.bindings.exp
Response binding for JobExplorer.getJobInstance(Long).
GetJobInstanceRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstanceRes
 
getJobInstances(String, int, int) - Method in class org.springframework.yarn.batch.repository.RemoteJobExplorer
 
GetJobInstancesReq - Class in org.springframework.yarn.batch.repository.bindings.exp
GetJobInstancesReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstancesReq
 
GetJobInstancesRes - Class in org.springframework.yarn.batch.repository.bindings.exp
GetJobInstancesRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstancesRes
 
getJobLauncher() - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
Gets the job launcher.
getJobName() - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
Gets the enabled job name.
getJobNames() - Method in class org.springframework.yarn.batch.repository.RemoteJobExplorer
 
GetJobNamesReq - Class in org.springframework.yarn.batch.repository.bindings.exp
Request binding for JobExplorer.getJobNames().
GetJobNamesReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobNamesReq
 
GetJobNamesRes - Class in org.springframework.yarn.batch.repository.bindings.exp
Response binding for JobExplorer.getJobNames().
GetJobNamesRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetJobNamesRes
 
getJobProperties(String) - Method in class org.springframework.yarn.batch.support.YarnBatchProperties
Find first occurrence for given job.
getJobRegistry() - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
 
getJobs() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties
 
getJobs() - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
Gets the jobs.
getKeyFileName() - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
Gets the key for a file name.
getKeySplitLength() - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
Gets the key for split length.
getKeySplitLocations() - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
Gets the key for split locations.
getKeySplitLocations() - Method in class org.springframework.yarn.batch.partition.AbstractPartitionHandler
Gets the key split locations.
getKeySplitStart() - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
Gets the key for split start.
getLastJobExecution(String, JobParameters) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
GetLastJobExecutionReq - Class in org.springframework.yarn.batch.repository.bindings.repo
GetLastJobExecutionReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.GetLastJobExecutionReq
 
GetLastJobExecutionRes - Class in org.springframework.yarn.batch.repository.bindings.repo
GetLastJobExecutionRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.GetLastJobExecutionRes
 
getLastStepExecution(JobInstance, String) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
GetLastStepExecutionReq - Class in org.springframework.yarn.batch.repository.bindings.repo
GetLastStepExecutionReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.GetLastStepExecutionReq
 
GetLastStepExecutionRes - Class in org.springframework.yarn.batch.repository.bindings.repo
GetLastStepExecutionRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.GetLastStepExecutionRes
 
getName() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties
 
getName() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
getParameters() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
getPartitionBaseIdentifier() - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
Gets the partition base identifier.
getStep(String) - Method in class org.springframework.yarn.batch.support.BeanFactoryStepLocator
Look up a bean with the provided name of type Step.
getStepExecution() - Method in class org.springframework.yarn.batch.event.PartitionedStepExecutionEvent
Gets the step execution for this event.
getStepExecution(Long, Long) - Method in class org.springframework.yarn.batch.repository.RemoteJobExplorer
 
getStepExecutionCount(JobInstance, String) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
GetStepExecutionCountReq - Class in org.springframework.yarn.batch.repository.bindings.repo
GetStepExecutionCountReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.GetStepExecutionCountReq
 
GetStepExecutionCountRes - Class in org.springframework.yarn.batch.repository.bindings.repo
GetStepExecutionCountRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.GetStepExecutionCountRes
 
GetStepExecutionReq - Class in org.springframework.yarn.batch.repository.bindings.exp
GetStepExecutionReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetStepExecutionReq
 
GetStepExecutionRes - Class in org.springframework.yarn.batch.repository.bindings.exp
GetStepExecutionRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.exp.GetStepExecutionRes
 
getStepExecutions() - Method in class org.springframework.yarn.batch.am.AbstractBatchAppmaster
Gets the step executions.
getStepExecutions() - Method in interface org.springframework.yarn.batch.am.BatchYarnAppmaster
Gets the step executions.
getStepLocator() - Method in class org.springframework.yarn.batch.container.AbstractBatchYarnContainer
Gets the step locator.
getStepName() - Method in class org.springframework.yarn.batch.partition.AbstractPartitionHandler
Gets the remote step name.
getStepNames() - Method in class org.springframework.yarn.batch.support.BeanFactoryStepLocator
Look in the bean factory for all beans of type Step.
getVersion() - Method in class org.springframework.yarn.batch.repository.bindings.repo.AddWithStepExecutionRes
 
getVersion() - Method in class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithJobExecutionRes
 
getVersion() - Method in class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithStepExecutionRes
 
getYarnJobLauncher() - Method in class org.springframework.yarn.batch.am.AbstractBatchAppmaster
 

H

handle(StepExecutionSplitter, StepExecution) - Method in class org.springframework.yarn.batch.partition.AbstractPartitionHandler
 
handleMindMessageInternal(MindRpcMessageHolder) - Method in class org.springframework.yarn.batch.repository.BatchAppmasterService
 
handleRequest(BaseObject) - Method in class org.springframework.yarn.batch.repository.BatchAppmasterService.JobRepositoryServiceInterceptorList
Handles the handleRequest calls.
handleRequest(BaseObject) - Method in interface org.springframework.yarn.batch.repository.JobRepositoryRemoteServiceInterceptor
Handles request if at least one interceptor returned null from a JobRepositoryRemoteServiceInterceptor.preRequest(BaseObject) method.

I

id - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
id - Variable in class org.springframework.yarn.batch.repository.bindings.JobInstanceType
 
id - Variable in class org.springframework.yarn.batch.repository.bindings.repo.AddWithStepExecutionRes
 
id - Variable in class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithJobExecutionRes
 
id - Variable in class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithStepExecutionRes
 
id - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
init() - Method in class org.springframework.yarn.batch.config.BatchNamespaceHandler
 
instanceId - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstanceReq
 
isEnabled() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties
 
isEnabled() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
isFailNext() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
isFailRestart() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
isJobInstanceExists(String, JobParameters) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
IsJobInstanceExistsReq - Class in org.springframework.yarn.batch.repository.bindings.repo
IsJobInstanceExistsReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.IsJobInstanceExistsReq
 
IsJobInstanceExistsRes - Class in org.springframework.yarn.batch.repository.bindings.repo
IsJobInstanceExistsRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.IsJobInstanceExistsRes
 
IsJobInstanceExistsRes(Boolean) - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.IsJobInstanceExistsRes
 
isNext() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
isRestart() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
isSaveState() - Method in class org.springframework.yarn.batch.item.DataStoreItemReader
The flag that determines whether to save internal state for restarts.

J

jobBuilders() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
jobConfigurationLocation - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
jobConfigurationLocation - Variable in class org.springframework.yarn.batch.repository.bindings.repo.CreateJobExecutionWithJobInstanceReq
 
jobExecution - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobExecutionRes
 
jobExecution - Variable in class org.springframework.yarn.batch.repository.bindings.repo.CreateJobExecutionRes
 
jobExecution - Variable in class org.springframework.yarn.batch.repository.bindings.repo.CreateJobExecutionWithJobInstanceRes
 
jobExecution - Variable in class org.springframework.yarn.batch.repository.bindings.repo.GetLastJobExecutionRes
 
jobExecution - Variable in class org.springframework.yarn.batch.repository.bindings.repo.UpdateExecutionContextReq
 
jobExecution - Variable in class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithJobExecutionReq
 
jobExecution - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
JobExecutionEvent - Class in org.springframework.yarn.batch.event
Generic event representing that Batch JobExecution has happened.
JobExecutionEvent(Object, JobExecution) - Constructor for class org.springframework.yarn.batch.event.JobExecutionEvent
Constructs event with the given StepExecution.
jobExecutionId - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetStepExecutionReq
 
jobExecutions - Variable in class org.springframework.yarn.batch.repository.bindings.exp.FindRunningJobExecutionsRes
 
jobExecutions - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobExecutionsRes
 
JobExecutionType - Class in org.springframework.yarn.batch.repository.bindings
Binding for JobExecution.
JobExecutionType() - Constructor for class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
jobExplorer() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
jobExplorer() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
jobInstance - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobExecutionsReq
 
jobInstance - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstanceRes
 
jobInstance - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
jobInstance - Variable in class org.springframework.yarn.batch.repository.bindings.repo.CreateJobExecutionWithJobInstanceReq
 
jobInstance - Variable in class org.springframework.yarn.batch.repository.bindings.repo.CreateJobInstanceRes
 
jobInstance - Variable in class org.springframework.yarn.batch.repository.bindings.repo.GetLastStepExecutionReq
 
jobInstance - Variable in class org.springframework.yarn.batch.repository.bindings.repo.GetStepExecutionCountReq
 
jobInstances - Variable in class org.springframework.yarn.batch.repository.bindings.exp.FindJobInstancesByJobNameRes
 
jobInstances - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstancesRes
 
JobInstanceType - Class in org.springframework.yarn.batch.repository.bindings
Bindings for JobInstance.
JobInstanceType() - Constructor for class org.springframework.yarn.batch.repository.bindings.JobInstanceType
 
jobName - Variable in class org.springframework.yarn.batch.repository.bindings.exp.FindJobInstancesByJobNameReq
 
jobName - Variable in class org.springframework.yarn.batch.repository.bindings.exp.FindRunningJobExecutionsReq
 
jobName - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstanceCountReq
 
jobName - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstancesReq
 
jobName - Variable in class org.springframework.yarn.batch.repository.bindings.JobInstanceType
 
jobName - Variable in class org.springframework.yarn.batch.repository.bindings.repo.CreateJobExecutionReq
 
jobName - Variable in class org.springframework.yarn.batch.repository.bindings.repo.CreateJobInstanceReq
 
jobName - Variable in class org.springframework.yarn.batch.repository.bindings.repo.GetLastJobExecutionReq
 
jobName - Variable in class org.springframework.yarn.batch.repository.bindings.repo.IsJobInstanceExistsReq
 
jobNames - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobNamesRes
 
jobParameters - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
jobParameters - Variable in class org.springframework.yarn.batch.repository.bindings.repo.CreateJobExecutionReq
 
jobParameters - Variable in class org.springframework.yarn.batch.repository.bindings.repo.CreateJobExecutionWithJobInstanceReq
 
jobParameters - Variable in class org.springframework.yarn.batch.repository.bindings.repo.CreateJobInstanceReq
 
jobParameters - Variable in class org.springframework.yarn.batch.repository.bindings.repo.GetLastJobExecutionReq
 
jobParameters - Variable in class org.springframework.yarn.batch.repository.bindings.repo.IsJobInstanceExistsReq
 
JobParametersType - Class in org.springframework.yarn.batch.repository.bindings
Binding for JobParameters.
JobParametersType() - Constructor for class org.springframework.yarn.batch.repository.bindings.JobParametersType
 
JobParameterType - Class in org.springframework.yarn.batch.repository.bindings
Binding for JobParameter.
JobParameterType() - Constructor for class org.springframework.yarn.batch.repository.bindings.JobParameterType
 
jobRepository() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
JobRepositoryRemoteServiceInterceptor - Interface in org.springframework.yarn.batch.repository
Interface for interceptors that are able to view and/or modify the messages when communication is handled with a service operating with BaseObject and BaseResponseObject.
JobRepositoryRpcFactory - Class in org.springframework.yarn.batch.repository
Helper class providing factory methods for building requests used in remote job repository functionality.
JobRepositoryRpcFactory() - Constructor for class org.springframework.yarn.batch.repository.JobRepositoryRpcFactory
 
jobRepositoryService() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
JobRepositoryService - Class in org.springframework.yarn.batch.repository
 
JobRepositoryService() - Constructor for class org.springframework.yarn.batch.repository.JobRepositoryService
 
JP_SPEL_KEY_INPUTPATTERNS - Static variable in class org.springframework.yarn.batch.BatchSystemConstants
Default spel expressiong for input patterns job parameter

K

KEY_FILENAME - Static variable in class org.springframework.yarn.batch.BatchSystemConstants
Default key for execution context file name
KEY_INPUTPATTERNS - Static variable in class org.springframework.yarn.batch.BatchSystemConstants
Default key for input patterns job parameter
KEY_PARTITION - Static variable in class org.springframework.yarn.batch.BatchSystemConstants
Default base key identifying a partition
KEY_SPLITLENGTH - Static variable in class org.springframework.yarn.batch.BatchSystemConstants
Default key for execution context file split length
KEY_SPLITLOCATIONS - Static variable in class org.springframework.yarn.batch.BatchSystemConstants
Default key for execution context split locations
KEY_SPLITSTART - Static variable in class org.springframework.yarn.batch.BatchSystemConstants
Default key for execution context file split start position

L

lastUpdated - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
lastUpdated - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
launchJobFromProperties(Properties) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
Launch jobs using Properties.
LineDataMapper<T> - Interface in org.springframework.yarn.batch.item
Interface for mapping lines (strings) to domain objects.

M

map - Variable in class org.springframework.yarn.batch.repository.bindings.ExecutionContextType
 
mapLine(String) - Method in interface org.springframework.yarn.batch.item.LineDataMapper
Implementations must implement this method to map the provided line to the parameter type T.
mapLine(String) - Method in class org.springframework.yarn.batch.item.PassThroughLineDataMapper
 
message - Variable in class org.springframework.yarn.batch.repository.bindings.repo.UpdateExecutionContextRes
 
mindHolderToObjectConverter() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
mindHolderToObjectConverter() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
mindObjectToHolderConverter() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
mindObjectToHolderConverter() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
mindRpcSerializer() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
mindRpcSerializer() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 

O

obj - Variable in class org.springframework.yarn.batch.repository.bindings.ExecutionContextType.ObjectEntry
 
objectMapper() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
objectMapper() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
onApplicationEvent(AbstractYarnEvent) - Method in class org.springframework.yarn.batch.am.BatchAppmaster
 
onContainerAllocated(Container) - Method in class org.springframework.yarn.batch.am.AbstractBatchAppmaster
 
onContainerCompleted(ContainerStatus) - Method in class org.springframework.yarn.batch.am.AbstractBatchAppmaster
 
onContainerLaunched(Container) - Method in class org.springframework.yarn.batch.am.AbstractBatchAppmaster
 
onInit() - Method in class org.springframework.yarn.batch.am.AbstractBatchAppmaster
 
open(ExecutionContext) - Method in class org.springframework.yarn.batch.item.DataStoreItemReader
 
org.springframework.yarn.batch - package org.springframework.yarn.batch
 
org.springframework.yarn.batch.am - package org.springframework.yarn.batch.am
 
org.springframework.yarn.batch.config - package org.springframework.yarn.batch.config
 
org.springframework.yarn.batch.container - package org.springframework.yarn.batch.container
 
org.springframework.yarn.batch.event - package org.springframework.yarn.batch.event
 
org.springframework.yarn.batch.item - package org.springframework.yarn.batch.item
 
org.springframework.yarn.batch.listener - package org.springframework.yarn.batch.listener
 
org.springframework.yarn.batch.partition - package org.springframework.yarn.batch.partition
 
org.springframework.yarn.batch.repository - package org.springframework.yarn.batch.repository
 
org.springframework.yarn.batch.repository.bindings - package org.springframework.yarn.batch.repository.bindings
 
org.springframework.yarn.batch.repository.bindings.exp - package org.springframework.yarn.batch.repository.bindings.exp
 
org.springframework.yarn.batch.repository.bindings.repo - package org.springframework.yarn.batch.repository.bindings.repo
 
org.springframework.yarn.batch.support - package org.springframework.yarn.batch.support
 

P

parameter - Variable in class org.springframework.yarn.batch.repository.bindings.JobParameterType
 
parameters - Variable in class org.springframework.yarn.batch.repository.bindings.JobParametersType
 
parameterType - Variable in class org.springframework.yarn.batch.repository.bindings.JobParameterType
 
parseInternal(Element, ParserContext) - Method in class org.springframework.yarn.batch.config.BatchMasterParser
 
partition(int) - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
 
PartitionedStepExecutionEvent - Class in org.springframework.yarn.batch.event
Generic event representing that partitioned StepExecution state has been changed.
PartitionedStepExecutionEvent(Object, StepExecution) - Constructor for class org.springframework.yarn.batch.event.PartitionedStepExecutionEvent
Constructs event with the given StepExecution.
PartitionedStepExecutionStateListener - Interface in org.springframework.yarn.batch.listener
Interface used for partitioned step to notify its state.
PartitionedStepExecutionStateListener.PartitionedStepExecutionState - Enum in org.springframework.yarn.batch.listener
Enum for partitioned step states
PartitionedStepExecutionStatusReq - Class in org.springframework.yarn.batch.repository.bindings
Request binding used to notify status of remote step execution.
PartitionedStepExecutionStatusReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.PartitionedStepExecutionStatusReq
 
PartitionedStepExecutionStatusRes - Class in org.springframework.yarn.batch.repository.bindings
PartitionedStepExecutionStatusRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.PartitionedStepExecutionStatusRes
 
PassThroughLineDataMapper - Class in org.springframework.yarn.batch.item
Simple LineDataMapper implementation which just passes data as it is.
PassThroughLineDataMapper() - Constructor for class org.springframework.yarn.batch.item.PassThroughLineDataMapper
 
postRequest(BaseResponseObject) - Method in class org.springframework.yarn.batch.repository.BatchAppmasterService.JobRepositoryServiceInterceptorList
Handles he post request calls.
postRequest(BaseResponseObject) - Method in interface org.springframework.yarn.batch.repository.JobRepositoryRemoteServiceInterceptor
Invoked after request is made using BaseObject and before BaseResponseObject is sent to further processing.
preLaunch(Container, ContainerLaunchContext) - Method in class org.springframework.yarn.batch.am.AbstractBatchAppmaster
 
preRequest(BaseObject) - Method in class org.springframework.yarn.batch.repository.BatchAppmasterService.JobRepositoryServiceInterceptorList
Handles the pre request calls.
preRequest(BaseObject) - Method in interface org.springframework.yarn.batch.repository.JobRepositoryRemoteServiceInterceptor
Invoked after request is made using BaseObject.
processSkipCount - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 

Q

queueChannel() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 

R

read() - Method in class org.springframework.yarn.batch.item.DataStoreItemReader
 
READ_POSITION - Static variable in class org.springframework.yarn.batch.item.DataStoreItemReader
 
readCount - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
readSkipCount - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
RemoteJobExplorer - Class in org.springframework.yarn.batch.repository
 
RemoteJobExplorer() - Constructor for class org.springframework.yarn.batch.repository.RemoteJobExplorer
 
RemoteJobExplorer(AppmasterMindScOperations) - Constructor for class org.springframework.yarn.batch.repository.RemoteJobExplorer
 
RemoteJobRepository - Class in org.springframework.yarn.batch.repository
 
RemoteJobRepository() - Constructor for class org.springframework.yarn.batch.repository.RemoteJobRepository
 
RemoteJobRepository(AppmasterMindScOperations) - Constructor for class org.springframework.yarn.batch.repository.RemoteJobRepository
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.yarn.batch.config.BatchMasterParser
 
response - Variable in class org.springframework.yarn.batch.repository.bindings.repo.IsJobInstanceExistsRes
 
rollbackCount - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
run(String...) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
Run the jobs.
run(Properties) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
Run the jobs.
runInternal() - Method in class org.springframework.yarn.batch.container.DefaultBatchYarnContainer
 

S

SEC_SPEL_KEY_FILENAME - Static variable in class org.springframework.yarn.batch.BatchSystemConstants
Default spel expression for step execution context file name
SEC_SPEL_KEY_SPLITLENGTH - Static variable in class org.springframework.yarn.batch.BatchSystemConstants
Default spel expression for step execution context file split length
SEC_SPEL_KEY_SPLITSTART - Static variable in class org.springframework.yarn.batch.BatchSystemConstants
Default spel expression for step execution context file split start position
set(List<JobRepositoryRemoteServiceInterceptor>) - Method in class org.springframework.yarn.batch.repository.BatchAppmasterService.JobRepositoryServiceInterceptorList
Sets the interceptors, clears any existing interceptors.
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
 
setAppmasterScOperations(AppmasterMindScOperations) - Method in class org.springframework.yarn.batch.repository.AbstractRemoteDao
Sets the AppmasterMindScOperations for this implementation.
setAppmasterServiceClient(AppmasterServiceClient) - Method in class org.springframework.yarn.batch.container.DefaultBatchYarnContainer
 
setBatchAppmaster(BatchYarnAppmaster) - Method in class org.springframework.yarn.batch.partition.AbstractPartitionHandler
Sets the batch appmaster.
setBeanFactory(BeanFactory) - Method in class org.springframework.yarn.batch.support.BeanFactoryStepLocator
 
setConfiguration(Configuration) - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
Sets the hadoop configuration.
setDataStoreReader(DataStoreReader<T>) - Method in class org.springframework.yarn.batch.item.DataStoreItemReader
Sets the data store reader.
setEnabled(boolean) - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
setEnabled(boolean) - Method in class org.springframework.yarn.batch.support.YarnBatchProperties
 
setFailNext(boolean) - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
setFailRestart(boolean) - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
setGridSize(int) - Method in class org.springframework.yarn.batch.partition.StaticPartitionHandler
Passed to the StepExecutionSplitter in the AbstractPartitionHandler.handle(StepExecutionSplitter, StepExecution) method, instructing it how many StepExecution instances are required, ideally.
setInputPatterns(String) - Method in class org.springframework.yarn.batch.partition.SplitterPartitioner
Sets the input patterns.
setInputPatterns(Set<String>) - Method in class org.springframework.yarn.batch.partition.SplitterPartitioner
Sets the input patterns.
setInterceptors(List<JobRepositoryRemoteServiceInterceptor>) - Method in class org.springframework.yarn.batch.repository.BatchAppmasterService
Set the list of channel interceptors.
setJobExplorer(JobExplorer) - Method in class org.springframework.yarn.batch.container.AbstractBatchYarnContainer
Sets the job explorer.
setJobExplorer(JobExplorer) - Method in class org.springframework.yarn.batch.repository.JobRepositoryService
 
setJobExplorer(JobExplorer) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
 
setJobLauncher(JobLauncher) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
Sets the job launcher.
setJobName(String) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
Sets the enabled job name.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
 
setJobRegistry(JobRegistry) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
 
setJobRepository(JobRepository) - Method in class org.springframework.yarn.batch.repository.JobRepositoryService
 
setJobRepositoryRemoteService(JobRepositoryService) - Method in class org.springframework.yarn.batch.repository.BatchAppmasterService
Sets the job repository remote service.
setJobs(List<YarnBatchProperties.JobProperties>) - Method in class org.springframework.yarn.batch.support.YarnBatchProperties
 
setJobs(Collection<Job>) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
Sets the jobs.
setKeyFileName(String) - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
The name of the key for the file name in each ExecutionContext.
setKeySplitLength(String) - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
The name of the key for the file split length in each ExecutionContext.
setKeySplitLocations(String) - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
The name of the key for the split locations in each ExecutionContext.
setKeySplitLocations(String) - Method in class org.springframework.yarn.batch.partition.AbstractPartitionHandler
The name of the key for the split locations in each ExecutionContext.
setKeySplitStart(String) - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
The name of the key for the file split start in each ExecutionContext.
setLineDataMapper(LineDataMapper<T>) - Method in class org.springframework.yarn.batch.item.DataStoreItemReader
Sets the line data mapper.
setName(String) - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
setName(String) - Method in class org.springframework.yarn.batch.support.YarnBatchProperties
 
setNext(boolean) - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
setParameters(Map<String, Object>) - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
setPartitionBaseIdentifier(String) - Method in class org.springframework.yarn.batch.partition.AbstractPartitioner
The name of the base key for identifying partition's ExecutionContext.
setRestart(boolean) - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
setSaveState(boolean) - Method in class org.springframework.yarn.batch.item.DataStoreItemReader
Set the flag that determines whether to save internal data for ExecutionContext.
setSplitter(Splitter) - Method in class org.springframework.yarn.batch.partition.SplitterPartitioner
Sets the splitter.
setStepLocator(StepLocator) - Method in class org.springframework.yarn.batch.container.AbstractBatchYarnContainer
Sets the step locator.
setStepName(String) - Method in class org.springframework.yarn.batch.partition.AbstractPartitionHandler
Sets the remote step name.
setYarnAppmaster(YarnAppmaster) - Method in class org.springframework.yarn.batch.partition.AbstractPartitionHandler
Sets the batch appmaster.
setYarnBatchProperties(YarnBatchProperties) - Method in class org.springframework.yarn.batch.support.YarnJobLauncher
 
setYarnJobLauncher(YarnJobLauncher) - Method in class org.springframework.yarn.batch.am.AbstractBatchAppmaster
 
SimpleYarnBatchConfiguration - Class in org.springframework.yarn.batch.config
Annotation based batch configuration for Yarn Appmaster.
SimpleYarnBatchConfiguration() - Constructor for class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
SimpleYarnRemoteBatchConfiguration - Class in org.springframework.yarn.batch.config
Annotation based batch configuration for Yarn Container.
SimpleYarnRemoteBatchConfiguration() - Constructor for class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
SplitterPartitioner - Class in org.springframework.yarn.batch.partition
Implementation of Partitioner that locates multiple resources and associates their file names with execution context keys.
SplitterPartitioner() - Constructor for class org.springframework.yarn.batch.partition.SplitterPartitioner
 
SplitterPartitionHandler - Class in org.springframework.yarn.batch.partition
Implementation of Spring Batch PartitionHandler which does partitioning based on number of input files from HDFS.
SplitterPartitionHandler() - Constructor for class org.springframework.yarn.batch.partition.SplitterPartitionHandler
Instantiates a new splitter partition handler.
SplitterPartitionHandler(AbstractBatchAppmaster) - Constructor for class org.springframework.yarn.batch.partition.SplitterPartitionHandler
Instantiates a new splitter partition handler.
start - Variable in class org.springframework.yarn.batch.repository.bindings.exp.FindJobInstancesByJobNameReq
 
start - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetJobInstancesReq
 
startTime - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
startTime - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
state(PartitionedStepExecutionStateListener.PartitionedStepExecutionState, StepExecution) - Method in class org.springframework.yarn.batch.listener.CompositePartitionedStepExecutionStateListener
 
state(PartitionedStepExecutionStateListener.PartitionedStepExecutionState, StepExecution) - Method in interface org.springframework.yarn.batch.listener.PartitionedStepExecutionStateListener
Invoked when partitioned step state is changing.
StaticPartitionHandler - Class in org.springframework.yarn.batch.partition
Implementation of Spring Batch PartitionHandler which does partitioning based on static grid size.
StaticPartitionHandler() - Constructor for class org.springframework.yarn.batch.partition.StaticPartitionHandler
Instantiates a new static partition handler.
StaticPartitionHandler(BatchYarnAppmaster) - Constructor for class org.springframework.yarn.batch.partition.StaticPartitionHandler
Instantiates a new static partition handler.
StaticPartitionHandler(BatchYarnAppmaster, int) - Constructor for class org.springframework.yarn.batch.partition.StaticPartitionHandler
Instantiates a new static partition handler.
status - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
status - Variable in class org.springframework.yarn.batch.repository.bindings.repo.UpdateExecutionContextRes
 
status - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
stepBuilders() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
stepExecution - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetStepExecutionRes
 
stepExecution - Variable in class org.springframework.yarn.batch.repository.bindings.PartitionedStepExecutionStatusReq
 
stepExecution - Variable in class org.springframework.yarn.batch.repository.bindings.repo.AddWithStepExecutionReq
 
stepExecution - Variable in class org.springframework.yarn.batch.repository.bindings.repo.GetLastStepExecutionRes
 
stepExecution - Variable in class org.springframework.yarn.batch.repository.bindings.repo.UpdateExecutionContextReq
 
stepExecution - Variable in class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithStepExecutionReq
 
stepExecutionId - Variable in class org.springframework.yarn.batch.repository.bindings.exp.GetStepExecutionReq
 
stepExecutions - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
StepExecutionType - Class in org.springframework.yarn.batch.repository.bindings
Binding for StepExecution.
StepExecutionType() - Constructor for class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
stepLocator() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
stepName - Variable in class org.springframework.yarn.batch.repository.bindings.repo.GetLastStepExecutionReq
 
stepName - Variable in class org.springframework.yarn.batch.repository.bindings.repo.GetStepExecutionCountReq
 
stepName - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
submitApplication() - Method in class org.springframework.yarn.batch.am.BatchAppmaster
 

T

tcpInboundGateway() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
tcpNetClientConnectionFactory() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
tcpNetServerConnectionFactory() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
tcpOutboundGateway() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 
terminateOnly - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
toString() - Method in class org.springframework.yarn.batch.event.JobExecutionEvent
 
toString() - Method in class org.springframework.yarn.batch.event.PartitionedStepExecutionEvent
 
toString() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
toString() - Method in class org.springframework.yarn.batch.support.YarnBatchProperties
 
transactionManager() - Method in class org.springframework.yarn.batch.config.SimpleYarnRemoteBatchConfiguration
 

U

update(ExecutionContext) - Method in class org.springframework.yarn.batch.item.DataStoreItemReader
 
update(JobExecution) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
update(StepExecution) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
updateExecutionContext(StepExecution) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
updateExecutionContext(JobExecution) - Method in class org.springframework.yarn.batch.repository.RemoteJobRepository
 
UpdateExecutionContextReq - Class in org.springframework.yarn.batch.repository.bindings.repo
UpdateExecutionContextReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.UpdateExecutionContextReq
 
UpdateExecutionContextRes - Class in org.springframework.yarn.batch.repository.bindings.repo
UpdateExecutionContextRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.UpdateExecutionContextRes
 
UpdateWithJobExecutionReq - Class in org.springframework.yarn.batch.repository.bindings.repo
UpdateWithJobExecutionReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithJobExecutionReq
 
UpdateWithJobExecutionRes - Class in org.springframework.yarn.batch.repository.bindings.repo
UpdateWithJobExecutionRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithJobExecutionRes
 
UpdateWithStepExecutionReq - Class in org.springframework.yarn.batch.repository.bindings.repo
UpdateWithStepExecutionReq() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithStepExecutionReq
 
UpdateWithStepExecutionRes - Class in org.springframework.yarn.batch.repository.bindings.repo
UpdateWithStepExecutionRes() - Constructor for class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithStepExecutionRes
 

V

valueOf(String) - Static method in enum org.springframework.yarn.batch.listener.PartitionedStepExecutionStateListener.PartitionedStepExecutionState
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.yarn.batch.listener.PartitionedStepExecutionStateListener.PartitionedStepExecutionState
Returns an array containing the constants of this enum type, in the order they are declared.
version - Variable in class org.springframework.yarn.batch.repository.bindings.JobExecutionType
 
version - Variable in class org.springframework.yarn.batch.repository.bindings.JobInstanceType
 
version - Variable in class org.springframework.yarn.batch.repository.bindings.repo.AddWithStepExecutionRes
 
version - Variable in class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithJobExecutionRes
 
version - Variable in class org.springframework.yarn.batch.repository.bindings.repo.UpdateWithStepExecutionRes
 
version - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 

W

waitCompleteState(StepExecution) - Method in class org.springframework.yarn.batch.partition.AbstractPartitionHandler
Uses CountDownLatch to wait completion status from application master.
writeCount - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 
writeSkipCount - Variable in class org.springframework.yarn.batch.repository.bindings.StepExecutionType
 

Y

YarnBatchProperties - Class in org.springframework.yarn.batch.support
 
YarnBatchProperties() - Constructor for class org.springframework.yarn.batch.support.YarnBatchProperties
 
YarnBatchProperties.JobProperties - Class in org.springframework.yarn.batch.support
Bindings for job properties.
YarnBatchProperties.JobProperties() - Constructor for class org.springframework.yarn.batch.support.YarnBatchProperties.JobProperties
 
yarnEventPublisher() - Method in class org.springframework.yarn.batch.config.SimpleYarnBatchConfiguration
 
YarnJobLauncher - Class in org.springframework.yarn.batch.support
Utility class to launch Spring Batch jobs.
YarnJobLauncher() - Constructor for class org.springframework.yarn.batch.support.YarnJobLauncher
 
A B C D E F G H I J K L M O P Q R S T U V W Y