Index

A B C D E F G H I J K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

AbstractSqlPagingQueryProvider - Class in org.springframework.cloud.task.repository.database.support
Abstract SQL Paging Query Provider to serve as a base class for all provided SQL paging query providers.
AbstractSqlPagingQueryProvider() - Constructor for class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
 
addFailureException(Throwable) - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
Add the provided throwable to the failure exception list.
afterChunk(ChunkContext) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingChunkListener
 
afterChunkError(ChunkContext) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingChunkListener
 
afterJob(JobExecution) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingJobExecutionListener
 
afterProcess(Object, Object) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemProcessListener
 
afterPropertiesSet() - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
 
afterPropertiesSet() - Method in class org.springframework.cloud.task.repository.support.TaskRepositoryInitializer
 
afterRead(Object) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemReadListener
 
afterStep(StepExecution) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingStepExecutionListener
 
afterTask(TaskExecution) - Method in class io.spring.taskobservations.TaskObservationsApplication
Prints the metrics as recorded in the simpleMeterRegistry.
AfterTask - Annotation Interface in org.springframework.cloud.task.listener.annotation
afterWrite(Chunk) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemWriteListener
 
amqpItemReader(AmqpTemplate, Class) - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemReaderAutoConfiguration
 
AmqpItemReaderAutoConfiguration - Class in org.springframework.cloud.task.batch.autoconfigure.rabbit
Autconfiguration for a AmqpItemReader.
AmqpItemReaderAutoConfiguration() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemReaderAutoConfiguration
 
amqpItemReaderProperties() - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemReaderAutoConfiguration
 
AmqpItemReaderProperties - Class in org.springframework.cloud.task.batch.autoconfigure.rabbit
Properties to configure a AmqpItemReader.
AmqpItemReaderProperties() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemReaderProperties
 
amqpItemWriter(AmqpTemplate) - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemWriterAutoConfiguration
 
AmqpItemWriterAutoConfiguration - Class in org.springframework.cloud.task.batch.autoconfigure.rabbit
Autconfiguration for a AmqpItemWriter.
AmqpItemWriterAutoConfiguration() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemWriterAutoConfiguration
 
amqpItemWriterProperties() - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemWriterAutoConfiguration
 
AmqpItemWriterProperties - Class in org.springframework.cloud.task.batch.autoconfigure.rabbit
 
AmqpItemWriterProperties() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemWriterProperties
 
applicationRunner() - Method in class io.spring.taskobservations.TaskObservationsApplication
 

B

BATCH_EXCEPTION - Static variable in class org.springframework.cloud.task.batch.listener.support.BatchJobHeaders
Key of the batch exception message.
BATCH_LISTENER_EVENT_TYPE - Static variable in class org.springframework.cloud.task.batch.listener.support.BatchJobHeaders
Name of the batch listener event type.
BatchEventAutoConfiguration - Class in org.springframework.cloud.task.batch.listener
Autoconfigures Spring Batch listeners designed to emit events on the following channels.
BatchEventAutoConfiguration() - Constructor for class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration
 
BatchEventAutoConfiguration.JobExecutionListenerConfiguration - Class in org.springframework.cloud.task.batch.listener
Configuration for Job Execution Listener.
BatchEventsApplication - Class in io.spring.cloud
 
BatchEventsApplication() - Constructor for class io.spring.cloud.BatchEventsApplication
 
BatchEventsApplication.JobConfiguration - Class in io.spring.cloud
 
batchItemKeyMapper() - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemWriterAutoConfiguration
 
BatchJobApplication - Class in io.spring
 
BatchJobApplication() - Constructor for class io.spring.BatchJobApplication
 
BatchJobHeaders - Class in org.springframework.cloud.task.batch.listener.support
Headers definitions used by the batch job plugin.
batchTaskEventListenerBeanPostProcessor() - Static method in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration
 
batchTaskExecutionListenerBeanPostProcessor() - Static method in class org.springframework.cloud.task.batch.configuration.TaskBatchAutoConfiguration
 
beforeChunk(ChunkContext) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingChunkListener
 
beforeJob(JobExecution) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingJobExecutionListener
 
beforeJob(JobExecution) - Method in class org.springframework.cloud.task.batch.listener.TaskBatchExecutionListener
 
beforeProcess(Object) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemProcessListener
 
beforeRead() - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemReadListener
 
beforeStep(StepExecution) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingStepExecutionListener
 
beforeTask(TaskExecution) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
 
BeforeTask - Annotation Interface in org.springframework.cloud.task.listener.annotation
beforeWrite(Chunk) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemWriteListener
 
buildSortClause(Map<String, Order>) - Static method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryUtils
Generates ORDER BY attributes based on the sort keys.
buildSortClause(AbstractSqlPagingQueryProvider) - Static method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryUtils
Generates ORDER BY attributes based on the sort keys.
buildWhereClause(AbstractSqlPagingQueryProvider, boolean, StringBuilder) - Static method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryUtils
Generates WHERE clause for queries that require sub selects.

C

CHUNK_EVENTS_LISTENER - Static variable in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration
Name of the chunk events listener bean.
chunkEventsListener(MessagePublisher, TaskEventProperties) - Method in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration.JobExecutionListenerConfiguration
 
CommandLineArgsProvider - Interface in org.springframework.cloud.task.batch.partition
Strategy to allow for the customization of command line arguments passed to each partition's execution.
commandLineRunner() - Method in class io.spring.TaskEventsApplication.TaskConfiguration
 
commandLineRunner() - Method in class io.spring.taskobservations.TaskObservationsApplication
 
completeTaskExecution(long, Integer, LocalDateTime, String) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
completeTaskExecution(long, Integer, LocalDateTime, String) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
completeTaskExecution(long, Integer, LocalDateTime, String) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Update and existing TaskExecution.
completeTaskExecution(long, Integer, LocalDateTime, String) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
completeTaskExecution(long, Integer, LocalDateTime, String) - Method in interface org.springframework.cloud.task.repository.TaskRepository
Notifies the repository that a taskExecution has completed.
completeTaskExecution(long, Integer, LocalDateTime, String, String) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
completeTaskExecution(long, Integer, LocalDateTime, String, String) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
completeTaskExecution(long, Integer, LocalDateTime, String, String) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Update and existing TaskExecution to mark it as completed.
completeTaskExecution(long, Integer, LocalDateTime, String, String) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
completeTaskExecution(long, Integer, LocalDateTime, String, String) - Method in interface org.springframework.cloud.task.repository.TaskRepository
Notifies the repository that a taskExecution has completed.
convert(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.RangeConverter
 
createTaskExecution() - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
createTaskExecution() - Method in interface org.springframework.cloud.task.repository.TaskRepository
Creates an empty TaskExecution with just an id provided.
createTaskExecution(String) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
createTaskExecution(String) - Method in interface org.springframework.cloud.task.repository.TaskRepository
Creates an empty TaskExecution with just an id and name provided.
createTaskExecution(String, LocalDateTime, List<String>, String) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
createTaskExecution(String, LocalDateTime, List<String>, String) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
createTaskExecution(String, LocalDateTime, List<String>, String) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Save a new TaskExecution.
createTaskExecution(String, LocalDateTime, List<String>, String, Long) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
createTaskExecution(String, LocalDateTime, List<String>, String, Long) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
createTaskExecution(String, LocalDateTime, List<String>, String, Long) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Save a new TaskExecution.
createTaskExecution(TaskExecution) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
createTaskExecution(TaskExecution) - Method in interface org.springframework.cloud.task.repository.TaskRepository
Notifies the repository that a taskExecution needs to be created.
CustomTaskConfigurer - Class in io.spring.configuration
 
CustomTaskConfigurer(DataSource) - Constructor for class io.spring.configuration.CustomTaskConfigurer
 

D

DatabaseType - Enum Class in org.springframework.cloud.task.repository.support
Enum representing a database type, such as DB2 or oracle.
dataSource - Variable in class io.spring.JobConfiguration
 
dataSource() - Method in class io.spring.configuration.EmbeddedDataSourceConfiguration
 
dataSource(DataSourceProperties) - Method in class io.spring.configuration.ExternalDataSourceConfiguration
 
DB2 - Enum constant in enum class org.springframework.cloud.task.repository.support.DatabaseType
DB2 DB.
DB2AS400 - Enum constant in enum class org.springframework.cloud.task.repository.support.DatabaseType
DB2AS400 DB.
Db2PagingQueryProvider - Class in org.springframework.cloud.task.repository.database.support
IBM DB2 implementation of a PagingQueryProvider using database specific features.
Db2PagingQueryProvider() - Constructor for class org.springframework.cloud.task.repository.database.support.Db2PagingQueryProvider
 
DB2VSE - Enum constant in enum class org.springframework.cloud.task.repository.support.DatabaseType
DB2VSE DB.
DB2ZOS - Enum constant in enum class org.springframework.cloud.task.repository.support.DatabaseType
DB2ZOS DB.
DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.cloud.task.configuration.TaskProperties
Default table prefix for Spring Cloud Task tables.
DefaultTaskConfigurer - Class in org.springframework.cloud.task.configuration
Default implementation of the TaskConfigurer interface.
DefaultTaskConfigurer() - Constructor for class org.springframework.cloud.task.configuration.DefaultTaskConfigurer
 
DefaultTaskConfigurer(String) - Constructor for class org.springframework.cloud.task.configuration.DefaultTaskConfigurer
Initializes the DefaultTaskConfigurer.
DefaultTaskConfigurer(DataSource) - Constructor for class org.springframework.cloud.task.configuration.DefaultTaskConfigurer
Initializes the DefaultTaskConfigurer and sets the default table prefix to TaskProperties.DEFAULT_TABLE_PREFIX.
DefaultTaskConfigurer(DataSource, String, ApplicationContext) - Constructor for class org.springframework.cloud.task.configuration.DefaultTaskConfigurer
Initializes the DefaultTaskConfigurer.
DefaultTaskExecutionObservationConvention - Class in org.springframework.cloud.task.listener
/** Default TaskExecutionObservationConvention implementation.
DefaultTaskExecutionObservationConvention() - Constructor for class org.springframework.cloud.task.listener.DefaultTaskExecutionObservationConvention
 
DefaultTaskObservationConvention - Class in org.springframework.cloud.task.configuration.observation
ObservationConvention for Spring Cloud Task.
DefaultTaskObservationConvention() - Constructor for class org.springframework.cloud.task.configuration.observation.DefaultTaskObservationConvention
 
DeployerPartitionHandler - Class in org.springframework.cloud.task.batch.partition
A PartitionHandler implementation that delegates to a TaskLauncher for each of the workers.
DeployerPartitionHandler(TaskLauncher, JobExplorer, Resource, String, TaskRepository) - Constructor for class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
Constructor initializing the DeployerPartitionHandler instance.
DeployerPartitionHandler(TaskLauncher, JobExplorer, Resource, String, TaskRepository, TaskExecutor) - Constructor for class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
Constructor initializing the DeployerPartitionHandler instance.
DeployerStepExecutionHandler - Class in org.springframework.cloud.task.batch.partition
A CommandLineRunner used to execute a Step.
DeployerStepExecutionHandler(BeanFactory, JobExplorer, JobRepository) - Constructor for class org.springframework.cloud.task.batch.partition.DeployerStepExecutionHandler
 
destroy() - Method in class org.springframework.cloud.task.listener.TaskLifecycleListener
 

E

EmbeddedDataSourceConfiguration - Class in io.spring.configuration
Creates two data sources that use embedded databases.
EmbeddedDataSourceConfiguration() - Constructor for class io.spring.configuration.EmbeddedDataSourceConfiguration
 
EnableTask - Annotation Interface in org.springframework.cloud.task.configuration
Enables the TaskLifecycleListener so that the features of Spring Cloud Task will be applied.
EnableTaskLauncher - Annotation Interface in org.springframework.cloud.task.launcher.annotation
Enable this boot app to be a sink to receive a TaskLaunchRequest and use the TaskLauncher to launch the task.
EnvironmentVariablesProvider - Interface in org.springframework.cloud.task.batch.partition
Strategy interface to allow for advanced configuration of environment variables for each worker in a partitioned job.
equals(Object) - Method in class org.springframework.cloud.task.batch.listener.support.JobParameterEvent
 
equals(Object) - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
 
equals(Object) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
equals(Object) - Method in class org.springframework.cloud.task.launcher.TaskLaunchRequest
 
EventEmittingChunkListener - Class in org.springframework.cloud.task.batch.listener
Provides informational messages around the Chunk of a batch job.
EventEmittingChunkListener(MessagePublisher, int, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingChunkListener
 
EventEmittingChunkListener(MessagePublisher, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingChunkListener
 
EventEmittingItemProcessListener - Class in org.springframework.cloud.task.batch.listener
Provides informational messages around the ItemProcessListener of a batch job.
EventEmittingItemProcessListener(MessagePublisher, int, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingItemProcessListener
 
EventEmittingItemProcessListener(MessagePublisher, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingItemProcessListener
 
EventEmittingItemReadListener - Class in org.springframework.cloud.task.batch.listener
Provides informational messages around the ItemReader of a batch job.
EventEmittingItemReadListener(MessagePublisher, int, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingItemReadListener
 
EventEmittingItemReadListener(MessagePublisher, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingItemReadListener
 
EventEmittingItemWriteListener - Class in org.springframework.cloud.task.batch.listener
Setups up the ItemWriteEventsListener to emit events to the spring cloud stream output channel.
EventEmittingItemWriteListener(MessagePublisher, int, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingItemWriteListener
 
EventEmittingItemWriteListener(MessagePublisher, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingItemWriteListener
 
EventEmittingJobExecutionListener - Class in org.springframework.cloud.task.batch.listener
Provides JobExecutionEvent at both the start and end of the job's execution.
EventEmittingJobExecutionListener(MessagePublisher, int, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingJobExecutionListener
 
EventEmittingJobExecutionListener(MessagePublisher, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingJobExecutionListener
 
EventEmittingSkipListener - Class in org.springframework.cloud.task.batch.listener
Setups up the SkipProcessListener to emit events to the spring cloud stream output channel.
EventEmittingSkipListener(MessagePublisher, int, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingSkipListener
 
EventEmittingSkipListener(MessagePublisher, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingSkipListener
 
EventEmittingStepExecutionListener - Class in org.springframework.cloud.task.batch.listener
Provides a StepExecutionEvent at the start and end of each step indicating the step's status.
EventEmittingStepExecutionListener(MessagePublisher, int, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingStepExecutionListener
 
EventEmittingStepExecutionListener(MessagePublisher, TaskEventProperties) - Constructor for class org.springframework.cloud.task.batch.listener.EventEmittingStepExecutionListener
 
execute(Job, JobParameters) - Method in class org.springframework.cloud.task.batch.handler.TaskJobLauncherApplicationRunner
 
ExitStatus - Class in org.springframework.cloud.task.batch.listener.support
ExitStatus DTO created so that ExitStatus can be serialized into Json without.
ExitStatus() - Constructor for class org.springframework.cloud.task.batch.listener.support.ExitStatus
 
ExitStatus(ExitStatus) - Constructor for class org.springframework.cloud.task.batch.listener.support.ExitStatus
 
ExternalDataSourceConfiguration - Class in io.spring.configuration
Creates two data sources that use external databases.
ExternalDataSourceConfiguration() - Constructor for class io.spring.configuration.ExternalDataSourceConfiguration
 
extract(Map<String, Object>) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterAutoConfiguration.MapFieldExtractor
 

F

FailedTask - Annotation Interface in org.springframework.cloud.task.listener.annotation
findAll(Pageable) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
findAll(Pageable) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
findAll(Pageable) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Retrieves all the task executions within the pageable constraints.
findAll(Pageable) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
findAll(Pageable) - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Retrieves all the task executions within the pageable constraints sorted by start date descending, taskExecution id descending.
findRunningTaskExecutions(String, Pageable) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
findRunningTaskExecutions(String, Pageable) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
findRunningTaskExecutions(String, Pageable) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Retrieves a set of task executions that are running for a taskName.
findRunningTaskExecutions(String, Pageable) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
findRunningTaskExecutions(String, Pageable) - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Retrieve a collection of taskExecutions that have the task name provided.
findTaskExecutionsByName(String, Pageable) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
findTaskExecutionsByName(String, Pageable) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
findTaskExecutionsByName(String, Pageable) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Retrieves a subset of task executions by task name, start location and size.
findTaskExecutionsByName(String, Pageable) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
findTaskExecutionsByName(String, Pageable) - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Get a collection/page of executions.
FlatFileItemReaderAutoConfiguration - Class in org.springframework.cloud.task.batch.autoconfigure.flatfile
Autconfiguration for a FlatFileItemReader.
FlatFileItemReaderAutoConfiguration(FlatFileItemReaderProperties) - Constructor for class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderAutoConfiguration
 
FlatFileItemReaderAutoConfiguration.MapFieldSetMapper - Class in org.springframework.cloud.task.batch.autoconfigure.flatfile
A FieldSetMapper that takes a FieldSet and returns the Map<String, Object> of its contents.
FlatFileItemReaderProperties - Class in org.springframework.cloud.task.batch.autoconfigure.flatfile
Properties to configure a FlatFileItemReader.
FlatFileItemReaderProperties() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
 
FlatFileItemWriterAutoConfiguration - Class in org.springframework.cloud.task.batch.autoconfigure.flatfile
Autoconfiguration for a FlatFileItemWriter.
FlatFileItemWriterAutoConfiguration(FlatFileItemWriterProperties) - Constructor for class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterAutoConfiguration
 
FlatFileItemWriterAutoConfiguration.MapFieldExtractor - Class in org.springframework.cloud.task.batch.autoconfigure.flatfile
A FieldExtractor that converts a Map<String, Object> to the ordered Object[] required to populate an output record.
FlatFileItemWriterProperties - Class in org.springframework.cloud.task.batch.autoconfigure.flatfile
Properties for configuring a FlatFileItemWriter.
FlatFileItemWriterProperties() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
 
FROM_CLAUSE - Static variable in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
FROM clause for task execution.
fromMetaData(DataSource) - Static method in enum class org.springframework.cloud.task.repository.support.DatabaseType
Convenience method that pulls a database product name from the DataSource's metadata.
fromProductName(String) - Static method in enum class org.springframework.cloud.task.repository.support.DatabaseType
Static method to obtain a DatabaseType from the provided product name.

G

generateLimitJumpToQuery(AbstractSqlPagingQueryProvider, String) - Static method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryUtils
Generate SQL query string using a LIMIT clause.
generateTopJumpToQuery(AbstractSqlPagingQueryProvider, String) - Static method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryUtils
Generate SQL query string using a TOP clause.
get() - Method in class org.springframework.cloud.task.configuration.observation.TaskObservationContext
 
get() - Method in class org.springframework.cloud.task.listener.TaskExecutionObservationContext
 
getAllFailureExceptions() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
Return all failure causing exceptions for this JobExecution, including step executions.
getApplicationId() - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
getApplicationName() - Method in class io.spring.TaskProcessorProperties
 
getApplicationName() - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
getApplicationName() - Method in class org.springframework.cloud.task.launcher.TaskLaunchRequest
Returns the name that will be associated with the launched task.
getApplicationRunnerOrder() - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchProperties
 
getApplicationVersion() - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
getArguments() - Method in class org.springframework.cloud.task.repository.TaskExecution
 
getBatchJobAssociations() - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getBeanName() - Method in class org.springframework.cloud.task.configuration.observation.TaskObservationContext
 
getChunkEventBindingName() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getChunkOrder() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getChunkSize() - Method in class org.springframework.cloud.task.batch.autoconfigure.SingleStepJobProperties
The number of items to process per transaction/chunk.
getClosecontextEnabled() - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
getCommandLineArgs(ExecutionContext) - Method in interface org.springframework.cloud.task.batch.partition.CommandLineArgsProvider
Returns a unique list of command line arguements to be passed to the partition's worker for the specified ExecutionContext.
getCommandLineArgs(ExecutionContext) - Method in class org.springframework.cloud.task.batch.partition.PassThroughCommandLineArgsProvider
 
getCommandLineArgs(ExecutionContext) - Method in class org.springframework.cloud.task.batch.partition.SimpleCommandLineArgsProvider
 
getCommandlineArguments() - Method in class org.springframework.cloud.task.launcher.TaskLaunchRequest
 
getCommandLineRunnerOrder() - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchProperties
Deprecated.
getComments() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
List of String values used to indicate what records are comments.
getCommitCount() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Returns the current number of commits for this execution.
getCreateTime() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
getCurrentItemCount() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Provides the index of the current item.
getCurrentItemCount() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Provides the index of the current item.
getDataSourceDriverClassName() - Method in class io.spring.TaskProcessorProperties
 
getDataSourcePassword() - Method in class io.spring.TaskProcessorProperties
 
getDataSourceUrl() - Method in class io.spring.TaskProcessorProperties
 
getDataSourceUserName() - Method in class io.spring.TaskProcessorProperties
 
getDate(String) - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
Deprecated.
getDate(String, Date) - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
Deprecated.
getDelimiter() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
The String used to divide the record into fields.
getDelimiter() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
When a file is delimited, this String will be used as the delimiter between fields.
getDeploymentProperties() - Method in class org.springframework.cloud.task.launcher.TaskLaunchRequest
Returns the properties used by a TaskLauncher.
getDouble(String) - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
Deprecated.
getDouble(String, double) - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
Deprecated.
getEncoding() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Returns the encoding for the input file.
getEncoding() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
File encoding for the output file.
getEndTime() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
getEndTime() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Returns the time that this execution ended.
getEndTime() - Method in class org.springframework.cloud.task.repository.TaskExecution
 
getEnvironmentProperties() - Method in class org.springframework.cloud.task.launcher.TaskLaunchRequest
Retrieves the environment variables for the task.
getEnvironmentVariables(ExecutionContext) - Method in interface org.springframework.cloud.task.batch.partition.EnvironmentVariablesProvider
Provides a Map of Strings to be used as environment variables.
getEnvironmentVariables(ExecutionContext) - Method in class org.springframework.cloud.task.batch.partition.NoOpEnvironmentVariablesProvider
 
getEnvironmentVariables(ExecutionContext) - Method in class org.springframework.cloud.task.batch.partition.SimpleEnvironmentVariablesProvider
 
getErrorMessage() - Method in class org.springframework.cloud.task.repository.TaskExecution
 
getExceptionMessage() - Method in class org.springframework.cloud.task.listener.TaskExecutionObservationContext
 
getExecutionContext() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
Returns the ExecutionContext for this execution.
getExecutionContext() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Returns the ExecutionContext for this execution.
getExecutionid() - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
getExecutionId() - Method in class org.springframework.cloud.task.repository.TaskExecution
 
getExitCode() - Method in class org.springframework.cloud.task.batch.listener.support.ExitStatus
 
getExitCode() - Method in class org.springframework.cloud.task.repository.TaskExecution
 
getExitDescription() - Method in class org.springframework.cloud.task.batch.listener.support.ExitStatus
 
getExitMessage() - Method in class org.springframework.cloud.task.repository.TaskExecution
 
getExitStatus() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
getExitStatus() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
getExternalExecutionId() - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
getExternalExecutionId() - Method in class org.springframework.cloud.task.repository.TaskExecution
 
getFailOnJobFailurePollInterval() - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchProperties
 
getFailureExceptions() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
getFailureExceptions() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
getFetchSize() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Provides the number of items to return each time the cursor fetches from the server.
getFilterCount() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Returns the current number of items filtered out of this execution.
getFormat() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Format used with the FormatterLineAggregator.
getFormat() - Method in class org.springframework.cloud.task.timestamp.TimestampTaskProperties
 
getFromClause() - Method in class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
 
getHighCardinalityKeyValues(TaskExecutionObservationContext) - Method in class org.springframework.cloud.task.listener.DefaultTaskExecutionObservationConvention
 
getId() - Method in class io.spring.configuration.TaskRunOutput
 
getIncludedFields() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
A List of indices indicating what fields to include.
getInstanceId() - Method in class org.springframework.cloud.task.batch.listener.support.JobInstanceEvent
 
getInstanceIndex() - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
getItemProcessEventBindingName() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getItemProcessOrder() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getItemReadEventBindingName() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getItemReadOrder() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getItemWriteEventBindingName() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getItemWriteOrder() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getJobExecutionEventBindingName() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getJobExecutionId() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
getJobExecutionIdsByTaskExecutionId(long) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
getJobExecutionIdsByTaskExecutionId(long) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getJobExecutionIdsByTaskExecutionId(long) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Returns the job execution ids associated with a task execution id.
getJobExecutionIdsByTaskExecutionId(long) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
getJobExecutionIdsByTaskExecutionId(long) - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Returns a Set of JobExecution ids for the jobs that were executed within the scope of the requested task.
getJobExecutionOrder() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getJobId() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
Convenience getter for for the id of the enclosing job.
getJobInstance() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
getJobName() - Method in class org.springframework.cloud.task.batch.autoconfigure.SingleStepJobProperties
The name of the job.
getJobName() - Method in class org.springframework.cloud.task.batch.listener.support.JobInstanceEvent
 
getJobNames() - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchProperties
 
getJobParameters() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
getLastUpdated() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
Get the date representing the last time this JobExecution was updated in the JobRepository.
getLastUpdated() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
getLatestTaskExecutionForTaskName(String) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
getLatestTaskExecutionForTaskName(String) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getLatestTaskExecutionForTaskName(String) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Returns the latest task execution for a given task name.
getLatestTaskExecutionForTaskName(String) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
getLatestTaskExecutionForTaskName(String) - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Returns the latest task execution for a given task name.
getLatestTaskExecutionsByTaskNames(String...) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
getLatestTaskExecutionsByTaskNames(String...) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getLatestTaskExecutionsByTaskNames(String...) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Returns a List of the latest TaskExecution for 1 or more task names.
getLatestTaskExecutionsByTaskNames(String...) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
getLatestTaskExecutionsByTaskNames(String...) - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Returns a List of the latest TaskExecution for 1 or more task names.
getLineSeparator() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
String used to separate lines in output.
getLinesToSkip() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Number of lines to skip when reading the input file.
getLocale() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
The Locale used when generating the output file.
getLong(String) - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
Deprecated.
getLong(String, long) - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
Deprecated.
getLowCardinalityKeyValues(TaskObservationContext) - Method in class org.springframework.cloud.task.configuration.observation.DefaultTaskObservationConvention
 
getLowCardinalityKeyValues(TaskExecutionObservationContext) - Method in class org.springframework.cloud.task.listener.DefaultTaskExecutionObservationConvention
 
getMaximumLength() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
The longest a record is allowed to be.
getMaxItemCount() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
The maximum number of items to be read.
getMaxItemCount() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
The maximum number of items to be read.
getMaxRows() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Provides the maximum number of rows to read with this reader.
getMinimumLength() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
The minimum record length.
getName() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Returns the configured value of the name used to calculate ExecutionContext keys.
getName() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Returns the configured value of the name used to calculate ExecutionContext keys.
getName() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcBatchItemWriterProperties
Returns the configured value of the name used to calculate ExecutionContext keys.
getName() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Returns the configured value of the name used to calculate ExecutionContext keys.
getName() - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderProperties
Returns the configured value of the name used to calculate ExecutionContext keys.
getName() - Method in class org.springframework.cloud.task.configuration.observation.DefaultTaskObservationConvention
 
getName() - Method in class org.springframework.cloud.task.listener.DefaultTaskExecutionObservationConvention
 
getNames() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Names of each column.
getNames() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Names of the fields to be extracted into the output.
getNextExecutionId() - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
getNextExecutionId() - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getNextExecutionId() - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Retrieves the next available execution id for a task execution.
getObject() - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchExecutionListenerFactoryBean
 
getObject() - Method in class org.springframework.cloud.task.batch.configuration.TaskJobLauncherApplicationRunnerFactoryBean
 
getObject() - Method in class org.springframework.cloud.task.listener.TaskListenerExecutorObjectFactory
 
getObject() - Method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryProviderFactoryBean
Get a PagingQueryProvider instance using the provided properties and appropriate for the given database type.
getObject() - Method in class org.springframework.cloud.task.repository.support.TaskExecutionDaoFactoryBean
 
getObjectType() - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchExecutionListenerFactoryBean
 
getObjectType() - Method in class org.springframework.cloud.task.batch.configuration.TaskJobLauncherApplicationRunnerFactoryBean
 
getObjectType() - Method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryProviderFactoryBean
Always returns PagingQueryProvider.
getObjectType() - Method in class org.springframework.cloud.task.repository.support.TaskExecutionDaoFactoryBean
 
getOrder() - Method in class org.springframework.cloud.task.batch.listener.EventEmittingChunkListener
 
getOrder() - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemProcessListener
 
getOrder() - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemReadListener
 
getOrder() - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemWriteListener
 
getOrder() - Method in class org.springframework.cloud.task.batch.listener.EventEmittingJobExecutionListener
 
getOrder() - Method in class org.springframework.cloud.task.batch.listener.EventEmittingSkipListener
 
getOrder() - Method in class org.springframework.cloud.task.batch.listener.EventEmittingStepExecutionListener
 
getOrder() - Method in class org.springframework.cloud.task.batch.listener.TaskBatchExecutionListener
 
getOrder() - Method in class org.springframework.cloud.task.listener.TaskLifecycleListener
 
getOrganizationName() - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
getOutput() - Method in class io.spring.configuration.TaskRunOutput
 
getPageQuery(Pageable) - Method in interface org.springframework.cloud.task.repository.database.PagingQueryProvider
Generate the query that will provide the jump to item query.
getPageQuery(Pageable) - Method in class org.springframework.cloud.task.repository.database.support.Db2PagingQueryProvider
 
getPageQuery(Pageable) - Method in class org.springframework.cloud.task.repository.database.support.H2PagingQueryProvider
 
getPageQuery(Pageable) - Method in class org.springframework.cloud.task.repository.database.support.HsqlPagingQueryProvider
 
getPageQuery(Pageable) - Method in class org.springframework.cloud.task.repository.database.support.MariaDbPagingQueryProvider
 
getPageQuery(Pageable) - Method in class org.springframework.cloud.task.repository.database.support.MySqlPagingQueryProvider
 
getPageQuery(Pageable) - Method in class org.springframework.cloud.task.repository.database.support.OraclePagingQueryProvider
 
getPageQuery(Pageable) - Method in class org.springframework.cloud.task.repository.database.support.PostgresPagingQueryProvider
 
getPageQuery(Pageable) - Method in class org.springframework.cloud.task.repository.database.support.SqlServerPagingQueryProvider
 
getParameterCount() - Method in interface org.springframework.cloud.task.repository.database.PagingQueryProvider
The number of parameters that are declared in the query.
getParameterCount() - Method in class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
 
getParameters() - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
Get a map of all parameters, including string, long, and date.
getParentExecutionId() - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
getParentExecutionId() - Method in class org.springframework.cloud.task.repository.TaskExecution
 
getPartitions() - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderProperties
A list of partitions to manually assign to the consumer.
getPhase() - Method in class org.springframework.cloud.task.listener.TaskLifecycleListener
 
getPollTimeOutInSeconds() - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderProperties
Get the pollTimeout for the poll() operations.
getProcessSkipCount() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
getQueryTimeout() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Provides the time in milliseconds for the query to timeout.
getQuoteCharacter() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
The char used to indicate that a field is quoted.
getRanges() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
The column ranges to be used to parsed a fixed width file.
getReadCount() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Returns the current number of items read for this execution.
getReadSkipCount() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
getResource() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
The input file for the FlatFileItemReader.
getResource() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
The output file for the FlatFileItemWriter.
getRollbackCount() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Returns the current number of rollbacks for this execution.
getRunningTaskExecutionCount() - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
getRunningTaskExecutionCount() - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getRunningTaskExecutionCount() - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Retrieves current number of task executions with an endTime of null.
getRunningTaskExecutionCount() - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
getRunningTaskExecutionCount() - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Retrieves current number of running task executions.
getRunningTaskExecutionCountByTaskName(String) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
getRunningTaskExecutionCountByTaskName(String) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getRunningTaskExecutionCountByTaskName(String) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Retrieves current number of task executions for a taskName and with an endTime of null.
getSelectClause() - Method in class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
 
getSingleInstanceEnabled() - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
getSingleInstanceLockCheckInterval() - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
getSingleInstanceLockTtl() - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
getSkipCount() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
getSkipEventBindingName() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getSkipOrder() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getSortKeys() - Method in interface org.springframework.cloud.task.repository.database.PagingQueryProvider
The sort keys.
getSortKeys() - Method in class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
A Map<String, Order> of sort columns as the key and Order for ascending/descending.
getSpaceId() - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
getSpaceName() - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
getSql() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcBatchItemWriterProperties
 
getSql() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Returns the SQL query to be executed.
getStartTime() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
getStartTime() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Gets the time this execution started.
getStartTime() - Method in class org.springframework.cloud.task.repository.TaskExecution
 
getStatus() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
getStatus() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Returns the current status of this step.
getStatus() - Method in class org.springframework.cloud.task.listener.TaskExecutionObservationContext
 
getStepExecutionEventBindingName() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getStepExecutionOrder() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getStepExecutions() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
Accessor for the step executions.
getStepName() - Method in class org.springframework.cloud.task.batch.autoconfigure.SingleStepJobProperties
Name of the step in the single step job.
getStepName() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
getString(String) - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
Deprecated.
getString(String, String) - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
Deprecated.
getSummary() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
getTablePrefix() - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
getTaskDataSource() - Method in class org.springframework.cloud.task.configuration.DefaultTaskConfigurer
 
getTaskDataSource() - Method in interface org.springframework.cloud.task.configuration.TaskConfigurer
Retrieves the DataSource that will be used for task operations.
getTaskEventBindingName() - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
getTaskExecution() - Method in class org.springframework.cloud.task.listener.TaskExecutionObservationContext
 
getTaskExecution(long) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
getTaskExecution(long) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getTaskExecution(long) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Retrieves a task execution from the task repository.
getTaskExecution(long) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
getTaskExecution(long) - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Retrieve a TaskExecution by its id.
getTaskExecutionCount() - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
getTaskExecutionCount() - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getTaskExecutionCount() - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Retrieves current number of task executions.
getTaskExecutionCount() - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
getTaskExecutionCount() - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Retrieves current number of task executions.
getTaskExecutionCountByTaskName(String) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
getTaskExecutionCountByTaskName(String) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getTaskExecutionCountByTaskName(String) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Retrieves current number of task executions for a taskName.
getTaskExecutionCountByTaskName(String) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
getTaskExecutionCountByTaskName(String) - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Get number of executions for a taskName.
getTaskExecutionDao() - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
Retrieves the taskExecutionDao associated with this repository.
getTaskExecutionIdByJobExecutionId(long) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
getTaskExecutionIdByJobExecutionId(long) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getTaskExecutionIdByJobExecutionId(long) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Returns the id of the TaskExecution that the requested Spring Batch job execution was executed within the context of.
getTaskExecutionIdByJobExecutionId(long) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
getTaskExecutionIdByJobExecutionId(long) - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Returns the id of the TaskExecution that the requested Spring Batch job execution was executed within the context of.
getTaskExecutions() - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getTaskExplorer() - Method in class org.springframework.cloud.task.configuration.DefaultTaskConfigurer
 
getTaskExplorer() - Method in interface org.springframework.cloud.task.configuration.TaskConfigurer
Create a TaskExplorer for the task.
getTaskName() - Method in class org.springframework.cloud.task.repository.support.SimpleTaskNameResolver
 
getTaskName() - Method in class org.springframework.cloud.task.repository.TaskExecution
 
getTaskName() - Method in interface org.springframework.cloud.task.repository.TaskNameResolver
 
getTaskNames() - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
getTaskNames() - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
getTaskNames() - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Retrieves a sorted list of distinct task names for the task executions.
getTaskNames() - Method in class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
getTaskNames() - Method in interface org.springframework.cloud.task.repository.TaskExplorer
Retrieve a list of available task names.
getTaskRepository() - Method in class org.springframework.cloud.task.configuration.DefaultTaskConfigurer
 
getTaskRepository() - Method in interface org.springframework.cloud.task.configuration.TaskConfigurer
Create a TaskRepository for the Task.
getTopic() - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderProperties
Returns the name of the topic from which messages will be read.
getTopic() - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemWriterProperties
Returns the name of the topic from which messages will be written.
getTransactionManager() - Method in class org.springframework.cloud.task.configuration.DefaultTaskConfigurer
 
getTransactionManager() - Method in interface org.springframework.cloud.task.configuration.TaskConfigurer
Create a PlatformTransactionManager for use with the TaskRepository.
getUri() - Method in class io.spring.TaskProcessorProperties
 
getUri() - Method in class org.springframework.cloud.task.launcher.TaskLaunchRequest
 
getValue() - Method in class org.springframework.cloud.task.batch.listener.support.JobParameterEvent
 
getWhereClause() - Method in class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
 
getWriteCount() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Returns the current number of items written for this execution.
getWriteSkipCount() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 

H

H2 - Enum constant in enum class org.springframework.cloud.task.repository.support.DatabaseType
H2 DB.
H2PagingQueryProvider - Class in org.springframework.cloud.task.repository.database.support
H2 implementation of a PagingQueryProvider using database specific features.
H2PagingQueryProvider() - Constructor for class org.springframework.cloud.task.repository.database.support.H2PagingQueryProvider
 
handle(StepExecutionSplitter, StepExecution) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
 
hashCode() - Method in class org.springframework.cloud.task.batch.listener.support.JobParameterEvent
 
hashCode() - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
 
hashCode() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
hashCode() - Method in class org.springframework.cloud.task.launcher.TaskLaunchRequest
 
HSQL - Enum constant in enum class org.springframework.cloud.task.repository.support.DatabaseType
HSQL DB.
HsqlPagingQueryProvider - Class in org.springframework.cloud.task.repository.database.support
HSQLDB implementation of a PagingQueryProvider using database specific features.
HsqlPagingQueryProvider() - Constructor for class org.springframework.cloud.task.repository.database.support.HsqlPagingQueryProvider
 

I

incrementCommitCount() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Increment the number of commits.
init(DataSource) - Method in interface org.springframework.cloud.task.repository.database.PagingQueryProvider
Initialize the query provider using the provided DataSource if necessary.
init(DataSource) - Method in class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
 
init(TaskExecution) - Method in class io.spring.configuration.TaskRunComponent
 
initialize() - Method in class org.springframework.cloud.task.configuration.SimpleTaskAutoConfiguration
Determines the TaskConfigurer to use.
initialize() - Method in class org.springframework.cloud.task.configuration.TaskLifecycleConfiguration
Initializes the TaskLifecycleListener for the task app.
io.spring - package io.spring
 
io.spring.cloud - package io.spring.cloud
 
io.spring.configuration - package io.spring.configuration
 
io.spring.task - package io.spring.task
 
io.spring.taskobservations - package io.spring.taskobservations
 
isAppend() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
True if an output file is found and should be added onto instead of replaced/deleted.
isAssertUpdates() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcBatchItemWriterProperties
 
isAutoStartup() - Method in class org.springframework.cloud.task.listener.TaskLifecycleListener
 
isDelete() - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemWriterProperties
Indicate if the items being passed to the writer are all to be sent as delete events to the topic.
isDelimited() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Indicates if the input file is a delimited file or not.
isDelimited() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Indicates of the output will be delimited by a configured string (, by default).
isDriverSupportsAbsolute() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Provides if the driver supports absolute positioning of a cursor.
isEmpty() - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
 
isEnabled() - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemReaderProperties
The state of the enabled flag.
isEnabled() - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemWriterProperties
The state of the enabled flag.
isFixedLength() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Indicates that a file contains records with fixed length columns.
isForceSync() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
A flag indicating that changes should be force-synced to disk on flush.
isFormatted() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Indicates that the output file will use String formatting to generate the output.
isIdentifying() - Method in class org.springframework.cloud.task.batch.listener.support.JobParameterEvent
 
isIgnoreWarnings() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Provides if SQL warnings should be ignored.
isInitializeEnabled() - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
isJsonConverterEnabled() - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemReaderProperties
States whether the Jackson2JsonMessageConverter is used as a message converter.
isJsonConverterEnabled() - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemWriterProperties
States whether the Jackson2JsonMessageConverter is used as a message converter.
isParsingStrict() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Indicates if the number of tokens must match the number of configured fields.
isRunning() - Method in class org.springframework.cloud.task.listener.TaskLifecycleListener
 
isSaveState() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Returns the configured value of if the state of the reader will be persisted.
isSaveState() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Returns the configured value of if the state of the reader will be persisted.
isSaveState() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Returns the configured value of if the state of the reader will be persisted.
isSaveState() - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderProperties
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
isShouldDeleteIfEmpty() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Indicates if the output file should be deleted if no output was written to it.
isShouldDeleteIfExists() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Indicates if an existing output file should be deleted on startup.
isSingleton() - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchExecutionListenerFactoryBean
 
isSingleton() - Method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryProviderFactoryBean
Always returns true.
isSingleton() - Method in class org.springframework.cloud.task.repository.support.TaskExecutionDaoFactoryBean
 
isStrict() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Returns true if a missing input file is considered an error.
isTerminateOnly() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
isTransactional() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Indicates if flushing the buffer should be delayed while a transaction is active.
isUseSharedExtendedConnection() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Sets whether the connection used for the cursor is being used by all other processing and is, therefore, part of the same transaction.
isUsingNamedParameters() - Method in interface org.springframework.cloud.task.repository.database.PagingQueryProvider
Indicate whether the generated queries use named parameter syntax.
isUsingNamedParameters() - Method in class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
 
isVerifyCursorPosition() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Indicates if the cursor's position should be validated with each item read (to confirm that the RowMapper has not moved the cursor's location).
ITEM_PROCESS_EVENTS_LISTENER - Static variable in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration
Name of the item process events listener bean.
ITEM_READ_EVENTS_LISTENER - Static variable in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration
Name of the item read events listener bean.
ITEM_WRITE_EVENTS_LISTENER - Static variable in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration
Name of the item write events listener bean.
itemProcessEventsListener(MessagePublisher, TaskEventProperties) - Method in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration.JobExecutionListenerConfiguration
 
itemReader(LineTokenizer, FieldSetMapper<Map<String, Object>>, LineMapper<Map<String, Object>>, LineCallbackHandler, RecordSeparatorPolicy) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderAutoConfiguration
 
itemReader(RowMapper<Map<String, Object>>, PreparedStatementSetter) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderAutoConfiguration
 
itemReadEventsListener(MessagePublisher, TaskEventProperties) - Method in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration.JobExecutionListenerConfiguration
 
itemWriteEventsListener(MessagePublisher, TaskEventProperties) - Method in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration.JobExecutionListenerConfiguration
 
itemWriter() - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterAutoConfiguration
 
itemWriter() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcBatchItemWriterAutoConfiguration
 

J

JdbcBatchItemWriterAutoConfiguration - Class in org.springframework.cloud.task.batch.autoconfigure.jdbc
Autconfiguration for a JdbcBatchItemWriter.
JdbcBatchItemWriterAutoConfiguration(DataSource, JdbcBatchItemWriterProperties) - Constructor for class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcBatchItemWriterAutoConfiguration
 
jdbcBatchItemWriterDataSourceProperties() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcBatchItemWriterAutoConfiguration
 
JdbcBatchItemWriterProperties - Class in org.springframework.cloud.task.batch.autoconfigure.jdbc
Properties to configure a JdbcBatchItemWriter.
JdbcBatchItemWriterProperties() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcBatchItemWriterProperties
 
JdbcCursorItemReaderAutoConfiguration - Class in org.springframework.cloud.task.batch.autoconfigure.jdbc
 
JdbcCursorItemReaderAutoConfiguration(JdbcCursorItemReaderProperties, DataSource) - Constructor for class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderAutoConfiguration
 
JdbcCursorItemReaderAutoConfiguration.MapRowMapper - Class in org.springframework.cloud.task.batch.autoconfigure.jdbc
 
jdbcCursorItemReaderDataSourceProperties() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderAutoConfiguration
 
JdbcCursorItemReaderProperties - Class in org.springframework.cloud.task.batch.autoconfigure.jdbc
 
JdbcCursorItemReaderProperties() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
 
JdbcTaskBatchDao - Class in org.springframework.cloud.task.batch.listener.support
JDBC based implementation of the TaskBatchDao.
JdbcTaskBatchDao(DataSource) - Constructor for class org.springframework.cloud.task.batch.listener.support.JdbcTaskBatchDao
Initializes the JdbcTaskBatchDao and defaults the table prefix to TaskProperties.DEFAULT_TABLE_PREFIX.
JdbcTaskBatchDao(DataSource, String) - Constructor for class org.springframework.cloud.task.batch.listener.support.JdbcTaskBatchDao
Initializes the JdbcTaskBatchDao.
JdbcTaskExecutionDao - Class in org.springframework.cloud.task.repository.dao
Stores Task Execution Information to a JDBC DataSource.
JdbcTaskExecutionDao(DataSource) - Constructor for class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
Initializes the JdbTaskExecutionDao and defaults the table prefix to TaskProperties.DEFAULT_TABLE_PREFIX.
JdbcTaskExecutionDao(DataSource, String) - Constructor for class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
Initializes the JdbcTaskExecutionDao.
job() - Method in class io.spring.cloud.BatchEventsApplication.JobConfiguration
 
job(ItemReader<Map<String, Object>>, ItemWriter<Map<String, Object>>) - Method in class org.springframework.cloud.task.batch.autoconfigure.SingleStepJobAutoConfiguration
 
JOB_EXECUTION_EVENTS_LISTENER - Static variable in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration
Name of the job execution events listener bean.
job1() - Method in class io.spring.configuration.JobConfiguration
 
JobConfiguration - Class in io.spring.configuration
 
JobConfiguration - Class in io.spring
 
JobConfiguration() - Constructor for class io.spring.cloud.BatchEventsApplication.JobConfiguration
 
JobConfiguration() - Constructor for class io.spring.configuration.JobConfiguration
 
JobConfiguration() - Constructor for class io.spring.JobConfiguration
 
JobExecutionEvent - Class in org.springframework.cloud.task.batch.listener.support
This is a JobEvent DTO created so that a JobExecution can be serialized into Json without having to add mixins to an ObjectMapper.
JobExecutionEvent() - Constructor for class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
JobExecutionEvent(JobExecution) - Constructor for class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
Constructor for the StepExecution to initialize the DTO.
jobExecutionEventsListener(MessagePublisher, TaskEventProperties) - Method in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration.JobExecutionListenerConfiguration
 
JobExecutionListenerConfiguration() - Constructor for class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration.JobExecutionListenerConfiguration
 
JobInstanceEvent - Class in org.springframework.cloud.task.batch.listener.support
This is a JobInstance DTO created so that a JobInstance can be serialized into Json without having to add mixins to an ObjectMapper.
JobInstanceEvent() - Constructor for class org.springframework.cloud.task.batch.listener.support.JobInstanceEvent
 
JobInstanceEvent(Long, String) - Constructor for class org.springframework.cloud.task.batch.listener.support.JobInstanceEvent
 
JobLaunchCondition - Class in org.springframework.cloud.task.batch.configuration
Evaluates if the correct conditions have been met to create a TaskJobLauncher.
JobLaunchCondition() - Constructor for class org.springframework.cloud.task.batch.configuration.JobLaunchCondition
 
JobParameterEvent - Class in org.springframework.cloud.task.batch.listener.support
This is a JobParameter DTO created so that a JobParameter can be serialized into Json without having to add mixins to an ObjectMapper.
JobParameterEvent() - Constructor for class org.springframework.cloud.task.batch.listener.support.JobParameterEvent
 
JobParameterEvent(JobParameter) - Constructor for class org.springframework.cloud.task.batch.listener.support.JobParameterEvent
 
JobParametersEvent - Class in org.springframework.cloud.task.batch.listener.support
This is a JobParametersEvent DTO created so that a JobParameters can be serialized into Json without having to add mixins to an ObjectMapper.
JobParametersEvent() - Constructor for class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
 
JobParametersEvent(Map<String, JobParameter<?>>) - Constructor for class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
 
jobRepository - Variable in class io.spring.configuration.JobConfiguration
 
jobRepository - Variable in class io.spring.JobConfiguration
 
JpaApplication - Class in io.spring
 
JpaApplication() - Constructor for class io.spring.JpaApplication
 

K

kafkaItemReader(KafkaItemReaderProperties) - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderAutoConfiguration
 
KafkaItemReaderAutoConfiguration - Class in org.springframework.cloud.task.batch.autoconfigure.kafka
AutoConfiguration for a KafkaItemReader.
KafkaItemReaderAutoConfiguration() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderAutoConfiguration
 
KafkaItemReaderProperties - Class in org.springframework.cloud.task.batch.autoconfigure.kafka
Properties to configure a KafkaItemReader.
KafkaItemReaderProperties() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderProperties
 
kafkaItemWriter(KafkaItemWriterProperties, ProducerFactory<Object, Map<String, Object>>, Converter<Map<String, Object>, Object>) - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemWriterAutoConfiguration
 
KafkaItemWriterAutoConfiguration - Class in org.springframework.cloud.task.batch.autoconfigure.kafka
Autconfiguration for a KafkaItemReader.
KafkaItemWriterAutoConfiguration() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemWriterAutoConfiguration
 
KafkaItemWriterProperties - Class in org.springframework.cloud.task.batch.autoconfigure.kafka
Properties to configure a KafkaItemWriter.
KafkaItemWriterProperties() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemWriterProperties
 

L

launchWorker(StepExecution) - Method in class org.springframework.cloud.task.batch.partition.TaskLauncherHandler
Launches the partition for the StepExecution.
ListenerConfiguration() - Constructor for class org.springframework.cloud.task.listener.TaskEventAutoConfiguration.ListenerConfiguration
 
lockTask(TaskExecution) - Method in class org.springframework.cloud.task.configuration.SingleInstanceTaskListener
 
logger - Static variable in class org.springframework.cloud.task.configuration.SimpleTaskAutoConfiguration
 
logger - Static variable in class org.springframework.cloud.task.configuration.TaskLifecycleConfiguration
 

M

main(String[]) - Static method in class io.spring.BatchJobApplication
 
main(String[]) - Static method in class io.spring.cloud.BatchEventsApplication
 
main(String[]) - Static method in class io.spring.JpaApplication
 
main(String[]) - Static method in class io.spring.MultipleDataSourcesApplication
 
main(String[]) - Static method in class io.spring.PartitionedBatchJobApplication
 
main(String[]) - Static method in class io.spring.SingleStepBatchJobApplication
 
main(String[]) - Static method in class io.spring.TaskEventsApplication
 
main(String[]) - Static method in class io.spring.taskobservations.TaskObservationsApplication
 
main(String[]) - Static method in class io.spring.TaskProcessorApplication
 
main(String[]) - Static method in class io.spring.TaskSinkApplication
 
main(String[]) - Static method in class org.springframework.cloud.task.timestamp.TaskApplication
 
MapFieldExtractor(String[]) - Constructor for class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterAutoConfiguration.MapFieldExtractor
 
mapFieldSet(FieldSet) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderAutoConfiguration.MapFieldSetMapper
 
MapFieldSetMapper() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderAutoConfiguration.MapFieldSetMapper
 
mapRow(ResultSet, int) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderAutoConfiguration.MapRowMapper
 
MapRowMapper() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderAutoConfiguration.MapRowMapper
 
MapTaskBatchDao - Class in org.springframework.cloud.task.batch.listener.support
Map implementation of the TaskBatchDao.
MapTaskBatchDao(Map<Long, Set<Long>>) - Constructor for class org.springframework.cloud.task.batch.listener.support.MapTaskBatchDao
 
MapTaskExecutionDao - Class in org.springframework.cloud.task.repository.dao
Stores Task Execution Information to a in-memory map.
MapTaskExecutionDao() - Constructor for class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
MARIADB - Enum constant in enum class org.springframework.cloud.task.repository.support.DatabaseType
MySQL DB.
MariaDbPagingQueryProvider - Class in org.springframework.cloud.task.repository.database.support
MariaDB implementation of a PagingQueryProvider using database specific features.
MariaDbPagingQueryProvider() - Constructor for class org.springframework.cloud.task.repository.database.support.MariaDbPagingQueryProvider
 
MAX_ERROR_MESSAGE_SIZE - Static variable in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
Default max error message size.
MAX_EXIT_MESSAGE_SIZE - Static variable in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
Default max exit message size.
MAX_TASK_NAME_SIZE - Static variable in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
Default max task name size.
messageConverter() - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemReaderAutoConfiguration
 
messageConverter() - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemWriterAutoConfiguration
 
messagePublisher(StreamBridge) - Method in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration.JobExecutionListenerConfiguration
 
MessagePublisher<P> - Class in org.springframework.cloud.task.batch.listener.support
Utility class that sends batch job listener payloads to the notification channel.
MessagePublisher(StreamBridge) - Constructor for class org.springframework.cloud.task.batch.listener.support.MessagePublisher
 
meterRegistry() - Method in class io.spring.taskobservations.ObservationConfiguration
 
MultipleDataSourcesApplication - Class in io.spring
 
MultipleDataSourcesApplication() - Constructor for class io.spring.MultipleDataSourcesApplication
 
myDataSourceProperties() - Method in class io.spring.configuration.ExternalDataSourceConfiguration
 
MYSQL - Enum constant in enum class org.springframework.cloud.task.repository.support.DatabaseType
MySQL DB.
MySqlPagingQueryProvider - Class in org.springframework.cloud.task.repository.database.support
MySQL implementation of a PagingQueryProvider using database specific features.
MySqlPagingQueryProvider() - Constructor for class org.springframework.cloud.task.repository.database.support.MySqlPagingQueryProvider
 

N

NoOpEnvironmentVariablesProvider - Class in org.springframework.cloud.task.batch.partition
A simple no-op implementation of the EnvironmentVariablesProvider.
NoOpEnvironmentVariablesProvider() - Constructor for class org.springframework.cloud.task.batch.partition.NoOpEnvironmentVariablesProvider
 

O

ObservationConfiguration - Class in io.spring.taskobservations
 
ObservationConfiguration() - Constructor for class io.spring.taskobservations.ObservationConfiguration
 
ObservationTaskAutoConfiguration - Class in org.springframework.cloud.task.configuration.observation
Auto-configuration that registers instrumentation for Spring Cloud Task.
ObservationTaskAutoConfiguration() - Constructor for class org.springframework.cloud.task.configuration.observation.ObservationTaskAutoConfiguration
 
onApplicationEvent(ApplicationEvent) - Method in class org.springframework.cloud.task.configuration.SingleInstanceTaskListener
 
onApplicationEvent(ApplicationEvent) - Method in class org.springframework.cloud.task.listener.TaskLifecycleListener
Utilizes ApplicationEvents to determine the end and failure of a task.
onProcessError(Object, Exception) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemProcessListener
 
onReadError(Exception) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemReadListener
 
onSkipInProcess(Object, Throwable) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingSkipListener
 
onSkipInRead(Throwable) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingSkipListener
 
onSkipInWrite(Object, Throwable) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingSkipListener
 
onTaskEnd(TaskExecution) - Method in class org.springframework.cloud.task.listener.annotation.TaskListenerExecutor
Executes all the methods that have been annotated with @AfterTask.
onTaskEnd(TaskExecution) - Method in interface org.springframework.cloud.task.listener.TaskExecutionListener
Invoked before the TaskExecution has been updated in the TaskRepository upon task end.
onTaskEnd(TaskExecution) - Method in class org.springframework.cloud.task.listener.TaskObservations
 
onTaskFailed(Throwable) - Method in class org.springframework.cloud.task.listener.TaskObservations
 
onTaskFailed(TaskExecution, Throwable) - Method in class org.springframework.cloud.task.listener.annotation.TaskListenerExecutor
Executes all the methods that have been annotated with @FailedTask.
onTaskFailed(TaskExecution, Throwable) - Method in interface org.springframework.cloud.task.listener.TaskExecutionListener
Invoked if an uncaught exception occurs during a task execution.
onTaskStartup(TaskExecution) - Method in class org.springframework.cloud.task.batch.listener.TaskBatchExecutionListener
 
onTaskStartup(TaskExecution) - Method in class org.springframework.cloud.task.batch.partition.SimpleCommandLineArgsProvider
 
onTaskStartup(TaskExecution) - Method in class org.springframework.cloud.task.listener.annotation.TaskListenerExecutor
Executes all the methods that have been annotated with @BeforeTask.
onTaskStartup(TaskExecution) - Method in interface org.springframework.cloud.task.listener.TaskExecutionListener
Invoked after the TaskExecution has been stored in the TaskRepository.
onTaskStartup(TaskExecution) - Method in class org.springframework.cloud.task.listener.TaskObservations
 
onWriteError(Exception, Chunk) - Method in class org.springframework.cloud.task.batch.listener.EventEmittingItemWriteListener
 
ORACLE - Enum constant in enum class org.springframework.cloud.task.repository.support.DatabaseType
Oracle DB.
OraclePagingQueryProvider - Class in org.springframework.cloud.task.repository.database.support
Oracle implementation of a PagingQueryProvider using database specific features.
OraclePagingQueryProvider() - Constructor for class org.springframework.cloud.task.repository.database.support.OraclePagingQueryProvider
 
org.springframework.cloud.task - package org.springframework.cloud.task
Base package for spring cloud task.
org.springframework.cloud.task.batch.autoconfigure - package org.springframework.cloud.task.batch.autoconfigure
 
org.springframework.cloud.task.batch.autoconfigure.flatfile - package org.springframework.cloud.task.batch.autoconfigure.flatfile
 
org.springframework.cloud.task.batch.autoconfigure.jdbc - package org.springframework.cloud.task.batch.autoconfigure.jdbc
 
org.springframework.cloud.task.batch.autoconfigure.kafka - package org.springframework.cloud.task.batch.autoconfigure.kafka
 
org.springframework.cloud.task.batch.autoconfigure.rabbit - package org.springframework.cloud.task.batch.autoconfigure.rabbit
 
org.springframework.cloud.task.batch.configuration - package org.springframework.cloud.task.batch.configuration
 
org.springframework.cloud.task.batch.handler - package org.springframework.cloud.task.batch.handler
 
org.springframework.cloud.task.batch.listener - package org.springframework.cloud.task.batch.listener
 
org.springframework.cloud.task.batch.listener.support - package org.springframework.cloud.task.batch.listener.support
 
org.springframework.cloud.task.batch.partition - package org.springframework.cloud.task.batch.partition
 
org.springframework.cloud.task.configuration - package org.springframework.cloud.task.configuration
Interfaces for configuring Spring Cloud Task and a default implementations.
org.springframework.cloud.task.configuration.observation - package org.springframework.cloud.task.configuration.observation
 
org.springframework.cloud.task.launcher - package org.springframework.cloud.task.launcher
 
org.springframework.cloud.task.launcher.annotation - package org.springframework.cloud.task.launcher.annotation
 
org.springframework.cloud.task.listener - package org.springframework.cloud.task.listener
 
org.springframework.cloud.task.listener.annotation - package org.springframework.cloud.task.listener.annotation
 
org.springframework.cloud.task.repository - package org.springframework.cloud.task.repository
 
org.springframework.cloud.task.repository.dao - package org.springframework.cloud.task.repository.dao
Interface DAO and default implementations for storing and retrieving data for tasks from a repository.
org.springframework.cloud.task.repository.database - package org.springframework.cloud.task.repository.database
 
org.springframework.cloud.task.repository.database.support - package org.springframework.cloud.task.repository.database.support
 
org.springframework.cloud.task.repository.support - package org.springframework.cloud.task.repository.support
Classes used for setting up and supporting a task repositories.
org.springframework.cloud.task.timestamp - package org.springframework.cloud.task.timestamp
 

P

PagingQueryProvider - Interface in org.springframework.cloud.task.repository.database
Interface defining the functionality to be provided for generating paging queries.
PartitionedBatchJobApplication - Class in io.spring
 
PartitionedBatchJobApplication() - Constructor for class io.spring.PartitionedBatchJobApplication
 
partitionedJob(PartitionHandler) - Method in class io.spring.JobConfiguration
 
partitioner() - Method in class io.spring.JobConfiguration
 
partitionHandler(TaskLauncher, JobExplorer, TaskRepository, ThreadPoolTaskExecutor) - Method in class io.spring.JobConfiguration
 
PassThroughCommandLineArgsProvider - Class in org.springframework.cloud.task.batch.partition
Returns the List<String> provided.
PassThroughCommandLineArgsProvider(List<String>) - Constructor for class org.springframework.cloud.task.batch.partition.PassThroughCommandLineArgsProvider
 
POSTGRES - Enum constant in enum class org.springframework.cloud.task.repository.support.DatabaseType
PostgreSQL DB.
PostgresPagingQueryProvider - Class in org.springframework.cloud.task.repository.database.support
Postgres implementation of a PagingQueryProvider using database specific features.
PostgresPagingQueryProvider() - Constructor for class org.springframework.cloud.task.repository.database.support.PostgresPagingQueryProvider
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchExecutionListenerBeanPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.cloud.task.batch.listener.support.TaskBatchEventListenerBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchExecutionListenerBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.cloud.task.batch.listener.support.TaskBatchEventListenerBeanPostProcessor
 
processRequest() - Method in class io.spring.TaskProcessor
 
publish(String, P) - Method in class org.springframework.cloud.task.batch.listener.support.MessagePublisher
 
publishWithThrowableHeader(String, P, String) - Method in class org.springframework.cloud.task.batch.listener.support.MessagePublisher
 

R

RangeConverter - Class in org.springframework.cloud.task.batch.autoconfigure
Converter for taking properties of format start-end or start (where start and end are both integers) and converting them into Range instances for configuring a FlatFileItemReader.
RangeConverter() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.RangeConverter
 
readerDataSource(DataSourceProperties) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderAutoConfiguration
 
registerHints(RuntimeHints, ClassLoader) - Method in class org.springframework.cloud.task.configuration.TaskRuntimeHints
 
rowMapper() - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderAutoConfiguration
 
run() - Method in class org.springframework.cloud.task.batch.partition.TaskLauncherHandler
 
run(String...) - Method in class io.spring.task.SampleCommandLineRunner
 
run(String...) - Method in class org.springframework.cloud.task.batch.handler.TaskJobLauncherApplicationRunner
 
run(String...) - Method in class org.springframework.cloud.task.batch.partition.DeployerStepExecutionHandler
 
run(String...) - Method in class org.springframework.cloud.task.timestamp.TaskApplication.TimestampTask
 
RUNNING_TASK_WHERE_CLAUSE - Static variable in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
WHERE clause for running task.

S

SampleCommandLineRunner - Class in io.spring.task
 
SampleCommandLineRunner(List<DataSource>) - Constructor for class io.spring.task.SampleCommandLineRunner
 
saveRelationship(TaskExecution, JobExecution) - Method in class org.springframework.cloud.task.batch.listener.support.JdbcTaskBatchDao
 
saveRelationship(TaskExecution, JobExecution) - Method in class org.springframework.cloud.task.batch.listener.support.MapTaskBatchDao
 
saveRelationship(TaskExecution, JobExecution) - Method in interface org.springframework.cloud.task.batch.listener.TaskBatchDao
Saves the relationship between a task execution and a job execution.
secondDataSource() - Method in class io.spring.configuration.EmbeddedDataSourceConfiguration
 
secondDataSource(DataSourceProperties) - Method in class io.spring.configuration.ExternalDataSourceConfiguration
 
SELECT_CLAUSE - Static variable in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
SELECT clause for task execution.
setAppend(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure if the output file is found if it should be appended to.
setAppendedArgs(List<String>) - Method in class org.springframework.cloud.task.batch.partition.SimpleCommandLineArgsProvider
Additional command line args to be appended.
setApplicationContext(ApplicationContext) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskNameResolver
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.cloud.task.batch.configuration.TaskJobLauncherApplicationRunnerFactoryBean
 
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.cloud.task.batch.handler.TaskJobLauncherApplicationRunner
 
setApplicationId(String) - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
setApplicationName(String) - Method in class io.spring.TaskProcessorProperties
 
setApplicationName(String) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
The name of the application to be launched.
setApplicationName(String) - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
setApplicationName(String) - Method in class org.springframework.cloud.task.launcher.TaskLaunchRequest
Sets the name to be applied to the launched task.
setApplicationRunnerOrder(int) - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchProperties
 
setApplicationVersion(String) - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
setArguments(List<String>) - Method in class org.springframework.cloud.task.repository.TaskExecution
 
setAssertUpdates(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcBatchItemWriterProperties
If set to true, confirms that every insert results in the update of at least one row in the database.
setChunkEventBindingName(String) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setChunkOrder(int) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setChunkSize(Integer) - Method in class org.springframework.cloud.task.batch.autoconfigure.SingleStepJobProperties
Set the number of items within a transaction/chunk.
setClosecontextEnabled(Boolean) - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
setCommandLineArgsProvider(CommandLineArgsProvider) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
Used to provide any command line arguements to be passed to each worker launched.
setCommandLineRunnerOrder(int) - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchProperties
Deprecated.
setComments(List<String>) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Takes a list of String elements used to indicate what records are comments.
setCommitCount(int) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Sets the current number of commits for this execution.
setConfiguredName(String) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskNameResolver
 
setCreateTime(LocalDateTime) - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
setCurrentItemCount(int) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Index for the current item.
setCurrentItemCount(int) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Index for the current item.
setDatabaseType(String) - Method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryProviderFactoryBean
 
setDataSource(DataSource) - Method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryProviderFactoryBean
 
setDataSource(DataSource) - Method in class org.springframework.cloud.task.repository.support.TaskRepositoryInitializer
 
setDataSourceDriverClassName(String) - Method in class io.spring.TaskProcessorProperties
 
setDataSourcePassword(String) - Method in class io.spring.TaskProcessorProperties
 
setDataSourceUrl(String) - Method in class io.spring.TaskProcessorProperties
 
setDataSourceUserName(String) - Method in class io.spring.TaskProcessorProperties
 
setDefaultArgsAsEnvironmentVars(boolean) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
If set to true, the default args that are used internally by Spring Cloud Task and Spring Batch are passed as environment variables instead of command line arguments.
setDelete(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemWriterProperties
Indicate if the items being passed to the writer are all to be sent as delete events to the topic.
setDelimited(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Indicates that a DelimitedLineTokenizer should be used to parse each line.
setDelimited(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure the use of the DelimitedLineAggregator to generate the output per item.
setDelimiter(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Define the delimiter for the file.
setDelimiter(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure the String used to delimit the fields in the output file.
setDeploymentProperties(Map<String, String>) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
Map of deployment properties to be used by the TaskLauncher.
setDriverSupportsAbsolute(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Sets if the driver supports absolute positioning of a cursor.
setEnabled(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemReaderProperties
Enables or disables the AmqpItemReader.
setEnabled(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemWriterProperties
Enables or disables the AmqpItemWriter.
setEncoding(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Configure the encoding used by the reader to read the input source.
setEncoding(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure encoding of the output file.
setEndTime(LocalDateTime) - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
setEndTime(LocalDateTime) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Sets the time that this execution ended.
setEndTime(LocalDateTime) - Method in class org.springframework.cloud.task.repository.TaskExecution
 
setEnvironment(Environment) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
 
setEnvironmentProperties(Map<String, String>) - Method in class org.springframework.cloud.task.batch.partition.SimpleEnvironmentVariablesProvider
 
setEnvironmentVariablesProvider(EnvironmentVariablesProvider) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
Used to provide any environment variables to be set on each worker launched.
setErrorMessage(String) - Method in class org.springframework.cloud.task.repository.TaskExecution
 
setExceptionMessage(String) - Method in class org.springframework.cloud.task.listener.TaskExecutionObservationContext
 
setExecutionContext(ExecutionContext) - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
Sets the ExecutionContext for this execution.
setExecutionContext(ExecutionContext) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Sets the ExecutionContext for this execution.
setExecutionid(Long) - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
setExitCode(Integer) - Method in class org.springframework.cloud.task.repository.TaskExecution
 
setExitCode(String) - Method in class org.springframework.cloud.task.batch.listener.support.ExitStatus
 
setExitDescription(String) - Method in class org.springframework.cloud.task.batch.listener.support.ExitStatus
 
setExitMessage(String) - Method in class org.springframework.cloud.task.repository.TaskExecution
 
setExitStatus(ExitStatus) - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
setExitStatus(ExitStatus) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
setExternalExecutionId(String) - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
setExternalExecutionId(String) - Method in class org.springframework.cloud.task.repository.TaskExecution
 
setFailOnJobFailurePollInterval(long) - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchProperties
 
setFetchSize(int) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Sets the number of items to return each time the cursor fetches from the server.
setFilterCount(int) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Public setter for the number of items filtered out of this execution.
setFixedLength(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Indicates that a FixedLengthTokenizer should be used to parse the records in the file.
setForceSync(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
A flag indicating that changes should be force-synced to disk on flush.
setFormat(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure the format the FormatterLineAggregator will use for each item.
setFormat(String) - Method in class org.springframework.cloud.task.timestamp.TimestampTaskProperties
 
setFormatted(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Indicates to use a FormatterLineAggregator to generate the output per item.
setFromClause(String) - Method in class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
 
setFromClause(String) - Method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryProviderFactoryBean
 
setGridSize(int) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
Approximate size of the pool of worker JVMs available.
setId(Long) - Method in class io.spring.configuration.TaskRunOutput
 
setIgnoreWarnings(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Sets if SQL warnings should be ignored.
setIncludeCurrentEnvironment(boolean) - Method in class org.springframework.cloud.task.batch.partition.SimpleEnvironmentVariablesProvider
Establishes if current environment variables will be included as a part of the provider.
setIncludedFields(List<Integer>) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
A list of indices of the fields within a delimited file to be included.
setInitializeEnabled(Boolean) - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
setInstanceIndex(String) - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
setItemProcessEventBindingName(String) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setItemProcessOrder(int) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setItemReadEventBindingName(String) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setItemReadOrder(int) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setItemWriteEventBindingName(String) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setItemWriteOrder(int) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setJobExecutionEventBindingName(String) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setJobExecutionOrder(int) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setJobInstance(JobInstanceEvent) - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
setJobName(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.SingleStepJobProperties
Set the name of the job.
setJobNames(String) - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchProperties
 
setJobNames(List<String>) - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchExecutionListenerBeanPostProcessor
 
setJsonConverterEnabled(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemReaderProperties
Establishes whether the Jackson2JsonMessageConverter is to be used as a message converter.
setJsonConverterEnabled(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.rabbit.AmqpItemWriterProperties
Establishes whether the Jackson2JsonMessageConverter is to be used as a message converter.
setLastUpdated(LocalDateTime) - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
Set the last time this JobExecution was updated.
setLastUpdated(LocalDateTime) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Set the time when the StepExecution was last updated before persisting.
setLineSeparator(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure the String used to separate each line.
setLinesToSkip(int) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
The number of lines to skip at the beginning of reading the file.
setLocale(Locale) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure the Locale to use when generating the output.
setMaxErrorMessageSize(int) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
setMaxExitMessageSize(int) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
setMaximumLength(int) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure the maximum record length.
setMaxItemCount(int) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Configure the max number of items to be read.
setMaxItemCount(int) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Configure the max number of items to be read.
setMaxRows(int) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Sets the maximum number of rows to be read with this reader.
setMaxTaskNameSize(int) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
setMaxWorkers(int) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
The maximum number of workers to be executing at once.
setMinimumLength(int) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure the minimum record length.
setName(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
The name used to calculate the key within the ExecutionContext.
setName(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
The name used to calculate the key within the ExecutionContext.
setName(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcBatchItemWriterProperties
The name used to calculate the key within the ExecutionContext.
setName(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
The name used to calculate the key within the ExecutionContext.
setName(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderProperties
The name used to calculate the key within the ExecutionContext.
setNames(String[]) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
The names of the fields to be parsed from the file.
setNames(String[]) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Provide an ordered array of field names used to generate the output of a file.
setOrder(int) - Method in class org.springframework.cloud.task.batch.configuration.TaskJobLauncherApplicationRunnerFactoryBean
 
setOrganizationName(String) - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
setOutput(String) - Method in class io.spring.configuration.TaskRunOutput
 
setParentExecutionId(Long) - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
setParentExecutionId(Long) - Method in class org.springframework.cloud.task.repository.TaskExecution
 
setParsingStrict(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Indicates if the number of tokens must match the number of configured fields.
setPartitions(List<Integer>) - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderProperties
A list of partitions to manually assign to the consumer.
setPollInterval(long) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
The interval to check the job repository for completed steps.
setPollTimeOutInSeconds(long) - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderProperties
Set the pollTimeout for the poll() operations.
setProcessSkipCount(int) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Set the number of records skipped during processing.
setQueryTimeout(int) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Sets the time in milliseconds for the query to timeout.
setQuoteCharacter(char) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Define the character used to quote fields.
setRanges(List<Range>) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Column ranges for each field.
setReadCount(int) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Sets the current number of read items for this execution.
setReadSkipCount(int) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Set the number of records skipped on read.
setResource(Resource) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
The Resource to be used as input.
setResource(Resource) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
The Resource to be used as output.
setResourceLoader(ResourceLoader) - Method in class org.springframework.cloud.task.repository.support.TaskRepositoryInitializer
 
setRollbackCount(int) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Setter for number of rollbacks for this execution.
setSaveState(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
setSaveState(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
setSaveState(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
setSaveState(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderProperties
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
setSelectClause(String) - Method in class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
 
setSelectClause(String) - Method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryProviderFactoryBean
 
setShouldDeleteIfEmpty(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure if an empty output file should be deleted once the step is complete.
setShouldDeleteIfExists(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configures if an existing output file should be deleted on the start of the step.
setSingleInstanceEnabled(boolean) - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
setSingleInstanceLockCheckInterval(int) - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
setSingleInstanceLockTtl(int) - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
setSkipEventBindingName(String) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setSkipOrder(int) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setSortKeys(Map<String, Order>) - Method in class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
 
setSortKeys(Map<String, Order>) - Method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryProviderFactoryBean
 
setSpaceId(String) - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
setSpaceName(String) - Method in class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
setSql(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcBatchItemWriterProperties
Sets the sql statement to be used to update the database.
setSql(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Sets the SQL query to be executed.
setStartTime(LocalDateTime) - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
setStartTime(LocalDateTime) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Sets the time this execution started.
setStartTime(LocalDateTime) - Method in class org.springframework.cloud.task.repository.TaskExecution
 
setStatus(String) - Method in class org.springframework.cloud.task.listener.TaskExecutionObservationContext
 
setStatus(BatchStatus) - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
Set the value of the status field.
setStatus(BatchStatus) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Sets the current status of this step.
setStepExecutionEventBindingName(String) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setStepExecutionOrder(int) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setStepName(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.SingleStepJobProperties
Set the name of the step.
setStepName(String) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
setStrict(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemReaderProperties
Configure if the reader should be in strict mode (require the input Resource to exist).
setTablePrefix(String) - Method in class org.springframework.cloud.task.configuration.TaskProperties
 
setTaskEventBindingName(String) - Method in class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
setTaskIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
setTaskName(String) - Method in class org.springframework.cloud.task.repository.TaskExecution
 
setTerminateOnly() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Set a flag that will signal to an execution environment that this execution (and its surrounding job) wishes to exit.
setTimeout(long) - Method in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
Timeout for the master step.
setTopic(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemReaderProperties
The topic name from which the messages will be read.
setTopic(String) - Method in class org.springframework.cloud.task.batch.autoconfigure.kafka.KafkaItemWriterProperties
The topic name from which the messages are written.
setTransactional(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.flatfile.FlatFileItemWriterProperties
Configure if output should not be flushed to disk during an active transaction.
setUri(String) - Method in class io.spring.TaskProcessorProperties
 
setUseSharedExtendedConnection(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Sets whether the the connection used for the cursor is being used by all other processing and is, therefore, part of the same transaction.
setVerifyCursorPosition(boolean) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcCursorItemReaderProperties
Provides if the cursor's position should be validated with each item read.
setWhereClause(String) - Method in class org.springframework.cloud.task.repository.database.support.AbstractSqlPagingQueryProvider
 
setWhereClause(String) - Method in class org.springframework.cloud.task.repository.database.support.SqlPagingQueryProviderFactoryBean
 
setWriteCount(int) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Sets the current number of written items for this execution.
setWriteSkipCount(int) - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Set the number of records skipped on write.
SimpleCommandLineArgsProvider - Class in org.springframework.cloud.task.batch.partition
Returns any command line arguments used with the TaskExecution provided appended with any additional arguments configured.
SimpleCommandLineArgsProvider() - Constructor for class org.springframework.cloud.task.batch.partition.SimpleCommandLineArgsProvider
 
SimpleCommandLineArgsProvider(TaskExecution) - Constructor for class org.springframework.cloud.task.batch.partition.SimpleCommandLineArgsProvider
 
SimpleEnvironmentVariablesProvider - Class in org.springframework.cloud.task.batch.partition
Copies all existing environment variables as made available in the Environment only if includeCurrentEnvironment is set to true (default).
SimpleEnvironmentVariablesProvider(Environment) - Constructor for class org.springframework.cloud.task.batch.partition.SimpleEnvironmentVariablesProvider
 
simpleMeterRegistry - Variable in class io.spring.taskobservations.TaskObservationsApplication
 
SimpleTaskAutoConfiguration - Class in org.springframework.cloud.task.configuration
Base Configuration class providing common structure for enabling and using Spring Task.
SimpleTaskAutoConfiguration() - Constructor for class org.springframework.cloud.task.configuration.SimpleTaskAutoConfiguration
 
SimpleTaskExplorer - Class in org.springframework.cloud.task.repository.support
TaskExplorer for that gathers task information from a task repository.
SimpleTaskExplorer(TaskExecutionDaoFactoryBean) - Constructor for class org.springframework.cloud.task.repository.support.SimpleTaskExplorer
 
SimpleTaskNameResolver - Class in org.springframework.cloud.task.repository.support
Simple implementation of the TaskNameResolver interface.
SimpleTaskNameResolver() - Constructor for class org.springframework.cloud.task.repository.support.SimpleTaskNameResolver
 
SimpleTaskRepository - Class in org.springframework.cloud.task.repository.support
Records the task execution information to the log and to TaskExecutionDao provided.
SimpleTaskRepository(FactoryBean<TaskExecutionDao>) - Constructor for class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
SimpleTaskRepository(FactoryBean<TaskExecutionDao>, Integer, Integer, Integer) - Constructor for class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
SingleInstanceTaskListener - Class in org.springframework.cloud.task.configuration
When spring.cloud.task.single-instance-enabled is set to true this listener will create a lock for the task based on the spring.cloud.task.name.
SingleInstanceTaskListener(DataSource, TaskNameResolver, TaskProperties, ApplicationEventPublisher, ApplicationContext) - Constructor for class org.springframework.cloud.task.configuration.SingleInstanceTaskListener
 
SingleInstanceTaskListener(LockRegistry, TaskNameResolver, TaskProperties, ApplicationEventPublisher, ApplicationContext) - Constructor for class org.springframework.cloud.task.configuration.SingleInstanceTaskListener
 
SingleStepBatchJobApplication - Class in io.spring
 
SingleStepBatchJobApplication() - Constructor for class io.spring.SingleStepBatchJobApplication
 
SingleStepJobAutoConfiguration - Class in org.springframework.cloud.task.batch.autoconfigure
Autoconfiguration to create a single step Spring Batch Job.
SingleStepJobAutoConfiguration(SingleStepJobProperties, ApplicationContext) - Constructor for class org.springframework.cloud.task.batch.autoconfigure.SingleStepJobAutoConfiguration
 
SingleStepJobProperties - Class in org.springframework.cloud.task.batch.autoconfigure
Properties to configure the step and job level properties for a single step job.
SingleStepJobProperties() - Constructor for class org.springframework.cloud.task.batch.autoconfigure.SingleStepJobProperties
 
SingleTaskConfiguration - Class in org.springframework.cloud.task.configuration
Autoconfiguration of SingleInstanceTaskListener.
SingleTaskConfiguration() - Constructor for class org.springframework.cloud.task.configuration.SingleTaskConfiguration
 
SKIP_EVENTS_LISTENER - Static variable in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration
Name of the skip events listener bean.
skipEventsListener(MessagePublisher, TaskEventProperties) - Method in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration.JobExecutionListenerConfiguration
 
SPRING_CLOUD_TASK_EXECUTION_ID - Static variable in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
ID of the Spring Cloud Task execution.
SPRING_CLOUD_TASK_JOB_EXECUTION_ID - Static variable in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
ID of Spring Cloud Task job execution.
SPRING_CLOUD_TASK_NAME - Static variable in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
Spring Cloud Task name property.
SPRING_CLOUD_TASK_PARENT_EXECUTION_ID - Static variable in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
ID of Spring Cloud Task parent execution.
SPRING_CLOUD_TASK_STEP_EXECUTION_ID - Static variable in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
ID of Spring Cloud Task step execution.
SPRING_CLOUD_TASK_STEP_NAME - Static variable in class org.springframework.cloud.task.batch.partition.DeployerPartitionHandler
Name of Spring Cloud Task step.
springCloudTaskTransactionManager() - Method in class org.springframework.cloud.task.configuration.SimpleTaskAutoConfiguration
 
springDataSourceProperties() - Method in class io.spring.configuration.ExternalDataSourceConfiguration
 
SqlPagingQueryProviderFactoryBean - Class in org.springframework.cloud.task.repository.database.support
Factory bean for PagingQueryProvider interface.
SqlPagingQueryProviderFactoryBean() - Constructor for class org.springframework.cloud.task.repository.database.support.SqlPagingQueryProviderFactoryBean
 
SqlPagingQueryUtils - Class in org.springframework.cloud.task.repository.database.support
Utility class that generates the actual SQL statements used by query providers.
SQLSERVER - Enum constant in enum class org.springframework.cloud.task.repository.support.DatabaseType
Microsoft SQL Server DB.
SqlServerPagingQueryProvider - Class in org.springframework.cloud.task.repository.database.support
Sql Server implementation of a PagingQueryProvider using database specific features.
SqlServerPagingQueryProvider() - Constructor for class org.springframework.cloud.task.repository.database.support.SqlServerPagingQueryProvider
 
start() - Method in class org.springframework.cloud.task.listener.TaskLifecycleListener
 
startTaskExecution(long, String, LocalDateTime, List<String>, String) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
startTaskExecution(long, String, LocalDateTime, List<String>, String) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
startTaskExecution(long, String, LocalDateTime, List<String>, String) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Update and existing TaskExecution to mark it as started.
startTaskExecution(long, String, LocalDateTime, List<String>, String) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
startTaskExecution(long, String, LocalDateTime, List<String>, String) - Method in interface org.springframework.cloud.task.repository.TaskRepository
Notifies the repository that a taskExecution has has started.
startTaskExecution(long, String, LocalDateTime, List<String>, String, Long) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
startTaskExecution(long, String, LocalDateTime, List<String>, String, Long) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
startTaskExecution(long, String, LocalDateTime, List<String>, String, Long) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Update and existing TaskExecution to mark it as started.
startTaskExecution(long, String, LocalDateTime, List<String>, String, Long) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
startTaskExecution(long, String, LocalDateTime, List<String>, String, Long) - Method in interface org.springframework.cloud.task.repository.TaskRepository
Notifies the repository that a taskExecution has has started.
STATUS_FAILURE - Static variable in class org.springframework.cloud.task.listener.TaskObservations
Failing task execution status indicator.
STATUS_SUCCESS - Static variable in class org.springframework.cloud.task.listener.TaskObservations
Successful task execution status indicator.
STEP_EXECUTION_EVENTS_LISTENER - Static variable in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration
Name of the step execution events listener bean.
step1() - Method in class io.spring.cloud.BatchEventsApplication.JobConfiguration
 
step1(PartitionHandler) - Method in class io.spring.JobConfiguration
 
step2() - Method in class io.spring.cloud.BatchEventsApplication.JobConfiguration
 
StepExecutionEvent - Class in org.springframework.cloud.task.batch.listener.support
This is a StepExecution DTO created so that a StepExecution can be serialized into Json without having to add mixins to an ObjectMapper.
StepExecutionEvent() - Constructor for class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
StepExecutionEvent(StepExecution) - Constructor for class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
Constructor for the StepExecution to initialize the DTO.
stepExecutionEventsListener(MessagePublisher, TaskEventProperties) - Method in class org.springframework.cloud.task.batch.listener.BatchEventAutoConfiguration.JobExecutionListenerConfiguration
 
stepExecutionHandler(JobExplorer) - Method in class io.spring.JobConfiguration
 
stop() - Method in class org.springframework.cloud.task.listener.TaskLifecycleListener
 
stop(Runnable) - Method in class org.springframework.cloud.task.listener.TaskLifecycleListener
 
supportsContext(Observation.Context) - Method in interface org.springframework.cloud.task.configuration.observation.TaskObservationConvention
 
supportsContext(Observation.Context) - Method in interface org.springframework.cloud.task.listener.TaskExecutionObservationConvention
 

T

TASK_ACTIVE - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation
Metrics created around a task execution.
TASK_CF_APP_ID - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
App id for CF cloud.
TASK_CF_APP_NAME - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
App name for CF cloud.
TASK_CF_APP_VERSION - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
App version for CF cloud.
TASK_CF_INSTANCE_INDEX - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
Instance index for CF cloud.
TASK_CF_ORG_NAME - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
Organization Name for CF cloud.
TASK_CF_SPACE_ID - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
Space id for CF cloud.
TASK_CF_SPACE_NAME - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
Space name for CF cloud.
TASK_EXECUTION_ID - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
Task execution id.
TASK_EXIT_CODE - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
Task exit code.
TASK_EXTERNAL_EXECUTION_ID - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
External execution id for task.
TASK_NAME - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
Task name measurement.
TASK_NAME_WHERE_CLAUSE - Static variable in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
WHERE clause for task name.
TASK_PARENT_EXECUTION_ID - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
Task parent execution id.
TASK_STATUS - Enum constant in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
task status.
TaskApplication - Class in org.springframework.cloud.task.timestamp
Spring Boot Application that has tasks enabled.
TaskApplication() - Constructor for class org.springframework.cloud.task.timestamp.TaskApplication
 
TaskApplication.TimestampTask - Class in org.springframework.cloud.task.timestamp
A commandline runner that prints a timestamp.
TaskBatchAutoConfiguration - Class in org.springframework.cloud.task.batch.configuration
Provides auto configuration for the TaskBatchExecutionListener.
TaskBatchAutoConfiguration() - Constructor for class org.springframework.cloud.task.batch.configuration.TaskBatchAutoConfiguration
 
TaskBatchAutoConfiguration.TaskBatchExecutionListenerAutoconfiguration - Class in org.springframework.cloud.task.batch.configuration
Auto configuration for TaskBatchExecutionListener.
TaskBatchDao - Interface in org.springframework.cloud.task.batch.listener
Maintains the association between a TaskExecution and a JobExecution executed within it.
TaskBatchEventListenerBeanPostProcessor - Class in org.springframework.cloud.task.batch.listener.support
Attaches the listeners to the job and its steps.
TaskBatchEventListenerBeanPostProcessor() - Constructor for class org.springframework.cloud.task.batch.listener.support.TaskBatchEventListenerBeanPostProcessor
 
taskBatchExecutionListener(TaskExplorer) - Method in class org.springframework.cloud.task.batch.configuration.TaskBatchAutoConfiguration.TaskBatchExecutionListenerAutoconfiguration
 
TaskBatchExecutionListener - Class in org.springframework.cloud.task.batch.listener
Responsible for storing the relationship between a Spring Batch job and the Spring Cloud task it was executed within.
TaskBatchExecutionListener(TaskBatchDao) - Constructor for class org.springframework.cloud.task.batch.listener.TaskBatchExecutionListener
 
TaskBatchExecutionListenerAutoconfiguration() - Constructor for class org.springframework.cloud.task.batch.configuration.TaskBatchAutoConfiguration.TaskBatchExecutionListenerAutoconfiguration
 
TaskBatchExecutionListenerBeanPostProcessor - Class in org.springframework.cloud.task.batch.configuration
Injects a configured TaskBatchExecutionListener into any batch jobs (beans assignable to AbstractJob) that are executed within the scope of a task.
TaskBatchExecutionListenerBeanPostProcessor() - Constructor for class org.springframework.cloud.task.batch.configuration.TaskBatchExecutionListenerBeanPostProcessor
 
TaskBatchExecutionListenerFactoryBean - Class in org.springframework.cloud.task.batch.configuration
FactoryBean for a TaskBatchExecutionListener.
TaskBatchExecutionListenerFactoryBean(DataSource, TaskExplorer) - Constructor for class org.springframework.cloud.task.batch.configuration.TaskBatchExecutionListenerFactoryBean
Initializes the TaskBatchExecutionListenerFactoryBean and defaults the tablePrefix to TaskProperties.DEFAULT_TABLE_PREFIX.
TaskBatchExecutionListenerFactoryBean(DataSource, TaskExplorer, String) - Constructor for class org.springframework.cloud.task.batch.configuration.TaskBatchExecutionListenerFactoryBean
Initializes the TaskBatchExecutionListenerFactoryBean.
TaskBatchProperties - Class in org.springframework.cloud.task.batch.configuration
Establish properties to be used for how Tasks work with Spring Batch.
TaskBatchProperties() - Constructor for class org.springframework.cloud.task.batch.configuration.TaskBatchProperties
 
TaskConfiguration() - Constructor for class io.spring.TaskEventsApplication.TaskConfiguration
 
TaskConfigurer - Interface in org.springframework.cloud.task.configuration
Provides a strategy interface for providing configuration customization to the task system.
TaskEventAutoConfiguration - Class in org.springframework.cloud.task.listener
 
TaskEventAutoConfiguration() - Constructor for class org.springframework.cloud.task.listener.TaskEventAutoConfiguration
 
TaskEventAutoConfiguration.ListenerConfiguration - Class in org.springframework.cloud.task.listener
Configuration for a TaskExecutionListener.
taskEventEmitter(StreamBridge, TaskEventProperties) - Method in class org.springframework.cloud.task.listener.TaskEventAutoConfiguration.ListenerConfiguration
 
TaskEventProperties - Class in org.springframework.cloud.task.batch.listener.support
 
TaskEventProperties() - Constructor for class org.springframework.cloud.task.batch.listener.support.TaskEventProperties
 
TaskEventsApplication - Class in io.spring
 
TaskEventsApplication() - Constructor for class io.spring.TaskEventsApplication
 
TaskEventsApplication.TaskConfiguration - Class in io.spring
 
TaskException - Exception in org.springframework.cloud.task.listener
Base Exception for any Task issues.
TaskException(String) - Constructor for exception org.springframework.cloud.task.listener.TaskException
 
TaskException(String, Throwable) - Constructor for exception org.springframework.cloud.task.listener.TaskException
 
TaskExecution - Class in org.springframework.cloud.task.repository
Represents the state of the Task for each execution.
TaskExecution() - Constructor for class org.springframework.cloud.task.repository.TaskExecution
 
TaskExecution(long, Integer, String, LocalDateTime, LocalDateTime, String, List<String>, String, String) - Constructor for class org.springframework.cloud.task.repository.TaskExecution
 
TaskExecution(long, Integer, String, LocalDateTime, LocalDateTime, String, List<String>, String, String, Long) - Constructor for class org.springframework.cloud.task.repository.TaskExecution
 
TaskExecutionDao - Interface in org.springframework.cloud.task.repository.dao
Data Access Object for task executions.
TaskExecutionDaoFactoryBean - Class in org.springframework.cloud.task.repository.support
A FactoryBean implementation that creates the appropriate TaskExecutionDao based on the provided information.
TaskExecutionDaoFactoryBean() - Constructor for class org.springframework.cloud.task.repository.support.TaskExecutionDaoFactoryBean
Default constructor will result in a Map based TaskExecutionDao.
TaskExecutionDaoFactoryBean(DataSource) - Constructor for class org.springframework.cloud.task.repository.support.TaskExecutionDaoFactoryBean
DataSource to be used.
TaskExecutionDaoFactoryBean(DataSource, String) - Constructor for class org.springframework.cloud.task.repository.support.TaskExecutionDaoFactoryBean
DataSource to be used.
TaskExecutionException - Exception in org.springframework.cloud.task.listener
Is thrown when executing a task.
TaskExecutionException(String) - Constructor for exception org.springframework.cloud.task.listener.TaskExecutionException
 
TaskExecutionException(String, Throwable) - Constructor for exception org.springframework.cloud.task.listener.TaskExecutionException
 
TaskExecutionListener - Interface in org.springframework.cloud.task.listener
The listener interface for receiving task execution events.
TaskExecutionListenerSupport - Class in org.springframework.cloud.task.listener
Deprecated.
since 3.0 in favor of the default implementations of TaskExecutionListener
TaskExecutionListenerSupport() - Constructor for class org.springframework.cloud.task.listener.TaskExecutionListenerSupport
Deprecated.
 
TaskExecutionObservation - Enum Class in org.springframework.cloud.task.listener
Enumeration for task execution observations.
TaskExecutionObservation.TaskKeyValues - Enum Class in org.springframework.cloud.task.listener
 
TaskExecutionObservationContext - Class in org.springframework.cloud.task.listener
A mutable holder of the TaskExecution required by a ObservationHandler.
TaskExecutionObservationContext(TaskExecution) - Constructor for class org.springframework.cloud.task.listener.TaskExecutionObservationContext
 
TaskExecutionObservationConvention - Interface in org.springframework.cloud.task.listener
ObservationConvention for TaskExecutionObservationContext.
taskExplorer() - Method in class org.springframework.cloud.task.configuration.SimpleTaskAutoConfiguration
 
TaskExplorer - Interface in org.springframework.cloud.task.repository
Offers methods that allow users to query the task executions that are available.
taskJobLauncherApplicationRunner(JobLauncher, JobExplorer, List<Job>, JobRegistry, JobRepository, BatchProperties) - Method in class org.springframework.cloud.task.batch.configuration.TaskJobLauncherAutoConfiguration
 
TaskJobLauncherApplicationRunner - Class in org.springframework.cloud.task.batch.handler
ApplicationRunner to launch Spring Batch jobs.
TaskJobLauncherApplicationRunner(JobLauncher, JobExplorer, JobRepository, TaskBatchProperties) - Constructor for class org.springframework.cloud.task.batch.handler.TaskJobLauncherApplicationRunner
TaskJobLauncherApplicationRunnerFactoryBean - Class in org.springframework.cloud.task.batch.configuration
Factory bean for creating an instance of TaskJobLauncherApplicationRunner.
TaskJobLauncherApplicationRunnerFactoryBean(JobLauncher, JobExplorer, List<Job>, TaskBatchProperties, JobRegistry, JobRepository, BatchProperties) - Constructor for class org.springframework.cloud.task.batch.configuration.TaskJobLauncherApplicationRunnerFactoryBean
 
TaskJobLauncherAutoConfiguration - Class in org.springframework.cloud.task.batch.configuration
Provides auto configuration for the TaskJobLauncherApplicationRunner.
TaskJobLauncherAutoConfiguration() - Constructor for class org.springframework.cloud.task.batch.configuration.TaskJobLauncherAutoConfiguration
 
taskLauncher - Variable in class org.springframework.cloud.task.launcher.TaskLauncherSink
 
TaskLauncherHandler - Class in org.springframework.cloud.task.batch.partition
Supports the launching of partitions.
TaskLauncherHandler(CommandLineArgsProvider, TaskRepository, boolean, String, TaskExecution, EnvironmentVariablesProvider, Resource, Map<String, String>, TaskLauncher, String) - Constructor for class org.springframework.cloud.task.batch.partition.TaskLauncherHandler
 
TaskLauncherHandler(CommandLineArgsProvider, TaskRepository, boolean, String, TaskExecution, EnvironmentVariablesProvider, Resource, Map<String, String>, TaskLauncher, String, StepExecution) - Constructor for class org.springframework.cloud.task.batch.partition.TaskLauncherHandler
 
taskLauncherSink() - Method in class org.springframework.cloud.task.launcher.TaskLauncherSink
Launches a task upon the receipt of a valid TaskLaunchRequest.
TaskLauncherSink - Class in org.springframework.cloud.task.launcher
A sink stream application that launches a tasks.
TaskLauncherSink() - Constructor for class org.springframework.cloud.task.launcher.TaskLauncherSink
 
TaskLaunchRequest - Class in org.springframework.cloud.task.launcher
Request that contains the maven repository and property information required by the TaskLauncherSink to launch the task.
TaskLaunchRequest() - Constructor for class org.springframework.cloud.task.launcher.TaskLaunchRequest
Constructor for the TaskLaunchRequest.
TaskLaunchRequest(String, List<String>, Map<String, String>, Map<String, String>, String) - Constructor for class org.springframework.cloud.task.launcher.TaskLaunchRequest
Constructor for the TaskLaunchRequest.
TaskLifecycleConfiguration - Class in org.springframework.cloud.task.configuration
Configuration for a TaskLifecycleListener.
TaskLifecycleConfiguration(TaskProperties, ConfigurableApplicationContext, TaskRepository, TaskExplorer, TaskNameResolver, ObjectProvider<ApplicationArguments>, ObservationRegistry, TaskObservationCloudKeyValues) - Constructor for class org.springframework.cloud.task.configuration.TaskLifecycleConfiguration
 
taskLifecycleListener() - Method in class org.springframework.cloud.task.configuration.TaskLifecycleConfiguration
 
TaskLifecycleListener - Class in org.springframework.cloud.task.listener
Monitors the lifecycle of a task.
TaskLifecycleListener(TaskRepository, TaskNameResolver, ApplicationArguments, TaskExplorer, TaskProperties, TaskListenerExecutorObjectFactory, ObservationRegistry, TaskObservationCloudKeyValues) - Constructor for class org.springframework.cloud.task.listener.TaskLifecycleListener
 
taskListener(TaskNameResolver, ApplicationContext) - Method in class org.springframework.cloud.task.configuration.SingleTaskConfiguration
 
TaskListenerExecutor - Class in org.springframework.cloud.task.listener.annotation
Identifies all beans that contain a TaskExecutionListener annotation and stores the associated method so that it can be called by the TaskExecutionListener at the appropriate time.
TaskListenerExecutor(Map<Method, Set<Object>>, Map<Method, Set<Object>>, Map<Method, Set<Object>>) - Constructor for class org.springframework.cloud.task.listener.annotation.TaskListenerExecutor
 
TaskListenerExecutorObjectFactory - Class in org.springframework.cloud.task.listener
Initializes TaskListenerExecutor for a task.
TaskListenerExecutorObjectFactory(ConfigurableApplicationContext) - Constructor for class org.springframework.cloud.task.listener.TaskListenerExecutorObjectFactory
 
taskNameResolver() - Method in class org.springframework.cloud.task.configuration.SimpleTaskAutoConfiguration
 
TaskNameResolver - Interface in org.springframework.cloud.task.repository
Strategy interface for customizing how the name of a task is determined.
TaskObservationCloudKeyValues - Class in org.springframework.cloud.task.configuration
Provides values for the KeyValues for the task Observation when the cloud profile is active.
TaskObservationCloudKeyValues() - Constructor for class org.springframework.cloud.task.configuration.TaskObservationCloudKeyValues
 
TaskObservationContext - Class in org.springframework.cloud.task.configuration.observation
Observation.Context for Spring Cloud Task.
TaskObservationContext(String) - Constructor for class org.springframework.cloud.task.configuration.observation.TaskObservationContext
 
TaskObservationConvention - Interface in org.springframework.cloud.task.configuration.observation
ObservationConvention for Spring Cloud Task.
TaskObservations - Class in org.springframework.cloud.task.listener
Utility class for publishing Spring Cloud Task specific Observations via Micrometer.
TaskObservations(ObservationRegistry, TaskObservationCloudKeyValues, ObservationConvention) - Constructor for class org.springframework.cloud.task.listener.TaskObservations
 
TaskObservationsApplication - Class in io.spring.taskobservations
 
TaskObservationsApplication() - Constructor for class io.spring.taskobservations.TaskObservationsApplication
 
TaskProcessor - Class in io.spring
A processor that takes the maven repository coordinates and datasource configuration for a task and sends a TaskLaunchRequest message to a task sink.
TaskProcessor() - Constructor for class io.spring.TaskProcessor
 
TaskProcessorApplication - Class in io.spring
 
TaskProcessorApplication() - Constructor for class io.spring.TaskProcessorApplication
 
TaskProcessorProperties - Class in io.spring
 
TaskProcessorProperties() - Constructor for class io.spring.TaskProcessorProperties
 
TaskProperties - Class in org.springframework.cloud.task.configuration
Properties available to configure the task.
TaskProperties() - Constructor for class org.springframework.cloud.task.configuration.TaskProperties
 
taskRepository() - Method in class org.springframework.cloud.task.configuration.SimpleTaskAutoConfiguration
 
TaskRepository - Interface in org.springframework.cloud.task.repository
TaskRepository interface offers methods that create and update task execution information.
taskRepositoryInitializer() - Method in class org.springframework.cloud.task.configuration.SimpleTaskAutoConfiguration
 
TaskRepositoryInitializer - Class in org.springframework.cloud.task.repository.support
Utility for initializing the Task Repository's datasource.
TaskRepositoryInitializer(TaskProperties) - Constructor for class org.springframework.cloud.task.repository.support.TaskRepositoryInitializer
 
TaskRunComponent - Class in io.spring.configuration
Records an entry in the TASK_RUN_OUTPUT table on the BeforeTask event.
TaskRunComponent() - Constructor for class io.spring.configuration.TaskRunComponent
 
TaskRunOutput - Class in io.spring.configuration
Entity for the id and output to be written to the data store.
TaskRunOutput() - Constructor for class io.spring.configuration.TaskRunOutput
 
TaskRunOutput(String) - Constructor for class io.spring.configuration.TaskRunOutput
 
TaskRunRepository - Interface in io.spring.configuration
 
TaskRuntimeHints - Class in org.springframework.cloud.task.configuration
Native Hints for Spring Cloud Task.
TaskRuntimeHints() - Constructor for class org.springframework.cloud.task.configuration.TaskRuntimeHints
 
TaskSinkApplication - Class in io.spring
A task sink sample application for launching tasks.
TaskSinkApplication() - Constructor for class io.spring.TaskSinkApplication
 
threadPoolTaskExecutor() - Method in class io.spring.JobConfiguration
 
timeStampTask() - Method in class org.springframework.cloud.task.timestamp.TaskApplication
 
TimestampTask() - Constructor for class org.springframework.cloud.task.timestamp.TaskApplication.TimestampTask
 
TimestampTaskProperties - Class in org.springframework.cloud.task.timestamp
 
TimestampTaskProperties() - Constructor for class org.springframework.cloud.task.timestamp.TimestampTaskProperties
 
toProperties() - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
 
toString() - Method in class io.spring.configuration.TaskRunOutput
 
toString() - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
 
toString() - Method in class org.springframework.cloud.task.batch.listener.support.JobInstanceEvent
 
toString() - Method in class org.springframework.cloud.task.batch.listener.support.JobParameterEvent
 
toString() - Method in class org.springframework.cloud.task.batch.listener.support.JobParametersEvent
 
toString() - Method in class org.springframework.cloud.task.batch.listener.support.StepExecutionEvent
 
toString() - Method in class org.springframework.cloud.task.launcher.TaskLaunchRequest
 
toString() - Method in class org.springframework.cloud.task.repository.TaskExecution
 
transactionManager - Variable in class io.spring.configuration.JobConfiguration
 

U

UNKNOWN - Static variable in class org.springframework.cloud.task.listener.TaskObservations
Default for when value is not present.
unlockTaskOnEnd(TaskExecution) - Method in class org.springframework.cloud.task.configuration.SingleInstanceTaskListener
 
unlockTaskOnError(TaskExecution, Throwable) - Method in class org.springframework.cloud.task.configuration.SingleInstanceTaskListener
 
updateExternalExecutionId(long, String) - Method in class org.springframework.cloud.task.repository.dao.JdbcTaskExecutionDao
 
updateExternalExecutionId(long, String) - Method in class org.springframework.cloud.task.repository.dao.MapTaskExecutionDao
 
updateExternalExecutionId(long, String) - Method in interface org.springframework.cloud.task.repository.dao.TaskExecutionDao
Updates the externalExecutionId for the execution id specified.
updateExternalExecutionId(long, String) - Method in class org.springframework.cloud.task.repository.support.SimpleTaskRepository
 
updateExternalExecutionId(long, String) - Method in interface org.springframework.cloud.task.repository.TaskRepository
Notifies the repository to update the taskExecution's externalExecutionId.
upgradeStatus(BatchStatus) - Method in class org.springframework.cloud.task.batch.listener.support.JobExecutionEvent
Upgrade the status field if the provided value is greater than the existing one.

V

valueOf(String) - Static method in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.springframework.cloud.task.listener.TaskExecutionObservation
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.springframework.cloud.task.repository.support.DatabaseType
Returns the enum constant of this class with the specified name.
values() - Static method in enum class org.springframework.cloud.task.listener.TaskExecutionObservation.TaskKeyValues
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.springframework.cloud.task.listener.TaskExecutionObservation
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.springframework.cloud.task.repository.support.DatabaseType
Returns an array containing the constants of this enum class, in the order they are declared.

W

workerStep() - Method in class io.spring.JobConfiguration
 
workerTasklet(Integer) - Method in class io.spring.JobConfiguration
 
writerDataSource(DataSourceProperties) - Method in class org.springframework.cloud.task.batch.autoconfigure.jdbc.JdbcBatchItemWriterAutoConfiguration
 
A B C D E F G H I J K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form