A B C D E F G H I J L M N O P Q R S T U V W Y Z _ 
All Classes All Packages

A

AAStoreInstruction - Class in org.jobrunr.jobs.details.instructions
 
AAStoreInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.AAStoreInstruction
 
AbstractAllowedConcurrentStateChange - Class in org.jobrunr.server.concurrent.statechanges
 
AbstractAllowedConcurrentStateChange(StateName, StateName) - Constructor for class org.jobrunr.server.concurrent.statechanges.AbstractAllowedConcurrentStateChange
 
AbstractBackgroundJobRunner - Class in org.jobrunr.server.runner
 
AbstractBackgroundJobRunner() - Constructor for class org.jobrunr.server.runner.AbstractBackgroundJobRunner
 
AbstractBackgroundJobRunner.BackgroundJobWorker - Class in org.jobrunr.server.runner
 
AbstractJob - Class in org.jobrunr.jobs
 
AbstractJob() - Constructor for class org.jobrunr.jobs.AbstractJob
 
AbstractJob(JobDetails) - Constructor for class org.jobrunr.jobs.AbstractJob
 
AbstractJob(JobDetails, int) - Constructor for class org.jobrunr.jobs.AbstractJob
 
AbstractJobState - Class in org.jobrunr.jobs.states
 
AbstractJobState(StateName) - Constructor for class org.jobrunr.jobs.states.AbstractJobState
 
AbstractJVMInstruction - Class in org.jobrunr.jobs.details.instructions
 
AbstractJVMInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.AbstractJVMInstruction
 
AbstractObjectSseExchange - Class in org.jobrunr.dashboard.sse
 
AbstractObjectSseExchange(HttpExchange, JsonMapper) - Constructor for class org.jobrunr.dashboard.sse.AbstractObjectSseExchange
 
AbstractStorageProvider - Class in org.jobrunr.storage
 
AbstractStorageProvider(RateLimiter) - Constructor for class org.jobrunr.storage.AbstractStorageProvider
 
AbstractTeenyHttpHandler - Class in org.jobrunr.dashboard.server
 
AbstractTeenyHttpHandler() - Constructor for class org.jobrunr.dashboard.server.AbstractTeenyHttpHandler
 
accept(S) - Method in interface org.jobrunr.jobs.lambdas.IocJobLambda
 
accept(S, T) - Method in interface org.jobrunr.jobs.lambdas.IocJobLambdaFromStream
 
accept(T) - Method in interface org.jobrunr.jobs.lambdas.JobLambdaFromStream
 
accept(T) - Method in interface org.jobrunr.utils.exceptions.Exceptions.ThrowingConsumer
 
accept(T, U) - Method in interface org.jobrunr.utils.exceptions.Exceptions.ThrowingBiConsumer
 
activateJob(Class<T>) - Method in interface org.jobrunr.server.JobActivator
 
adaptFromJson(JsonArray) - Method in class org.jobrunr.utils.mapper.jsonb.adapters.JobHistoryAdapter
 
adaptFromJson(JsonObject) - Method in class org.jobrunr.utils.mapper.jsonb.adapters.JobDetailsAdapter
 
adaptFromJson(JsonObject) - Method in class org.jobrunr.utils.mapper.jsonb.adapters.JobMetadataAdapter
 
adaptFromJson(JsonObject) - Method in class org.jobrunr.utils.mapper.jsonb.JobAdapter
 
adaptFromJson(JsonObject) - Method in class org.jobrunr.utils.mapper.jsonb.RecurringJobAdapter
 
adaptToJson(List<JobState>) - Method in class org.jobrunr.utils.mapper.jsonb.adapters.JobHistoryAdapter
 
adaptToJson(Map<String, Object>) - Method in class org.jobrunr.utils.mapper.jsonb.adapters.JobMetadataAdapter
 
adaptToJson(Job) - Method in class org.jobrunr.utils.mapper.jsonb.JobAdapter
 
adaptToJson(JobDetails) - Method in class org.jobrunr.utils.mapper.jsonb.adapters.JobDetailsAdapter
 
adaptToJson(RecurringJob) - Method in class org.jobrunr.utils.mapper.jsonb.RecurringJobAdapter
 
add(String, boolean) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(String, double) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(String, int) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(String, long) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(String, Long) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(String, String) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(String, BigDecimal) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(String, BigInteger) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(String, UUID) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(String, JsonArrayBuilder) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(String, JsonObjectBuilder) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(String, JsonValue) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
add(JobDashboardLogger.JobDashboardLogLine) - Method in class org.jobrunr.jobs.context.JobDashboardLogger.JobDashboardLogLines
 
addJobState(JobState) - Method in class org.jobrunr.jobs.Job
 
addJobStorageOnChangeListener(StorageProviderChangeListener) - Method in class org.jobrunr.storage.AbstractStorageProvider
 
addJobStorageOnChangeListener(StorageProviderChangeListener) - Method in interface org.jobrunr.storage.StorageProvider
 
addJobStorageOnChangeListener(StorageProviderChangeListener) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
addLocalVariable(Object) - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
addNull(String) - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
AllJVMInstructions - Class in org.jobrunr.jobs.details.instructions
 
allMatch(Predicate<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
allMatch(Predicate<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
AllowedConcurrentStateChange - Interface in org.jobrunr.server.concurrent.statechanges
 
ALoadOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
ALoadOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.ALoadOperandInstruction
 
andPollIntervalInSeconds(int) - Method in class org.jobrunr.server.BackgroundJobServerConfiguration
Allows to set the pollIntervalInSeconds for the BackgroundJobServer
andPort(int) - Method in class org.jobrunr.dashboard.JobRunrDashboardWebServerConfiguration
Specifies the port on which the JobRunrDashboard will run
andWorkerCount(int) - Method in class org.jobrunr.server.BackgroundJobServerConfiguration
Allows to set the workerCount for the BackgroundJobServer which defines the maximum number of jobs that will be run in parallel
andWorkerCountPolicy(BackgroundJobServerWorkerPolicy) - Method in class org.jobrunr.server.BackgroundJobServerConfiguration
 
ANewArrayOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
ANewArrayOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.ANewArrayOperandInstruction
 
announce(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
announceBackgroundJobServer(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
announceBackgroundJobServer(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
announceBackgroundJobServer(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
announceBackgroundJobServer(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
announceBackgroundJobServer(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
announceBackgroundJobServer(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
announceBackgroundJobServer(BackgroundJobServerStatus) - Method in interface org.jobrunr.storage.StorageProvider
 
announceBackgroundJobServer(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
AnsiDialect - Class in org.jobrunr.storage.sql.common.db.dialect
 
AnsiDialect() - Constructor for class org.jobrunr.storage.sql.common.db.dialect.AnsiDialect
 
anyMatch(Predicate<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
anyMatch(Predicate<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
APPLICATION_JSON - Static variable in class org.jobrunr.dashboard.server.http.ContentType
 
APPLICATION_OCTET_STREAM - Static variable in class org.jobrunr.dashboard.server.http.ContentType
 
apply(T) - Method in interface org.jobrunr.utils.exceptions.Exceptions.ThrowingFunction
 
apply(T, U) - Method in interface org.jobrunr.utils.exceptions.Exceptions.ThrowingBiFunction
 
ApplyStateFilter - Interface in org.jobrunr.jobs.filters
A filter that is triggered each time that the state of a Job has changed.
areNewJobs(List<Job>) - Static method in class org.jobrunr.storage.StorageProviderUtils
 
asBigDecimal(String) - Method in class org.jobrunr.storage.sql.common.db.SqlResultSet
 
asBoolean(String) - Method in class org.jobrunr.storage.sql.common.db.SqlResultSet
 
ASC - org.jobrunr.storage.PageRequest.Order
 
ascOnUpdatedAt(int) - Static method in class org.jobrunr.storage.PageRequest
 
ascOnUpdatedAt(long, int) - Static method in class org.jobrunr.storage.PageRequest
 
asDouble(String) - Method in class org.jobrunr.storage.sql.common.db.SqlResultSet
 
asFloat(String) - Method in class org.jobrunr.storage.sql.common.db.SqlResultSet
 
asInstant(String) - Method in class org.jobrunr.storage.sql.common.db.SqlResultSet
 
asInt(String) - Method in class org.jobrunr.storage.sql.common.db.SqlResultSet
 
asJson(Object) - Method in class org.jobrunr.dashboard.server.http.HttpResponse
 
asLong(String) - Method in class org.jobrunr.storage.sql.common.db.SqlResultSet
 
assertJobExists(JobDetails) - Static method in class org.jobrunr.utils.JobUtils
 
asString(String) - Method in class org.jobrunr.storage.sql.common.db.SqlResultSet
 
AStoreInstruction - Class in org.jobrunr.jobs.details.instructions
 
AStoreInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.AStoreInstruction
 
asUUID() - Method in class org.jobrunr.jobs.JobId
 
asUUID(String) - Method in class org.jobrunr.storage.sql.common.db.SqlResultSet
 
at10Requests() - Method in class org.jobrunr.utils.resilience.RateLimiter.Builder
 
at1Request() - Method in class org.jobrunr.utils.resilience.RateLimiter.Builder
 
at2Requests() - Method in class org.jobrunr.utils.resilience.RateLimiter.Builder
 
at5Requests() - Method in class org.jobrunr.utils.resilience.RateLimiter.Builder
 
atRequests(int) - Method in class org.jobrunr.utils.resilience.RateLimiter.Builder
 
autobox(Object, Class<Boolean>) - Method in class org.jobrunr.utils.reflection.autobox.BooleanTypeAutoboxer
 
autobox(Object, Class<Double>) - Method in class org.jobrunr.utils.reflection.autobox.DoubleTypeAutoboxer
 
autobox(Object, Class<Enum>) - Method in class org.jobrunr.utils.reflection.autobox.EnumAutoboxer
 
autobox(Object, Class<Float>) - Method in class org.jobrunr.utils.reflection.autobox.FloatTypeAutoboxer
 
autobox(Object, Class<Integer>) - Method in class org.jobrunr.utils.reflection.autobox.IntegerTypeAutoboxer
 
autobox(Object, Class<Long>) - Method in class org.jobrunr.utils.reflection.autobox.LongTypeAutoboxer
 
autobox(Object, Class<String>) - Method in class org.jobrunr.utils.reflection.autobox.StringTypeAutoboxer
 
autobox(Object, Class<Instant>) - Method in class org.jobrunr.utils.reflection.autobox.InstantForOracleTypeAutoboxer
 
autobox(Object, Class<Instant>) - Method in class org.jobrunr.utils.reflection.autobox.InstantTypeAutoboxer
 
autobox(Object, Class<UUID>) - Method in class org.jobrunr.utils.reflection.autobox.UUIDTypeAutoboxer
 
autobox(Object, Class<T>) - Static method in class org.jobrunr.utils.reflection.autobox.Autoboxer
 
autobox(Object, Class<T>) - Method in interface org.jobrunr.utils.reflection.autobox.TypeAutoboxer
 
autobox(Object, Class<T>) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
Autoboxer - Class in org.jobrunr.utils.reflection.autobox
 
AWAITING - org.jobrunr.jobs.states.StateName
 

B

BACKGROUND_JOB_SERVERS_KEY - Static variable in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
BACKGROUND_JOB_SERVERS_KEY - Static variable in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
BackgroundJob - Class in org.jobrunr.scheduling
Provides static methods for creating fire-and-forget, delayed and recurring jobs as well as to delete existing background jobs.
BackgroundJobPerformer - Class in org.jobrunr.server
 
BackgroundJobPerformer(BackgroundJobServer, Job) - Constructor for class org.jobrunr.server.BackgroundJobPerformer
 
BackgroundJobRunner - Interface in org.jobrunr.server.runner
 
BackgroundJobServer - Class in org.jobrunr.server
 
BackgroundJobServer(StorageProvider) - Constructor for class org.jobrunr.server.BackgroundJobServer
 
BackgroundJobServer(StorageProvider, JobActivator) - Constructor for class org.jobrunr.server.BackgroundJobServer
 
BackgroundJobServer(StorageProvider, JobActivator, BackgroundJobServerConfiguration) - Constructor for class org.jobrunr.server.BackgroundJobServer
 
BackgroundJobServerConfiguration - Class in org.jobrunr.server
This class allows to configure the BackgroundJobServer
backgroundJobServerIndexName() - Static method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchUtils
 
backgroundJobServerKey(String) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
backgroundJobServerKey(UUID) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
backgroundJobServerKey(BackgroundJobServerStatus) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
BackgroundJobServerMBean - Interface in org.jobrunr.server.jmx
 
backgroundJobServersIndex() - Static method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchUtils
 
BackgroundJobServerStatus - Class in org.jobrunr.storage
 
BackgroundJobServerStatus(int, int) - Constructor for class org.jobrunr.storage.BackgroundJobServerStatus
 
BackgroundJobServerStatus(UUID, int, int, Instant, Instant, boolean, Long, Long, Double, Long, Long, Long, Double) - Constructor for class org.jobrunr.storage.BackgroundJobServerStatus
 
BackgroundJobServerStatusChangeListener - Interface in org.jobrunr.storage.listeners
 
BackgroundJobServerStatusDocumentMapper - Class in org.jobrunr.storage.nosql.mongo
 
BackgroundJobServerStatusDocumentMapper() - Constructor for class org.jobrunr.storage.nosql.mongo.BackgroundJobServerStatusDocumentMapper
 
BackgroundJobServerStatusMBean - Interface in org.jobrunr.server.jmx
 
BackgroundJobServerStatusSseExchange - Class in org.jobrunr.dashboard.sse
 
BackgroundJobServerStatusSseExchange(HttpExchange, StorageProvider, JsonMapper) - Constructor for class org.jobrunr.dashboard.sse.BackgroundJobServerStatusSseExchange
 
BackgroundJobServerStatusWriteModel(BackgroundJobServerStatus) - Constructor for class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
backgroundJobServerTable() - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
BackgroundJobServerTable - Class in org.jobrunr.storage.sql.common
 
BackgroundJobServerTable(DataSource) - Constructor for class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
BackgroundJobServerWorkerPolicy - Interface in org.jobrunr.server.configuration
 
BackgroundJobWithIocRunner - Class in org.jobrunr.server.runner
 
BackgroundJobWithIocRunner(JobActivator) - Constructor for class org.jobrunr.server.runner.BackgroundJobWithIocRunner
 
BackgroundJobWithIocRunner.ConsumerBackgroundJobWorker - Class in org.jobrunr.server.runner
 
BackgroundJobWithoutIocRunner - Class in org.jobrunr.server.runner
 
BackgroundJobWithoutIocRunner() - Constructor for class org.jobrunr.server.runner.BackgroundJobWithoutIocRunner
 
BackgroundJobWorker(Job) - Constructor for class org.jobrunr.server.runner.AbstractBackgroundJobRunner.BackgroundJobWorker
 
BackgroundStaticJobWithoutIocRunner - Class in org.jobrunr.server.runner
 
BackgroundStaticJobWithoutIocRunner() - Constructor for class org.jobrunr.server.runner.BackgroundStaticJobWithoutIocRunner
 
BackgroundStaticJobWithoutIocRunner.StaticFieldBackgroundJobWorker - Class in org.jobrunr.server.runner
 
BasicWorkDistributionStrategy - Class in org.jobrunr.server.strategy
 
BasicWorkDistributionStrategy(BackgroundJobServer, JobZooKeeper) - Constructor for class org.jobrunr.server.strategy.BasicWorkDistributionStrategy
 
batchCollector(int, Consumer<List<T>>) - Static method in class org.jobrunr.utils.streams.StreamUtils
Creates a new batch collector
Because - Annotation Type in org.jobrunr.utils.annotations
Documents why a class, field or method is visible
Beta - Annotation Type in org.jobrunr.utils.annotations
Signifies that a public API (public class, method or field) is subject to incompatible changes, or even removal, in a future release.
BooleanTypeAutoboxer - Class in org.jobrunr.utils.reflection.autobox
 
BooleanTypeAutoboxer() - Constructor for class org.jobrunr.utils.reflection.autobox.BooleanTypeAutoboxer
 
build() - Method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
builder() - Static method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
builder() - Static method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
Builder() - Constructor for class org.jobrunr.utils.resilience.RateLimiter.Builder
 
byId(List<UUID>) - Method in class org.jobrunr.storage.nosql.mongo.JobDocumentMapper
 

C

canOnboardNewWork() - Method in class org.jobrunr.server.strategy.BasicWorkDistributionStrategy
 
canOnboardNewWork() - Method in interface org.jobrunr.server.strategy.WorkDistributionStrategy
 
capitalize(String) - Static method in class org.jobrunr.utils.StringUtils
 
cast(Object) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
Why: less warnings and @SuppressWarnings("unchecked")
characteristics() - Method in class org.jobrunr.storage.sql.common.db.SqlSpliterator
 
classExists(String) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
ClassNameObjectTypeAdapter - Class in org.jobrunr.utils.mapper.gson
 
ClassPathUtils - Class in org.jobrunr.utils
 
clearJob() - Static method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
close() - Method in class org.jobrunr.dashboard.server.AbstractTeenyHttpHandler
 
close() - Method in class org.jobrunr.dashboard.server.sse.ServerSentEventHandler
 
close() - Method in class org.jobrunr.dashboard.server.sse.SseExchange
 
close() - Method in interface org.jobrunr.dashboard.server.TeenyHttpHandler
 
close() - Method in class org.jobrunr.dashboard.sse.BackgroundJobServerStatusSseExchange
 
close() - Method in class org.jobrunr.dashboard.sse.JobSseExchange
 
close() - Method in class org.jobrunr.dashboard.sse.JobStatsSseExchange
 
close() - Method in class org.jobrunr.storage.AbstractStorageProvider
 
close() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
close() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
close() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
close() - Method in class org.jobrunr.storage.sql.common.db.SqlSpliterator
 
close() - Method in interface org.jobrunr.storage.StorageProvider
 
close() - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
close() - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
close() - Method in class org.jobrunr.utils.resilience.Lock
 
close() - Method in class org.jobrunr.utils.resilience.MultiLock
 
collect(Supplier<R>, BiConsumer<R, ? super T>, BiConsumer<R, R>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
collect(Supplier<R>, BiConsumer<R, ? super T>, BiConsumer<R, R>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
collect(Collector<? super T, A, R>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
collect(Collector<? super T, A, R>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
COLUMN_FIRST_HEARTBEAT - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_ID - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_LAST_HEARTBEAT - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_POLL_INTERVAL_IN_SECONDS - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_PROCESS_ALLOCATED_MEMORY - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_PROCESS_CPU_LOAD - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_PROCESS_FREE_MEMORY - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_PROCESS_MAX_MEMORY - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_RUNNING - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_SYSTEM_CPU_LOAD - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_SYSTEM_FREE_MEMORY - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_SYSTEM_TOTAL_MEMORY - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
COLUMN_WORKER_POOL_SIZE - Static variable in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
compareTo(CronExpression) - Method in class org.jobrunr.scheduling.cron.CronExpression
Compare two Schedule objects based on next occurrence.
concat(Stream<? extends T1>, Stream<? extends T1>) - Static method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
concat(Stream<? extends T1>, Stream<? extends T1>) - Static method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
concurrentDatabaseModificationException(Object, int) - Static method in exception org.jobrunr.storage.sql.common.db.ConcurrentSqlModificationException
 
concurrentDatabaseModificationException(List<?>, int[]) - Static method in exception org.jobrunr.storage.sql.common.db.ConcurrentSqlModificationException
 
ConcurrentJobModificationException - Exception in org.jobrunr.storage
 
ConcurrentJobModificationException(List<Job>) - Constructor for exception org.jobrunr.storage.ConcurrentJobModificationException
 
ConcurrentJobModificationException(Job) - Constructor for exception org.jobrunr.storage.ConcurrentJobModificationException
 
ConcurrentJobModificationResolver - Class in org.jobrunr.server.concurrent
 
ConcurrentJobModificationResolver(StorageProvider, JobZooKeeper) - Constructor for class org.jobrunr.server.concurrent.ConcurrentJobModificationResolver
 
ConcurrentJobModificationResolveResult - Class in org.jobrunr.server.concurrent
 
ConcurrentSqlModificationException - Exception in org.jobrunr.storage.sql.common.db
 
configurationException(String) - Static method in exception org.jobrunr.JobRunrException
 
configurationException(String, Throwable) - Static method in exception org.jobrunr.JobRunrException
 
configure() - Static method in class org.jobrunr.configuration.JobRunr
 
ConsumerBackgroundJobWorker(JobActivator, Job) - Constructor for class org.jobrunr.server.runner.BackgroundJobWithIocRunner.ConsumerBackgroundJobWorker
 
ContentType - Class in org.jobrunr.dashboard.server.http
 
count() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
count() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
countJobs(StateName) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
countJobs(StateName) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
countJobs(StateName) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
countJobs(StateName) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
countJobs(StateName) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
countJobs(StateName) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
countJobs(StateName) - Method in class org.jobrunr.storage.sql.common.JobTable
 
countJobs(StateName) - Method in interface org.jobrunr.storage.StorageProvider
 
countJobs(StateName) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
countJobs(StateName, int) - Method in class org.jobrunr.storage.sql.common.JobTable
 
create(Gson, TypeToken<R>) - Method in class org.jobrunr.utils.mapper.gson.RuntimeClassNameTypeAdapterFactory
 
create(String) - Static method in class org.jobrunr.scheduling.cron.CronExpression
Parses crontab expression and create a Schedule object representing that expression.
CREATE - org.jobrunr.storage.sql.common.DefaultSqlStorageProvider.DatabaseOptions
 
createContext(TeenyHttpHandler) - Method in class org.jobrunr.dashboard.server.TeenyWebServer
 
createDBIfNecessary() - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
createObjectViaConstructor(String, Class<?>[], Object[]) - Static method in class org.jobrunr.jobs.details.JobDetailsGeneratorUtils
 
createObjectViaMethod(Object, String, Class<?>[], Object[]) - Static method in class org.jobrunr.jobs.details.JobDetailsGeneratorUtils
 
createObjectViaStaticMethod(String, String, Class<?>[], Object[]) - Static method in class org.jobrunr.jobs.details.JobDetailsGeneratorUtils
 
createSseExchange(HttpExchange) - Method in class org.jobrunr.dashboard.JobRunrSseHandler
 
createSseExchange(HttpExchange) - Method in class org.jobrunr.dashboard.server.sse.ServerSentEventHandler
 
Cron - Class in org.jobrunr.scheduling.cron
 
CronExpression - Class in org.jobrunr.scheduling.cron
Schedule class represents a parsed crontab expression.
CronFieldType - Enum in org.jobrunr.scheduling.cron
 

D

daily() - Static method in class org.jobrunr.scheduling.cron.Cron
 
daily(int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
daily(int, int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
DatabaseCreator - Class in org.jobrunr.storage.sql.common
 
DatabaseCreator(DataSource) - Constructor for class org.jobrunr.storage.sql.common.DatabaseCreator
 
DatabaseCreator(DataSource, Class<? extends SqlStorageProvider>) - Constructor for class org.jobrunr.storage.sql.common.DatabaseCreator
 
DatabaseCreator(DatabaseCreator.ConnectionProvider, Class<? extends SqlStorageProvider>) - Constructor for class org.jobrunr.storage.sql.common.DatabaseCreator
 
databaseOptions - Variable in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
dataSource - Variable in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
DAY - org.jobrunr.scheduling.cron.CronFieldType
 
DAY_OF_WEEK - org.jobrunr.scheduling.cron.CronFieldType
 
DB2StorageProvider - Class in org.jobrunr.storage.sql.db2
 
DB2StorageProvider(DataSource) - Constructor for class org.jobrunr.storage.sql.db2.DB2StorageProvider
 
debug(String) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
debug(String, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
debug(String, Object...) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
debug(String, Object, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
debug(String, Throwable) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
debug(Marker, String) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
debug(Marker, String, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
debug(Marker, String, Object...) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
debug(Marker, String, Object, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
debug(Marker, String, Throwable) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
DEFAULT_NBR_OF_RETRIES - Static variable in class org.jobrunr.jobs.filters.RetryFilter
 
DefaultBackgroundJobServerWorkerPolicy - Class in org.jobrunr.server.configuration
 
DefaultBackgroundJobServerWorkerPolicy() - Constructor for class org.jobrunr.server.configuration.DefaultBackgroundJobServerWorkerPolicy
 
DefaultSqlStorageProvider - Class in org.jobrunr.storage.sql.common
 
DefaultSqlStorageProvider(DataSource) - Constructor for class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
DefaultSqlStorageProvider(DataSource, DefaultSqlStorageProvider.DatabaseOptions) - Constructor for class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
DefaultSqlStorageProvider.DatabaseOptions - Enum in org.jobrunr.storage.sql.common
 
delete() - Method in class org.jobrunr.jobs.Job
 
delete(String) - Static method in class org.jobrunr.scheduling.BackgroundJob
Deletes the recurring job based on the given id.
delete(String) - Method in class org.jobrunr.scheduling.JobScheduler
Deletes the recurring job based on the given id.
delete(String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
delete(String, HttpRequestHandler) - Method in class org.jobrunr.dashboard.server.http.RestHttpHandler
 
delete(Connection, String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
delete(UUID) - Static method in class org.jobrunr.scheduling.BackgroundJob
Deletes a job and sets it's state to DELETED.
delete(UUID) - Method in class org.jobrunr.scheduling.JobScheduler
Deletes a job and sets it's state to DELETED.
delete(UUID) - Method in class org.jobrunr.storage.AbstractStorageProvider
 
delete(UUID) - Method in interface org.jobrunr.storage.StorageProvider
This method changes the state of the job to the DeletedState - it does not permanently delete it yet
delete(UUID) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
delete(JobId) - Static method in class org.jobrunr.scheduling.BackgroundJob
 
delete(JobId) - Method in class org.jobrunr.scheduling.JobScheduler
 
DELETE - Static variable in class org.jobrunr.dashboard.server.http.handlers.HttpRequestHandlers.RequestMethod
 
deleteById(String) - Method in class org.jobrunr.storage.sql.common.RecurringJobTable
 
DELETED - org.jobrunr.jobs.states.StateName
 
DeletedState - Class in org.jobrunr.jobs.states
 
DeletedState() - Constructor for class org.jobrunr.jobs.states.DeletedState
 
DeletedWhileFailedConcurrentStateChange - Class in org.jobrunr.server.concurrent.statechanges
 
DeletedWhileFailedConcurrentStateChange() - Constructor for class org.jobrunr.server.concurrent.statechanges.DeletedWhileFailedConcurrentStateChange
 
DeletedWhileProcessingConcurrentStateChange - Class in org.jobrunr.server.concurrent.statechanges
 
DeletedWhileProcessingConcurrentStateChange(JobZooKeeper) - Constructor for class org.jobrunr.server.concurrent.statechanges.DeletedWhileProcessingConcurrentStateChange
 
DeletedWhileScheduledConcurrentStateChange - Class in org.jobrunr.server.concurrent.statechanges
 
DeletedWhileScheduledConcurrentStateChange() - Constructor for class org.jobrunr.server.concurrent.statechanges.DeletedWhileScheduledConcurrentStateChange
 
DeletedWhileSucceededConcurrentStateChange - Class in org.jobrunr.server.concurrent.statechanges
 
DeletedWhileSucceededConcurrentStateChange() - Constructor for class org.jobrunr.server.concurrent.statechanges.DeletedWhileSucceededConcurrentStateChange
 
deleteJobs(StateName, Instant) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
deleteJobs(StateName, Instant) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
deleteJobs(StateName, Instant) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
deleteJobs(StateName, Instant) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
deleteJobs(StateName, Instant) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
deleteJobs(StateName, Instant) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
deleteJobs(StateName, Instant) - Method in interface org.jobrunr.storage.StorageProvider
 
deleteJobs(StateName, Instant) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
deleteJobsByStateAndUpdatedBefore(StateName, Instant) - Method in class org.jobrunr.storage.sql.common.JobTable
 
deletePermanently(UUID) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
deletePermanently(UUID) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
deletePermanently(UUID) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
deletePermanently(UUID) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
deletePermanently(UUID) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
deletePermanently(UUID) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
deletePermanently(UUID) - Method in interface org.jobrunr.storage.StorageProvider
 
deletePermanently(UUID) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
deletePermanently(UUID...) - Method in class org.jobrunr.storage.sql.common.JobTable
 
deleteRecurringJob(String) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
deleteRecurringJob(String) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
deleteRecurringJob(String) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
deleteRecurringJob(String) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
deleteRecurringJob(String) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
deleteRecurringJob(String) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
deleteRecurringJob(String) - Method in interface org.jobrunr.storage.StorageProvider
 
deleteRecurringJob(String) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
DESC - org.jobrunr.storage.PageRequest.Order
 
descOnUpdatedAt(int) - Static method in class org.jobrunr.storage.PageRequest
 
descOnUpdatedAt(long, int) - Static method in class org.jobrunr.storage.PageRequest
 
descriptor - Variable in class org.jobrunr.jobs.details.instructions.VisitFieldInstruction
 
descriptor - Variable in class org.jobrunr.jobs.details.instructions.VisitMethodInstruction
 
deserialize(JsonParser, DeserializationContext) - Method in class org.jobrunr.utils.mapper.jackson.modules.DurationDeserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class org.jobrunr.utils.mapper.jackson.modules.InstantDeserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class org.jobrunr.utils.mapper.jackson.modules.JobParameterDeserializer
 
deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class org.jobrunr.utils.mapper.gson.JobParameterDeserializer
 
deserialize(String, Class<T>) - Method in class org.jobrunr.utils.mapper.gson.GsonJsonMapper
 
deserialize(String, Class<T>) - Method in class org.jobrunr.utils.mapper.jackson.JacksonJsonMapper
 
deserialize(String, Class<T>) - Method in class org.jobrunr.utils.mapper.jsonb.JsonbJsonMapper
 
deserialize(String, Class<T>) - Method in interface org.jobrunr.utils.mapper.JsonMapper
 
deserialize(JsonParser, DeserializationContext, Type) - Method in class org.jobrunr.utils.mapper.jsonb.serializer.DurationTypeDeserializer
 
deserialize(JsonParser, DeserializationContext, Type) - Method in class org.jobrunr.utils.mapper.jsonb.serializer.FileTypeDeserializer
 
deserialize(JsonParser, DeserializationContext, Type) - Method in class org.jobrunr.utils.mapper.jsonb.serializer.PathTypeDeserializer
 
deserializeJob(String) - Method in class org.jobrunr.jobs.mappers.JobMapper
 
deserializeRecurringJob(String) - Method in class org.jobrunr.jobs.mappers.JobMapper
 
destroy() - Static method in class org.jobrunr.configuration.JobRunr
 
Dialect - Interface in org.jobrunr.storage.sql.common.db.dialect
 
DialectFactory - Class in org.jobrunr.storage.sql.common.db.dialect
 
DisplayNameFilter - Class in org.jobrunr.jobs.filters
 
DisplayNameFilter() - Constructor for class org.jobrunr.jobs.filters.DisplayNameFilter
 
distinct() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
distinct() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
DLoadOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
DLoadOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.DLoadOperandInstruction
 
DoubleTypeAutoboxer - Class in org.jobrunr.utils.reflection.autobox
 
DoubleTypeAutoboxer() - Constructor for class org.jobrunr.utils.reflection.autobox.DoubleTypeAutoboxer
 
DStoreInstruction - Class in org.jobrunr.jobs.details.instructions
 
DStoreInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.DStoreInstruction
 
DupOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
DupOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.DupOperandInstruction
 
DurationAdapter - Class in org.jobrunr.utils.mapper.gson
 
DurationAdapter() - Constructor for class org.jobrunr.utils.mapper.gson.DurationAdapter
 
DurationDeserializer - Class in org.jobrunr.utils.mapper.jackson.modules
 
DurationDeserializer() - Constructor for class org.jobrunr.utils.mapper.jackson.modules.DurationDeserializer
 
DurationSerializer - Class in org.jobrunr.utils.mapper.jackson.modules
 
DurationSerializer() - Constructor for class org.jobrunr.utils.mapper.jackson.modules.DurationSerializer
 
DurationTypeDeserializer - Class in org.jobrunr.utils.mapper.jsonb.serializer
 
DurationTypeDeserializer() - Constructor for class org.jobrunr.utils.mapper.jsonb.serializer.DurationTypeDeserializer
 
DurationTypeSerializer - Class in org.jobrunr.utils.mapper.jsonb.serializer
Serializer for Duration type.
DurationTypeSerializer() - Constructor for class org.jobrunr.utils.mapper.jsonb.serializer.DurationTypeSerializer
 

E

ElasticSearchDocumentMapper - Class in org.jobrunr.storage.nosql.elasticsearch
 
ElasticSearchDocumentMapper(JobMapper) - Constructor for class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchDocumentMapper
 
ElasticSearchStorageProvider - Class in org.jobrunr.storage.nosql.elasticsearch
 
ElasticSearchStorageProvider(String, int) - Constructor for class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
ElasticSearchStorageProvider(HttpHost) - Constructor for class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
ElasticSearchStorageProvider(RestHighLevelClient) - Constructor for class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
ElasticSearchStorageProvider(RestHighLevelClient, RateLimiter) - Constructor for class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
ElasticSearchUtils - Class in org.jobrunr.storage.nosql.elasticsearch
 
ElasticSearchUtils() - Constructor for class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchUtils
 
ElectStateFilter - Interface in org.jobrunr.jobs.filters
A filter that is triggered each time that the state of a Job is changed.
empty() - Static method in class org.jobrunr.storage.JobStats
 
empty() - Static method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
empty() - Static method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
enqueue() - Method in class org.jobrunr.jobs.Job
 
enqueue(Stream<T>, IocJobLambdaFromStream<S, T>) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates new fire-and-forget jobs for each item in the input stream using the lambda passed as jobFromStream.
enqueue(Stream<T>, IocJobLambdaFromStream<S, T>) - Method in class org.jobrunr.scheduling.JobScheduler
Creates new fire-and-forget jobs for each item in the input stream using the lambda passed as jobFromStream.
enqueue(Stream<T>, JobLambdaFromStream<T>) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates new fire-and-forget jobs for each item in the input stream using the lambda passed as jobFromStream.
enqueue(Stream<T>, JobLambdaFromStream<T>) - Method in class org.jobrunr.scheduling.JobScheduler
Creates new fire-and-forget jobs for each item in the input stream using the lambda passed as jobFromStream.
enqueue(IocJobLambda<S>) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new fire-and-forget job based on a given lambda.
enqueue(IocJobLambda<S>) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new fire-and-forget job based on a given lambda.
enqueue(JobLambda) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new fire-and-forget job based on a given lambda.
enqueue(JobLambda) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new fire-and-forget job based on a given lambda.
ENQUEUED - org.jobrunr.jobs.states.StateName
 
EnqueuedState - Class in org.jobrunr.jobs.states
 
EnqueuedState() - Constructor for class org.jobrunr.jobs.states.EnqueuedState
 
enrich(JobStats) - Method in class org.jobrunr.storage.JobStatsEnricher
 
EnumAutoboxer - Class in org.jobrunr.utils.reflection.autobox
 
EnumAutoboxer() - Constructor for class org.jobrunr.utils.reflection.autobox.EnumAutoboxer
 
equals(Object) - Method in class org.jobrunr.jobs.JobId
 
equals(Object) - Method in class org.jobrunr.scheduling.cron.CronExpression
Compares this object against the specified object.
error(String) - Method in class org.jobrunr.jobs.context.JobDashboardLogger
 
error(String) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
error(String, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
error(String, Object...) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
error(String, Object, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
error(String, Throwable) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
error(Throwable) - Method in class org.jobrunr.dashboard.server.http.HttpResponse
 
error(Marker, String) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
error(Marker, String, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
error(Marker, String, Object...) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
error(Marker, String, Object, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
error(Marker, String, Throwable) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
ERROR - org.jobrunr.jobs.context.JobDashboardLogger.Level
 
estimateSize() - Method in class org.jobrunr.storage.sql.common.db.SqlSpliterator
 
Estimation(boolean) - Constructor for class org.jobrunr.storage.JobStatsExtended.Estimation
 
Estimation(boolean, Instant) - Constructor for class org.jobrunr.storage.JobStatsExtended.Estimation
 
every10minutes() - Static method in class org.jobrunr.scheduling.cron.Cron
 
every15minutes() - Static method in class org.jobrunr.scheduling.cron.Cron
 
every5minutes() - Static method in class org.jobrunr.scheduling.cron.Cron
 
everyHalfHour() - Static method in class org.jobrunr.scheduling.cron.Cron
 
ExceptionHandler<T extends java.lang.Exception> - Interface in org.jobrunr.dashboard.server.http.handlers
 
Exceptions - Class in org.jobrunr.utils.exceptions
 
Exceptions() - Constructor for class org.jobrunr.utils.exceptions.Exceptions
 
Exceptions.ThrowingBiConsumer<T,​U> - Interface in org.jobrunr.utils.exceptions
 
Exceptions.ThrowingBiFunction<T,​U,​R> - Interface in org.jobrunr.utils.exceptions
 
Exceptions.ThrowingConsumer<T> - Interface in org.jobrunr.utils.exceptions
 
Exceptions.ThrowingFunction<T,​R> - Interface in org.jobrunr.utils.exceptions
 
Exceptions.ThrowingRunnable - Interface in org.jobrunr.utils.exceptions
 
Exceptions.ThrowingSupplier<T> - Interface in org.jobrunr.utils.exceptions
 
execute(String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
exists(JobDetails, StateName...) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
exists(JobDetails, StateName...) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
exists(JobDetails, StateName...) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
exists(JobDetails, StateName...) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
exists(JobDetails, StateName...) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
exists(JobDetails, StateName...) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
exists(JobDetails, StateName...) - Method in class org.jobrunr.storage.sql.common.JobTable
 
exists(JobDetails, StateName...) - Method in interface org.jobrunr.storage.StorageProvider
 
exists(JobDetails, StateName...) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 

F

FACTORY - Static variable in class org.jobrunr.utils.mapper.gson.ClassNameObjectTypeAdapter
 
failed() - Method in class org.jobrunr.server.concurrent.ConcurrentJobModificationResolveResult
 
failed(String, Exception) - Method in class org.jobrunr.jobs.Job
 
failed(Job) - Static method in class org.jobrunr.server.concurrent.ConcurrentJobModificationResolveResult
 
FAILED - org.jobrunr.jobs.states.StateName
 
FAILED_STATES - Static variable in enum org.jobrunr.jobs.states.StateName
 
FailedState - Class in org.jobrunr.jobs.states
 
FailedState() - Constructor for class org.jobrunr.jobs.states.FailedState
 
FailedState(String, Exception) - Constructor for class org.jobrunr.jobs.states.FailedState
 
FIELD_CREATED_AT - Static variable in class org.jobrunr.storage.StorageProviderUtils.Jobs
 
FIELD_FIRST_HEARTBEAT - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_ID - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_ID - Static variable in class org.jobrunr.storage.StorageProviderUtils.Jobs
 
FIELD_ID - Static variable in class org.jobrunr.storage.StorageProviderUtils.JobStats
 
FIELD_ID - Static variable in class org.jobrunr.storage.StorageProviderUtils.RecurringJobs
 
FIELD_IS_RUNNING - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_JOB_AS_JSON - Static variable in class org.jobrunr.storage.StorageProviderUtils.Jobs
 
FIELD_JOB_AS_JSON - Static variable in class org.jobrunr.storage.StorageProviderUtils.RecurringJobs
 
FIELD_JOB_SIGNATURE - Static variable in class org.jobrunr.storage.StorageProviderUtils.Jobs
 
FIELD_LAST_HEARTBEAT - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_POLL_INTERVAL_IN_SECONDS - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_PROCESS_ALLOCATED_MEMORY - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_PROCESS_CPU_LOAD - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_PROCESS_FREE_MEMORY - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_PROCESS_MAX_MEMORY - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_SCHEDULED_AT - Static variable in class org.jobrunr.storage.StorageProviderUtils.Jobs
 
FIELD_STATE - Static variable in class org.jobrunr.storage.StorageProviderUtils.Jobs
 
FIELD_STATS - Static variable in class org.jobrunr.storage.StorageProviderUtils.JobStats
 
FIELD_SYSTEM_CPU_LOAD - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_SYSTEM_FREE_MEMORY - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_SYSTEM_TOTAL_MEMORY - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FIELD_UPDATED_AT - Static variable in class org.jobrunr.storage.StorageProviderUtils.Jobs
 
FIELD_VERSION - Static variable in class org.jobrunr.storage.StorageProviderUtils.Jobs
 
FIELD_VERSION - Static variable in class org.jobrunr.storage.StorageProviderUtils.RecurringJobs
 
FIELD_WORKER_POOL_SIZE - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
FieldAccessStrategy - Class in org.jobrunr.utils.mapper.jsonb
 
FieldAccessStrategy() - Constructor for class org.jobrunr.utils.mapper.jsonb.FieldAccessStrategy
 
FieldNotFoundException - Exception in org.jobrunr.scheduling.exceptions
 
FieldNotFoundException(Class<?>, String) - Constructor for exception org.jobrunr.scheduling.exceptions.FieldNotFoundException
 
FileTypeDeserializer - Class in org.jobrunr.utils.mapper.jsonb.serializer
 
FileTypeDeserializer() - Constructor for class org.jobrunr.utils.mapper.jsonb.serializer.FileTypeDeserializer
 
FileTypeSerializer - Class in org.jobrunr.utils.mapper.jsonb.serializer
 
FileTypeSerializer() - Constructor for class org.jobrunr.utils.mapper.jsonb.serializer.FileTypeSerializer
 
fillBitSet(int, int) - Method in enum org.jobrunr.scheduling.cron.CronFieldType
 
fillBitSetToIncl(int, int) - Method in enum org.jobrunr.scheduling.cron.CronFieldType
 
filter(Predicate<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
filter(Predicate<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
findAny() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
findAny() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
findField(Class<?>, String) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
findFirst() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
findFirst() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
findMatchingUrl(TeenyMatchUrl) - Method in class org.jobrunr.dashboard.server.http.handlers.HttpRequestMethodHandlers
 
findMethod(Class<?>, String, Class<?>...) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
findParamTypesFromDescriptor(String) - Static method in class org.jobrunr.jobs.details.JobDetailsGeneratorUtils
 
findParamTypesFromDescriptorAsArray(String) - Static method in class org.jobrunr.jobs.details.JobDetailsGeneratorUtils
 
FixedSizeBackgroundJobServerWorkerPolicy - Class in org.jobrunr.server.configuration
 
FixedSizeBackgroundJobServerWorkerPolicy(int) - Constructor for class org.jobrunr.server.configuration.FixedSizeBackgroundJobServerWorkerPolicy
 
flatMap(Function<? super T, ? extends Stream<? extends R>>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
flatMap(Function<? super T, ? extends Stream<? extends R>>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
flatMapToDouble(Function<? super T, ? extends DoubleStream>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
flatMapToDouble(Function<? super T, ? extends DoubleStream>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
flatMapToInt(Function<? super T, ? extends IntStream>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
flatMapToInt(Function<? super T, ? extends IntStream>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
flatMapToLong(Function<? super T, ? extends LongStream>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
flatMapToLong(Function<? super T, ? extends LongStream>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
FLoadOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
FLoadOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.FLoadOperandInstruction
 
FloatTypeAutoboxer - Class in org.jobrunr.utils.reflection.autobox
 
FloatTypeAutoboxer() - Constructor for class org.jobrunr.utils.reflection.autobox.FloatTypeAutoboxer
 
forDataSource(DataSource) - Static method in class org.jobrunr.storage.sql.common.db.dialect.DialectFactory
 
forEach(Consumer<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
forEach(Consumer<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
forEachOrdered(Consumer<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
forEachOrdered(Consumer<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
forType(Class<T>) - Static method in class org.jobrunr.storage.sql.common.db.Sql
 
from(String) - Static method in class org.jobrunr.dashboard.server.http.ContentType
 
from(Path) - Static method in class org.jobrunr.dashboard.server.http.ContentType
 
fromJson(InputStream, Class<T>) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
fromJson(InputStream, Type) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
fromJson(Reader, Class<T>) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
fromJson(Reader, Type) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
fromJson(String, Class<T>) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
fromJson(String, Type) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
fromJsonToJsonValue(Object) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
fromJsonValue(JsonValue, Class<T>) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
fromQueryParams(Class<T>) - Method in class org.jobrunr.dashboard.server.http.HttpRequest
 
fromQueryParams(Class<T>) - Method in class org.jobrunr.dashboard.server.http.url.TeenyRequestUrl
 
FStoreInstruction - Class in org.jobrunr.jobs.details.instructions
 
FStoreInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.FStoreInstruction
 

G

generate(Supplier<? extends T1>) - Static method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
generate(Supplier<? extends T1>) - Static method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
get() - Method in interface org.jobrunr.utils.exceptions.Exceptions.ThrowingSupplier
 
get(int, JobDetailsFinderContext) - Static method in class org.jobrunr.jobs.details.instructions.AllJVMInstructions
 
get(String) - Method in class org.jobrunr.dashboard.server.http.handlers.HttpRequestHandlers
 
get(String, HttpRequestHandler) - Method in class org.jobrunr.dashboard.server.http.RestHttpHandler
 
GET - Static variable in class org.jobrunr.dashboard.server.http.handlers.HttpRequestHandlers.RequestMethod
 
getAll() - Method in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
getAmountFailed() - Method in class org.jobrunr.storage.JobStatsExtended
 
getAmountSucceeded() - Method in class org.jobrunr.storage.JobStatsExtended
 
getAwaiting() - Method in class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
getAwaiting() - Method in interface org.jobrunr.server.jmx.JobStatsMBean
 
getAwaiting() - Method in class org.jobrunr.storage.JobStats
 
getBackgroundJobServers() - Method in class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
getBackgroundJobServers() - Method in interface org.jobrunr.server.jmx.JobStatsMBean
 
getBackgroundJobServers() - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
getBackgroundJobServers() - Method in class org.jobrunr.storage.JobStats
 
getBackgroundJobServers() - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
getBackgroundJobServers() - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
getBackgroundJobServers() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
getBackgroundJobServers() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
getBackgroundJobServers() - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
getBackgroundJobServers() - Method in interface org.jobrunr.storage.StorageProvider
 
getBackgroundJobServers() - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
getBackgroundJobServerStatusWriteModel(BackgroundJobServer) - Method in class org.jobrunr.server.ServerZooKeeper
 
getBackgroundJobWorker(Job) - Method in class org.jobrunr.server.runner.AbstractBackgroundJobRunner
 
getBackgroundJobWorker(Job) - Method in class org.jobrunr.server.runner.BackgroundJobWithIocRunner
 
getBackgroundJobWorker(Job) - Method in class org.jobrunr.server.runner.BackgroundJobWithoutIocRunner
 
getBackgroundJobWorker(Job) - Method in class org.jobrunr.server.runner.BackgroundStaticJobWithoutIocRunner
 
getBootstrapMethodArguments() - Method in class org.jobrunr.jobs.details.instructions.InvokeDynamicInstruction
 
getBootstrapMethodHandle() - Method in class org.jobrunr.jobs.details.instructions.InvokeDynamicInstruction
 
getClassContainingLambdaAsInputStream(Object) - Static method in class org.jobrunr.jobs.details.JobDetailsGeneratorUtils
 
getClassName() - Method in class org.jobrunr.jobs.JobDetails
 
getClassName() - Method in class org.jobrunr.jobs.JobParameter
 
getConcurrentUpdatedJobs() - Method in exception org.jobrunr.storage.ConcurrentJobModificationException
 
getConnection() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
getContextPath() - Method in class org.jobrunr.dashboard.server.http.RedirectHttpHandler
 
getContextPath() - Method in class org.jobrunr.dashboard.server.http.RestHttpHandler
 
getContextPath() - Method in class org.jobrunr.dashboard.server.http.StaticFileHttpHandler
 
getContextPath() - Method in class org.jobrunr.dashboard.server.sse.ServerSentEventHandler
 
getContextPath() - Method in interface org.jobrunr.dashboard.server.TeenyHttpHandler
 
getCreatedAt() - Method in class org.jobrunr.jobs.context.JobContext
 
getCreatedAt() - Method in class org.jobrunr.jobs.Job
 
getCreatedAt() - Method in class org.jobrunr.jobs.states.AbstractJobState
 
getCreatedAt() - Method in interface org.jobrunr.jobs.states.JobState
 
getCronExpression() - Method in class org.jobrunr.jobs.RecurringJob
 
getCurrentPage() - Method in class org.jobrunr.storage.Page
 
getDatabaseCreator() - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
getDatabaseSpecificMigrations() - Method in class org.jobrunr.storage.sql.common.DatabaseCreator
 
getDeleted() - Method in class org.jobrunr.storage.JobStats
 
getDeletedAt() - Method in class org.jobrunr.jobs.states.DeletedState
 
getDescriptor() - Method in class org.jobrunr.jobs.details.instructions.InvokeDynamicInstruction
 
getEnqueued() - Method in class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
getEnqueued() - Method in interface org.jobrunr.server.jmx.JobStatsMBean
 
getEnqueued() - Method in class org.jobrunr.storage.JobStats
 
getEnqueuedAt() - Method in class org.jobrunr.jobs.states.EnqueuedState
 
getEstimatedProcessingFinishedAt() - Method in class org.jobrunr.storage.JobStatsExtended.Estimation
 
getEstimation() - Method in class org.jobrunr.storage.JobStatsExtended
 
getException() - Method in class org.jobrunr.jobs.states.FailedState
 
getExceptionCauseMessage() - Method in class org.jobrunr.jobs.states.FailedState
 
getExceptionCauseType() - Method in class org.jobrunr.jobs.states.FailedState
 
getExceptionMessage() - Method in class org.jobrunr.jobs.states.FailedState
 
getExceptionType() - Method in class org.jobrunr.jobs.states.FailedState
 
getExponentialBackoffPolicy(Job, int) - Method in class org.jobrunr.jobs.filters.RetryFilter
 
getExpression() - Method in class org.jobrunr.scheduling.cron.CronExpression
 
getFailed() - Method in class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
getFailed() - Method in interface org.jobrunr.server.jmx.JobStatsMBean
 
getFailed() - Method in class org.jobrunr.storage.JobStats
 
getFailedItems() - Method in exception org.jobrunr.storage.sql.common.db.ConcurrentSqlModificationException
 
getField(Class<?>, String) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
GetFieldInstruction - Class in org.jobrunr.jobs.details.instructions
 
GetFieldInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.GetFieldInstruction
 
getFieldName() - Method in enum org.jobrunr.scheduling.cron.CronFieldType
 
getFirstHeartbeat() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getFirstHeartbeat() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getFirstHeartbeat() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getId() - Method in class org.jobrunr.jobs.AbstractJob
 
getId() - Method in class org.jobrunr.jobs.Job
 
getId() - Method in class org.jobrunr.jobs.RecurringJob
 
getId() - Method in class org.jobrunr.server.BackgroundJobServer
 
getId() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerMBean
 
getId() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getId() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getId() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getInstructions() - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
getItems() - Method in class org.jobrunr.storage.Page
 
getJedis() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
getJob() - Method in class org.jobrunr.server.concurrent.ConcurrentJobModificationResolveResult
 
getJobAnnotation(JobDetails) - Static method in class org.jobrunr.utils.JobUtils
 
getJobById(UUID) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
getJobById(UUID) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
getJobById(UUID) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
getJobById(UUID) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
getJobById(UUID) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
getJobById(UUID) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
getJobById(UUID) - Method in interface org.jobrunr.storage.StorageProvider
 
getJobById(UUID) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
getJobById(JobId) - Method in interface org.jobrunr.storage.StorageProvider
 
getJobById(JobId) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
getJobClass(JobDetails) - Static method in class org.jobrunr.utils.JobUtils
 
getJobDetails() - Method in class org.jobrunr.jobs.AbstractJob
 
getJobDetails() - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
getJobId() - Method in class org.jobrunr.dashboard.sse.JobSseExchange
 
getJobId() - Method in class org.jobrunr.jobs.context.JobContext
 
getJobId() - Method in interface org.jobrunr.storage.listeners.JobChangeListener
 
getJobMethod(Class<?>, JobDetails) - Static method in class org.jobrunr.utils.JobUtils
 
getJobMethod(JobDetails) - Static method in class org.jobrunr.utils.JobUtils
 
getJobMethodToPerform(Class<?>) - Method in class org.jobrunr.server.runner.AbstractBackgroundJobRunner.BackgroundJobWorker
 
getJobName() - Method in class org.jobrunr.jobs.AbstractJob
 
getJobName() - Method in class org.jobrunr.jobs.context.JobContext
 
getJobPage(StateName, PageRequest) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
getJobPage(StateName, PageRequest) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
getJobPage(StateName, PageRequest) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
getJobPage(StateName, PageRequest) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
getJobPage(StateName, PageRequest) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
getJobPage(StateName, PageRequest) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
getJobPage(StateName, PageRequest) - Method in interface org.jobrunr.storage.StorageProvider
 
getJobPage(StateName, PageRequest) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
getJobParameters() - Method in class org.jobrunr.jobs.JobDetails
 
getJobParameterTypes() - Method in class org.jobrunr.jobs.JobDetails
 
getJobParameterValues() - Method in class org.jobrunr.jobs.JobDetails
 
getJobs(StateName, Instant, PageRequest) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
getJobs(StateName, Instant, PageRequest) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
getJobs(StateName, Instant, PageRequest) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
getJobs(StateName, Instant, PageRequest) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
getJobs(StateName, Instant, PageRequest) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
getJobs(StateName, Instant, PageRequest) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
getJobs(StateName, Instant, PageRequest) - Method in interface org.jobrunr.storage.StorageProvider
 
getJobs(StateName, Instant, PageRequest) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
getJobs(StateName, PageRequest) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
getJobs(StateName, PageRequest) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
getJobs(StateName, PageRequest) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
getJobs(StateName, PageRequest) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
getJobs(StateName, PageRequest) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
getJobs(StateName, PageRequest) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
getJobs(StateName, PageRequest) - Method in interface org.jobrunr.storage.StorageProvider
 
getJobs(StateName, PageRequest) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
getJobSignature() - Method in class org.jobrunr.jobs.AbstractJob
 
getJobSignature(Job) - Static method in class org.jobrunr.utils.JobUtils
 
getJobSignature(JobDetails) - Static method in class org.jobrunr.utils.JobUtils
 
getJobState() - Method in class org.jobrunr.jobs.context.JobContext
 
getJobState() - Method in class org.jobrunr.jobs.Job
 
getJobState(int) - Method in class org.jobrunr.jobs.Job
 
getJobStates() - Method in class org.jobrunr.jobs.Job
 
getJobStatesOfType(Class<T>) - Method in class org.jobrunr.jobs.Job
 
getJobStats() - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
getJobStats() - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
getJobStats() - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
getJobStats() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
getJobStats() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
getJobStats() - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
getJobStats() - Method in interface org.jobrunr.storage.StorageProvider
 
getJobStats() - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
getJobToPerform(Class<?>) - Method in class org.jobrunr.server.runner.AbstractBackgroundJobRunner.BackgroundJobWorker
 
getJobToPerform(Class<?>) - Method in class org.jobrunr.server.runner.BackgroundJobWithIocRunner.ConsumerBackgroundJobWorker
 
getJobToPerformClass() - Method in class org.jobrunr.server.runner.AbstractBackgroundJobRunner.BackgroundJobWorker
 
getJobZooKeeper() - Method in class org.jobrunr.server.BackgroundJobServer
 
getLastHeartbeat() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getLastHeartbeat() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getLastHeartbeat() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getLastJobStateOfType(Class<T>) - Method in class org.jobrunr.jobs.Job
 
getLatencyDuration() - Method in class org.jobrunr.jobs.states.SucceededState
 
getLength() - Method in enum org.jobrunr.scheduling.cron.CronFieldType
 
getLevel() - Method in class org.jobrunr.jobs.context.JobDashboardLogger.JobDashboardLogLine
 
getLimit() - Method in class org.jobrunr.storage.Page
 
getLimit() - Method in class org.jobrunr.storage.PageRequest
 
getLocalVariable(int) - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
getLogInstant() - Method in class org.jobrunr.jobs.context.JobDashboardLogger.JobDashboardLogLine
 
getLogLines() - Method in class org.jobrunr.jobs.context.JobDashboardLogger.JobDashboardLogLines
 
getLogMessage() - Method in class org.jobrunr.jobs.context.JobDashboardLogger.JobDashboardLogLine
 
getMaxAllowedValue() - Method in enum org.jobrunr.scheduling.cron.CronFieldType
 
getMessage() - Method in class org.jobrunr.jobs.states.FailedState
 
getMetadata() - Method in class org.jobrunr.jobs.context.JobContext
 
getMetadata() - Method in class org.jobrunr.jobs.Job
 
getMethod(Class<?>, String, Class<?>...) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
getMethodName() - Method in class org.jobrunr.jobs.JobDetails
 
getMigrations() - Method in class org.jobrunr.storage.sql.common.DatabaseCreator
 
getMinAllowedValue() - Method in enum org.jobrunr.scheduling.cron.CronFieldType
 
getModule() - Method in class org.jobrunr.utils.mapper.jackson.JacksonJsonMapper
 
getName() - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
getName() - Method in class org.jobrunr.jobs.details.instructions.InvokeDynamicInstruction
 
getName() - Method in class org.jobrunr.jobs.states.AbstractJobState
 
getName() - Method in interface org.jobrunr.jobs.states.JobState
 
getNextRun() - Method in class org.jobrunr.dashboard.ui.model.RecurringJobUIModel
 
getNextRun() - Method in class org.jobrunr.jobs.RecurringJob
 
getNumberOfFields() - Method in class org.jobrunr.scheduling.cron.CronExpression
 
getObject() - Method in class org.jobrunr.jobs.JobParameter
 
getObjectViaField(Object, String) - Static method in class org.jobrunr.jobs.details.JobDetailsGeneratorUtils
 
getObjectViaStaticField(String, String) - Static method in class org.jobrunr.jobs.details.JobDetailsGeneratorUtils
 
getOccupiedWorkerCount() - Method in class org.jobrunr.server.JobZooKeeper
 
getOffset() - Method in class org.jobrunr.storage.Page
 
getOffset() - Method in class org.jobrunr.storage.PageRequest
 
getOrder() - Method in class org.jobrunr.storage.PageRequest
 
getParametersUsingParamTypes(Class<?>[]) - Method in class org.jobrunr.jobs.details.instructions.VisitMethodInstruction
 
getParams() - Method in class org.jobrunr.dashboard.server.http.url.TeenyRequestUrl
 
getPollIntervalInSeconds() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getPollIntervalInSeconds() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getPollIntervalInSeconds() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getPriority() - Method in interface org.jobrunr.server.threadpool.JobRunrExecutor
 
getPriority() - Method in class org.jobrunr.server.threadpool.ScheduledThreadPoolJobRunrExecutor
 
getProcessAllocatedMemory() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getProcessAllocatedMemory() - Method in class org.jobrunr.server.jmx.JobServerStats
 
getProcessAllocatedMemory() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getProcessAllocatedMemory() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getProcessCpuLoad() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getProcessCpuLoad() - Method in class org.jobrunr.server.jmx.JobServerStats
 
getProcessCpuLoad() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getProcessCpuLoad() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getProcessDuration() - Method in class org.jobrunr.jobs.states.SucceededState
 
getProcessFreeMemory() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getProcessFreeMemory() - Method in class org.jobrunr.server.jmx.JobServerStats
 
getProcessFreeMemory() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getProcessFreeMemory() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getProcessing() - Method in class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
getProcessing() - Method in interface org.jobrunr.server.jmx.JobStatsMBean
 
getProcessing() - Method in class org.jobrunr.storage.JobStats
 
getProcessMaxMemory() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getProcessMaxMemory() - Method in class org.jobrunr.server.jmx.JobServerStats
 
getProcessMaxMemory() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getProcessMaxMemory() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getProgress() - Method in class org.jobrunr.jobs.context.JobDashboardProgressBar
 
getReadableNameFromJobDetails(JobDetails) - Static method in class org.jobrunr.utils.JobUtils
 
getReason() - Method in class org.jobrunr.jobs.states.ScheduledState
 
getRecurringJobs() - Method in class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
getRecurringJobs() - Method in interface org.jobrunr.server.jmx.JobStatsMBean
 
getRecurringJobs() - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
getRecurringJobs() - Method in class org.jobrunr.storage.JobStats
 
getRecurringJobs() - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
getRecurringJobs() - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
getRecurringJobs() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
getRecurringJobs() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
getRecurringJobs() - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
getRecurringJobs() - Method in interface org.jobrunr.storage.StorageProvider
 
getRecurringJobs() - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
getScheduled() - Method in class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
getScheduled() - Method in interface org.jobrunr.server.jmx.JobStatsMBean
 
getScheduled() - Method in class org.jobrunr.storage.JobStats
 
getScheduledAt() - Method in class org.jobrunr.jobs.states.ScheduledState
 
getScheduledJobs(Instant, PageRequest) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
getScheduledJobs(Instant, PageRequest) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
getScheduledJobs(Instant, PageRequest) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
getScheduledJobs(Instant, PageRequest) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
getScheduledJobs(Instant, PageRequest) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
getScheduledJobs(Instant, PageRequest) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
getScheduledJobs(Instant, PageRequest) - Method in interface org.jobrunr.storage.StorageProvider
 
getScheduledJobs(Instant, PageRequest) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
getSecondsToAdd(Job) - Method in class org.jobrunr.jobs.filters.RetryFilter
 
getServerId() - Method in class org.jobrunr.jobs.states.ProcessingState
 
getServerStatus() - Method in class org.jobrunr.server.BackgroundJobServer
 
getServerStatus() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerMBean
 
getSignature() - Method in class org.jobrunr.jobs.context.JobContext
 
getStack() - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
getStackTrace() - Method in class org.jobrunr.jobs.states.FailedState
 
getStackTraceAsString(Throwable) - Static method in class org.jobrunr.utils.exceptions.Exceptions
 
getState() - Method in class org.jobrunr.jobs.Job
 
getStaticFieldName() - Method in class org.jobrunr.jobs.JobDetails
 
GetStaticInstruction - Class in org.jobrunr.jobs.details.instructions
 
GetStaticInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.GetStaticInstruction
 
getStorageProvider() - Method in class org.jobrunr.server.BackgroundJobServer
 
getSucceeded() - Method in class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
getSucceeded() - Method in interface org.jobrunr.server.jmx.JobStatsMBean
 
getSucceeded() - Method in class org.jobrunr.storage.JobStats
 
getSystemCpuLoad() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getSystemCpuLoad() - Method in class org.jobrunr.server.jmx.JobServerStats
 
getSystemCpuLoad() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getSystemCpuLoad() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getSystemFreeMemory() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getSystemFreeMemory() - Method in class org.jobrunr.server.jmx.JobServerStats
 
getSystemFreeMemory() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getSystemFreeMemory() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getSystemTotalMemory() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getSystemTotalMemory() - Method in class org.jobrunr.server.jmx.JobServerStats
 
getSystemTotalMemory() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getSystemTotalMemory() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getThreadProcessingJob(Job) - Method in class org.jobrunr.server.JobZooKeeper
 
getTimeStamp() - Method in class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
getTimeStamp() - Method in interface org.jobrunr.server.jmx.JobStatsMBean
 
getTimeStamp() - Method in class org.jobrunr.storage.JobStats
 
getTotal() - Method in class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
getTotal() - Method in interface org.jobrunr.server.jmx.JobStatsMBean
 
getTotal() - Method in class org.jobrunr.storage.JobStats
 
getTotal() - Method in class org.jobrunr.storage.Page
 
getTotalPages() - Method in class org.jobrunr.storage.Page
 
getUpdatedAt() - Method in class org.jobrunr.jobs.context.JobContext
 
getUpdatedAt() - Method in class org.jobrunr.jobs.Job
 
getUpdatedAt() - Method in class org.jobrunr.jobs.states.AbstractJobState
 
getUpdatedAt() - Method in interface org.jobrunr.jobs.states.JobState
 
getUpdatedAt() - Method in class org.jobrunr.jobs.states.ProcessingState
 
getUrl() - Method in class org.jobrunr.dashboard.server.http.url.TeenyMatchUrl
 
getUrl() - Method in class org.jobrunr.dashboard.server.http.url.TeenyRequestUrl
 
getValueFromFieldOrProperty(Object, String) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
getVariable() - Method in class org.jobrunr.jobs.details.instructions.StoreVariableInstruction
 
getVersion() - Method in class org.jobrunr.jobs.AbstractJob
 
getVersion(Class<?>) - Static method in class org.jobrunr.utils.metadata.VersionRetriever
 
getWebServerHostAddress() - Method in class org.jobrunr.dashboard.server.TeenyWebServer
 
getWebServerHostPort() - Method in class org.jobrunr.dashboard.server.TeenyWebServer
 
getWorkerCount() - Method in interface org.jobrunr.server.configuration.BackgroundJobServerWorkerPolicy
 
getWorkerCount() - Method in class org.jobrunr.server.configuration.DefaultBackgroundJobServerWorkerPolicy
 
getWorkerCount() - Method in class org.jobrunr.server.configuration.FixedSizeBackgroundJobServerWorkerPolicy
 
getWorkerPoolSize() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
getWorkerPoolSize() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
getWorkerPoolSize() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
getWorkPageRequest() - Method in class org.jobrunr.server.strategy.BasicWorkDistributionStrategy
 
getWorkPageRequest() - Method in interface org.jobrunr.server.strategy.WorkDistributionStrategy
 
getZoneId() - Method in class org.jobrunr.jobs.RecurringJob
 
GsonJsonMapper - Class in org.jobrunr.utils.mapper.gson
 
GsonJsonMapper() - Constructor for class org.jobrunr.utils.mapper.gson.GsonJsonMapper
 

H

H2StorageProvider - Class in org.jobrunr.storage.sql.h2
 
H2StorageProvider(DataSource) - Constructor for class org.jobrunr.storage.sql.h2.H2StorageProvider
 
handle(HttpExchange) - Method in class org.jobrunr.dashboard.server.http.RedirectHttpHandler
 
handle(HttpExchange) - Method in class org.jobrunr.dashboard.server.http.RestHttpHandler
 
handle(HttpExchange) - Method in class org.jobrunr.dashboard.server.http.StaticFileHttpHandler
 
handle(HttpExchange) - Method in class org.jobrunr.dashboard.server.sse.ServerSentEventHandler
 
hasCause(Throwable, Class<? extends Throwable>) - Static method in class org.jobrunr.utils.exceptions.Exceptions
 
hasDefaultNoArgConstructor(Class<?>) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
hasDefaultNoArgConstructor(String) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
hashCode() - Method in class org.jobrunr.jobs.JobId
 
hashCode() - Method in class org.jobrunr.scheduling.cron.CronExpression
 
hasNext() - Method in class org.jobrunr.storage.Page
 
hasPrevious() - Method in class org.jobrunr.storage.Page
 
hasState(StateName) - Method in class org.jobrunr.jobs.Job
 
head(String, HttpRequestHandler) - Method in class org.jobrunr.dashboard.server.http.RestHttpHandler
 
HEAD - Static variable in class org.jobrunr.dashboard.server.http.handlers.HttpRequestHandlers.RequestMethod
 
HOUR - org.jobrunr.scheduling.cron.CronFieldType
 
hourly() - Static method in class org.jobrunr.scheduling.cron.Cron
 
hourly(int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
HttpRequest - Class in org.jobrunr.dashboard.server.http
 
HttpRequest(TeenyRequestUrl) - Constructor for class org.jobrunr.dashboard.server.http.HttpRequest
 
HttpRequestHandler - Interface in org.jobrunr.dashboard.server.http.handlers
 
HttpRequestHandlers - Class in org.jobrunr.dashboard.server.http.handlers
 
HttpRequestHandlers() - Constructor for class org.jobrunr.dashboard.server.http.handlers.HttpRequestHandlers
 
HttpRequestHandlers.RequestMethod - Class in org.jobrunr.dashboard.server.http.handlers
 
HttpRequestMethodHandlers - Class in org.jobrunr.dashboard.server.http.handlers
 
HttpRequestMethodHandlers() - Constructor for class org.jobrunr.dashboard.server.http.handlers.HttpRequestMethodHandlers
 
HttpResponse - Class in org.jobrunr.dashboard.server.http
 
HttpResponse(HttpExchange, JsonMapper) - Constructor for class org.jobrunr.dashboard.server.http.HttpResponse
 

I

IConst0OperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
IConst0OperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.IConst0OperandInstruction
 
IConst1OperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
IConst1OperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.IConst1OperandInstruction
 
IConst2OperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
IConst2OperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.IConst2OperandInstruction
 
IConst3OperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
IConst3OperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.IConst3OperandInstruction
 
IConst4OperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
IConst4OperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.IConst4OperandInstruction
 
IConst5OperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
IConst5OperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.IConst5OperandInstruction
 
ILoadOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
ILoadOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.ILoadOperandInstruction
 
IMAGE_PNG - Static variable in class org.jobrunr.dashboard.server.http.ContentType
 
IMAGE_X_ICON - Static variable in class org.jobrunr.dashboard.server.http.ContentType
 
increaseByOne() - Method in class org.jobrunr.jobs.context.JobDashboardProgressBar
 
increaseVersion() - Method in class org.jobrunr.jobs.AbstractJob
Increases the version of this Job instance
info(String) - Method in class org.jobrunr.jobs.context.JobDashboardLogger
 
info(String) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
info(String, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
info(String, Object...) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
info(String, Object, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
info(String, Throwable) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
info(Marker, String) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
info(Marker, String, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
info(Marker, String, Object...) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
info(Marker, String, Object, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
info(Marker, String, Throwable) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
INFO - org.jobrunr.jobs.context.JobDashboardLogger.Level
 
init() - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
initialize() - Method in class org.jobrunr.configuration.JobRunrConfiguration
Initializes JobRunr and returns a JobScheduler which can then be used to register in the IoC framework or to enqueue/schedule some Jobs.
initLocalVariables(Object[]) - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
InMemoryStorageProvider - Class in org.jobrunr.storage
 
InMemoryStorageProvider() - Constructor for class org.jobrunr.storage.InMemoryStorageProvider
 
InMemoryStorageProvider(RateLimiter) - Constructor for class org.jobrunr.storage.InMemoryStorageProvider
 
insert(Connection, String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
insert(Connection, T, String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
insert(T, String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
insertAll(List<T>, String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
InstantAdapter - Class in org.jobrunr.utils.mapper.gson
 
InstantAdapter() - Constructor for class org.jobrunr.utils.mapper.gson.InstantAdapter
 
InstantDeserializer - Class in org.jobrunr.utils.mapper.jackson.modules
 
InstantDeserializer() - Constructor for class org.jobrunr.utils.mapper.jackson.modules.InstantDeserializer
 
InstantForOracleTypeAutoboxer - Class in org.jobrunr.utils.reflection.autobox
 
InstantForOracleTypeAutoboxer() - Constructor for class org.jobrunr.utils.reflection.autobox.InstantForOracleTypeAutoboxer
 
InstantSerializer - Class in org.jobrunr.utils.mapper.jackson.modules
 
InstantSerializer() - Constructor for class org.jobrunr.utils.mapper.jackson.modules.InstantSerializer
 
InstantTypeAutoboxer - Class in org.jobrunr.utils.reflection.autobox
 
InstantTypeAutoboxer() - Constructor for class org.jobrunr.utils.reflection.autobox.InstantTypeAutoboxer
 
IntegerTypeAutoboxer - Class in org.jobrunr.utils.reflection.autobox
 
IntegerTypeAutoboxer() - Constructor for class org.jobrunr.utils.reflection.autobox.IntegerTypeAutoboxer
 
InvalidCronExpressionException - Exception in org.jobrunr.scheduling.cron
 
InvokeDynamicInstruction - Class in org.jobrunr.jobs.details.instructions
 
InvokeDynamicInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.InvokeDynamicInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.AAStoreInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.AbstractJVMInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.ANewArrayOperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.DStoreInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.DupOperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.GetFieldInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.GetStaticInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.IConst0OperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.IConst1OperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.IConst2OperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.IConst3OperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.IConst4OperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.IConst5OperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.InvokeDynamicInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.InvokeSpecialInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.InvokeStaticInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.JobDetailsInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.LConst0OperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.LConst1OperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.LdcInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.LStoreInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.NewOperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.PopOperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.ReturnOperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.SingleIntOperandInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.StoreVariableInstruction
 
invokeInstruction() - Method in class org.jobrunr.jobs.details.instructions.VisitLocalVariableInstruction
 
invokeInstructionAndPushOnStack() - Method in class org.jobrunr.jobs.details.instructions.AbstractJVMInstruction
 
invokeInstructionAndPushOnStack() - Method in class org.jobrunr.jobs.details.instructions.StoreVariableInstruction
 
InvokeInterfaceInstruction - Class in org.jobrunr.jobs.details.instructions
 
InvokeInterfaceInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.InvokeInterfaceInstruction
 
invokeJobMethod(Object, Method) - Method in class org.jobrunr.server.runner.AbstractBackgroundJobRunner.BackgroundJobWorker
 
InvokeSpecialInstruction - Class in org.jobrunr.jobs.details.instructions
 
InvokeSpecialInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.InvokeSpecialInstruction
 
InvokeStaticInstruction - Class in org.jobrunr.jobs.details.instructions
 
InvokeStaticInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.InvokeStaticInstruction
 
InvokeVirtualInstruction - Class in org.jobrunr.jobs.details.instructions
 
InvokeVirtualInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.InvokeVirtualInstruction
 
IocJobLambda<S> - Interface in org.jobrunr.jobs.lambdas
This is a functional interface which represents a lambda that will be parsed by JobRunr.
IocJobLambdaFromStream<S,​T> - Interface in org.jobrunr.jobs.lambdas
This is a functional interface which allows you to schedule jobs based on a Stream and a lambda that will be parsed by JobRunr.
isAllowed() - Method in class org.jobrunr.utils.resilience.RateLimiter
 
isClassAssignableToObject(Class<?>, Object) - Static method in class org.jobrunr.jobs.details.JobDetailsGeneratorUtils
 
isClosed() - Method in class org.jobrunr.dashboard.server.sse.SseExchange
 
isDebugEnabled() - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
isDebugEnabled(Marker) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
isErrorEnabled() - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
isErrorEnabled(Marker) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
isEstimatedProcessingFinishedInstantAvailable() - Method in class org.jobrunr.storage.JobStatsExtended.Estimation
 
isInfoEnabled() - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
isInfoEnabled(Marker) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
isInterface - Variable in class org.jobrunr.jobs.details.instructions.VisitMethodInstruction
 
isLeapYear(int) - Static method in class org.jobrunr.scheduling.cron.CronExpression
 
isLocked() - Method in class org.jobrunr.utils.resilience.Lock
 
isMaster() - Method in class org.jobrunr.server.JobZooKeeper
 
isMigrationApplied(Path) - Method in class org.jobrunr.storage.sql.common.DatabaseCreator
 
isNotNullOrEmpty(String) - Static method in class org.jobrunr.utils.StringUtils
 
isNullOrEmpty(String) - Static method in class org.jobrunr.utils.StringUtils
 
isParallel() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
isParallel() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
isProblematicAndDoNotRetry() - Method in exception org.jobrunr.JobRunrException
 
isProcessingDone() - Method in class org.jobrunr.storage.JobStatsExtended.Estimation
 
isRateLimited() - Method in class org.jobrunr.utils.resilience.RateLimiter
 
isRunning() - Method in class org.jobrunr.server.BackgroundJobServer
 
isRunning() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerMBean
 
isRunning() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
isRunning() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
isRunning() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
IStoreInstruction - Class in org.jobrunr.jobs.details.instructions
 
IStoreInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.IStoreInstruction
 
isTraceEnabled() - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
isTraceEnabled(Marker) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
isVisible(Field) - Method in class org.jobrunr.utils.mapper.jsonb.FieldAccessStrategy
 
isVisible(Method) - Method in class org.jobrunr.utils.mapper.jsonb.FieldAccessStrategy
 
isWarnEnabled() - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
isWarnEnabled(Marker) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
iterate(T1, UnaryOperator<T1>) - Static method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
iterate(T1, UnaryOperator<T1>) - Static method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
iterator() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
iterator() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 

J

JacksonJsonMapper - Class in org.jobrunr.utils.mapper.jackson
 
JacksonJsonMapper() - Constructor for class org.jobrunr.utils.mapper.jackson.JacksonJsonMapper
 
JedisRedisPipelinedStream<T> - Class in org.jobrunr.storage.nosql.redis
 
JedisRedisPipelinedStream(Collection<T>, Jedis) - Constructor for class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
JedisRedisPipelinedStream(Stream<T>, Jedis) - Constructor for class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
JedisRedisStorageProvider - Class in org.jobrunr.storage.nosql.redis
 
JedisRedisStorageProvider() - Constructor for class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
JedisRedisStorageProvider(JedisPool) - Constructor for class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
JedisRedisStorageProvider(JedisPool, RateLimiter) - Constructor for class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
Job - Class in org.jobrunr.jobs
Defines the job with it's JobDetails, History and Job Metadata
Job - Annotation Type in org.jobrunr.jobs.annotations
Allows to add a specific name to a job that will be used in the dashboard as well as extra jobFilters that will be used for the job.
Job(UUID, int, JobDetails, List<JobState>, ConcurrentMap<String, Object>) - Constructor for class org.jobrunr.jobs.Job
 
Job(JobDetails) - Constructor for class org.jobrunr.jobs.Job
 
Job(JobDetails, List<JobState>) - Constructor for class org.jobrunr.jobs.Job
 
Job(JobDetails, JobState) - Constructor for class org.jobrunr.jobs.Job
 
JOB_RUNR_LOG_KEY - Static variable in class org.jobrunr.jobs.context.JobDashboardLogger
 
JOB_RUNR_LOG_KEY - Static variable in class org.jobrunr.jobs.context.JobDashboardProgressBar
 
JobActivator - Interface in org.jobrunr.server
 
JobAdapter - Class in org.jobrunr.utils.mapper.jsonb
 
JobAdapter() - Constructor for class org.jobrunr.utils.mapper.jsonb.JobAdapter
 
JobChangeListener - Interface in org.jobrunr.storage.listeners
 
JobClassNotFoundException - Exception in org.jobrunr.scheduling.exceptions
 
JobClassNotFoundException(String) - Constructor for exception org.jobrunr.scheduling.exceptions.JobClassNotFoundException
 
JobClassNotFoundException(JobDetails) - Constructor for exception org.jobrunr.scheduling.exceptions.JobClassNotFoundException
 
JobClientFilter - Interface in org.jobrunr.jobs.filters
A filter that is triggered each time that a Job is about to be created (before it is saved to the StorageProvider) has been created (after is has been saved in the StorageProvider
JobContext - Class in org.jobrunr.jobs.context
 
JobContext - Static variable in class org.jobrunr.jobs.JobParameter
 
JobContext(Job) - Constructor for class org.jobrunr.jobs.context.JobContext
Keep constructor package protected to remove confusion on how to instantiate the JobContext.
JobContext.Metadata - Interface in org.jobrunr.jobs.context
 
jobCounterKey(StateName) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
JobDashboardLogger - Class in org.jobrunr.jobs.context
 
JobDashboardLogger(Job) - Constructor for class org.jobrunr.jobs.context.JobDashboardLogger
 
JobDashboardLogger.JobDashboardLogLine - Class in org.jobrunr.jobs.context
 
JobDashboardLogger.JobDashboardLogLines - Class in org.jobrunr.jobs.context
 
JobDashboardLogger.Level - Enum in org.jobrunr.jobs.context
 
JobDashboardLogLine() - Constructor for class org.jobrunr.jobs.context.JobDashboardLogger.JobDashboardLogLine
 
JobDashboardLogLine(JobDashboardLogger.Level, String) - Constructor for class org.jobrunr.jobs.context.JobDashboardLogger.JobDashboardLogLine
 
JobDashboardLogLines() - Constructor for class org.jobrunr.jobs.context.JobDashboardLogger.JobDashboardLogLines
 
JobDashboardProgressBar - Class in org.jobrunr.jobs.context
 
JobDashboardProgressBar(Job, Long) - Constructor for class org.jobrunr.jobs.context.JobDashboardProgressBar
 
jobDetails - Variable in class org.jobrunr.server.runner.AbstractBackgroundJobRunner.BackgroundJobWorker
 
JobDetails - Class in org.jobrunr.jobs
 
JobDetails(String, String, String, List<JobParameter>) - Constructor for class org.jobrunr.jobs.JobDetails
 
JobDetailsAdapter - Class in org.jobrunr.utils.mapper.jsonb.adapters
 
JobDetailsAdapter(JobRunrJsonb) - Constructor for class org.jobrunr.utils.mapper.jsonb.adapters.JobDetailsAdapter
 
JobDetailsAsmGenerator - Class in org.jobrunr.jobs.details
 
JobDetailsAsmGenerator() - Constructor for class org.jobrunr.jobs.details.JobDetailsAsmGenerator
 
jobDetailsBuilder - Variable in class org.jobrunr.jobs.details.instructions.AbstractJVMInstruction
 
JobDetailsFinderContext - Class in org.jobrunr.jobs.details
 
JobDetailsFinderContext(SerializedLambda, Object...) - Constructor for class org.jobrunr.jobs.details.JobDetailsFinderContext
 
JobDetailsGenerator - Interface in org.jobrunr.jobs.details
 
JobDetailsGeneratorUtils - Class in org.jobrunr.jobs.details
 
JobDetailsInstruction - Class in org.jobrunr.jobs.details.instructions
 
JobDetailsInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.JobDetailsInstruction
 
jobDetailsKey(StateName) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
JobDocumentMapper - Class in org.jobrunr.storage.nosql.mongo
 
JobDocumentMapper(JobMapper) - Constructor for class org.jobrunr.storage.nosql.mongo.JobDocumentMapper
 
JobFilter - Interface in org.jobrunr.jobs.filters
 
jobFilters() - Method in annotation type org.jobrunr.jobs.annotations.Job
 
JobFilters - Class in org.jobrunr.jobs.filters
 
JobFilters(List<JobFilter>) - Constructor for class org.jobrunr.jobs.filters.JobFilters
 
JobFilters(JobFilter...) - Constructor for class org.jobrunr.jobs.filters.JobFilters
 
JobHistoryAdapter - Class in org.jobrunr.utils.mapper.jsonb.adapters
 
JobHistoryAdapter(JobRunrJsonb) - Constructor for class org.jobrunr.utils.mapper.jsonb.adapters.JobHistoryAdapter
 
JobId - Class in org.jobrunr.jobs
Class which represents the Id of the job.
JobId(UUID) - Constructor for class org.jobrunr.jobs.JobId
 
jobIndex() - Static method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchUtils
 
jobIndexName() - Static method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchUtils
 
jobKey(String) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
jobKey(UUID) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
jobKey(Job) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
JobLambda - Interface in org.jobrunr.jobs.lambdas
This is a functional interface which represents a lambda that will be parsed by JobRunr.
JobLambdaFromStream<T> - Interface in org.jobrunr.jobs.lambdas
This is a functional interface which allows you to schedule jobs based on a Stream and a lambda that will be parsed by JobRunr.
jobMapper - Variable in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
JobMapper - Class in org.jobrunr.jobs.mappers
 
JobMapper(JsonMapper) - Constructor for class org.jobrunr.jobs.mappers.JobMapper
 
JobMetadataAdapter - Class in org.jobrunr.utils.mapper.jsonb.adapters
 
JobMetadataAdapter(JobRunrJsonb) - Constructor for class org.jobrunr.utils.mapper.jsonb.adapters.JobMetadataAdapter
 
JobMethodNotFoundException - Exception in org.jobrunr.scheduling.exceptions
 
JobMethodNotFoundException(String) - Constructor for exception org.jobrunr.scheduling.exceptions.JobMethodNotFoundException
 
JobMethodNotFoundException(JobDetails) - Constructor for exception org.jobrunr.scheduling.exceptions.JobMethodNotFoundException
 
JobNotFoundException - Exception in org.jobrunr.scheduling.exceptions
 
JobNotFoundException - Exception in org.jobrunr.storage
 
JobNotFoundException(Class<?>, String, Class<?>[]) - Constructor for exception org.jobrunr.scheduling.exceptions.JobNotFoundException
 
JobNotFoundException(String) - Constructor for exception org.jobrunr.scheduling.exceptions.JobNotFoundException
 
JobNotFoundException(String) - Constructor for exception org.jobrunr.storage.JobNotFoundException
 
JobNotFoundException(String, String, String[]) - Constructor for exception org.jobrunr.scheduling.exceptions.JobNotFoundException
 
JobNotFoundException(UUID) - Constructor for exception org.jobrunr.storage.JobNotFoundException
 
JobNotFoundException(JobDetails) - Constructor for exception org.jobrunr.scheduling.exceptions.JobNotFoundException
 
JobParameter - Class in org.jobrunr.jobs
 
JobParameter(Class<?>, Object) - Constructor for class org.jobrunr.jobs.JobParameter
 
JobParameter(String, Object) - Constructor for class org.jobrunr.jobs.JobParameter
 
JobParameterDeserializer - Class in org.jobrunr.utils.mapper.gson
 
JobParameterDeserializer - Class in org.jobrunr.utils.mapper.jackson.modules
 
JobParameterDeserializer() - Constructor for class org.jobrunr.utils.mapper.gson.JobParameterDeserializer
 
JobParameterDeserializer() - Constructor for class org.jobrunr.utils.mapper.jackson.modules.JobParameterDeserializer
 
JobParameterSerializer - Class in org.jobrunr.utils.mapper.jackson.modules
 
JobParameterSerializer() - Constructor for class org.jobrunr.utils.mapper.jackson.modules.JobParameterSerializer
 
jobQueueForStateKey(StateName) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
JobRunr - Class in org.jobrunr.configuration
This class provides the entry point for the JobRunr configuration.
JobRunrApiHandler - Class in org.jobrunr.dashboard
 
JobRunrApiHandler(StorageProvider, JsonMapper) - Constructor for class org.jobrunr.dashboard.JobRunrApiHandler
 
JobRunrConfiguration - Class in org.jobrunr.configuration
The main class to cofigure JobRunr
JobRunrDashboardLogger - Class in org.jobrunr.jobs.context
 
JobRunrDashboardLogger(Logger) - Constructor for class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
JobRunrDashboardLogger(Logger, JobDashboardLogger.Level) - Constructor for class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
JobRunrDashboardWebServer - Class in org.jobrunr.dashboard
Provides a dashboard which gives insights in your jobs and servers.
JobRunrDashboardWebServer(StorageProvider, JsonMapper) - Constructor for class org.jobrunr.dashboard.JobRunrDashboardWebServer
 
JobRunrDashboardWebServer(StorageProvider, JsonMapper, int) - Constructor for class org.jobrunr.dashboard.JobRunrDashboardWebServer
 
JobRunrDashboardWebServer(StorageProvider, JsonMapper, JobRunrDashboardWebServerConfiguration) - Constructor for class org.jobrunr.dashboard.JobRunrDashboardWebServer
 
JobRunrDashboardWebServerConfiguration - Class in org.jobrunr.dashboard
This class allows to configure the JobRunrDashboard
JobRunrException - Exception in org.jobrunr
 
JobRunrException(String) - Constructor for exception org.jobrunr.JobRunrException
 
JobRunrException(String, boolean) - Constructor for exception org.jobrunr.JobRunrException
 
JobRunrException(String, boolean, Throwable) - Constructor for exception org.jobrunr.JobRunrException
 
JobRunrException(String, Throwable) - Constructor for exception org.jobrunr.JobRunrException
 
JobRunrExecutor - Interface in org.jobrunr.server.threadpool
 
JobRunrJMXExtensions - Class in org.jobrunr.server.jmx
 
JobRunrJMXExtensions(BackgroundJobServer, StorageProvider) - Constructor for class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
JobRunrJob - Interface in org.jobrunr.jobs.lambdas
 
JobRunrJsonb - Class in org.jobrunr.utils.mapper.jsonb
 
JobRunrJsonb(Jsonb) - Constructor for class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
JobRunrSseHandler - Class in org.jobrunr.dashboard
 
JobRunrSseHandler(String, StorageProvider, JsonMapper) - Constructor for class org.jobrunr.dashboard.JobRunrSseHandler
 
JobRunrSseHandler(StorageProvider, JsonMapper) - Constructor for class org.jobrunr.dashboard.JobRunrSseHandler
 
JobRunrStaticFileHandler - Class in org.jobrunr.dashboard
 
JobRunrStaticFileHandler() - Constructor for class org.jobrunr.dashboard.JobRunrStaticFileHandler
 
JobRunrTimeModule - Class in org.jobrunr.utils.mapper.jackson.modules
 
JobRunrTimeModule() - Constructor for class org.jobrunr.utils.mapper.jackson.modules.JobRunrTimeModule
 
JobScheduler - Class in org.jobrunr.scheduling
Provides methods for creating fire-and-forget, delayed and recurring jobs as well as to delete existing background jobs.
JobScheduler(StorageProvider) - Constructor for class org.jobrunr.scheduling.JobScheduler
Creates a new JobScheduler using the provided storageProvider
JobScheduler(StorageProvider, List<JobFilter>) - Constructor for class org.jobrunr.scheduling.JobScheduler
Creates a new JobScheduler using the provided storageProvider and the list of JobFilters that will be used for every background job
JobServerFilter - Interface in org.jobrunr.jobs.filters
A filter that is triggered each time that a Job starts processing or has been processed.
JobServerStats - Class in org.jobrunr.server.jmx
 
JobServerStats() - Constructor for class org.jobrunr.server.jmx.JobServerStats
 
JobServerStats(OperatingSystemMXBean, MBeanServer) - Constructor for class org.jobrunr.server.jmx.JobServerStats
 
JobSseExchange - Class in org.jobrunr.dashboard.sse
 
JobSseExchange(HttpExchange, StorageProvider, JsonMapper) - Constructor for class org.jobrunr.dashboard.sse.JobSseExchange
 
JobState - Interface in org.jobrunr.jobs.states
 
JobStats - Class in org.jobrunr.storage
 
JobStats(Instant, Long, Long, Long, Long, Long, Long, Long, Long, int, int) - Constructor for class org.jobrunr.storage.JobStats
 
JobStats(JobStats) - Constructor for class org.jobrunr.storage.JobStats
 
JobStatsChangeListener - Interface in org.jobrunr.storage.listeners
 
JobStatsEnricher - Class in org.jobrunr.storage
 
JobStatsEnricher() - Constructor for class org.jobrunr.storage.JobStatsEnricher
 
JobStatsExtended - Class in org.jobrunr.storage
 
JobStatsExtended(JobStats) - Constructor for class org.jobrunr.storage.JobStatsExtended
 
JobStatsExtended(JobStats, Long, Long, Instant) - Constructor for class org.jobrunr.storage.JobStatsExtended
 
JobStatsExtended.Estimation - Class in org.jobrunr.storage
 
jobStatsIndex() - Static method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchUtils
 
JobStatsMBean - Interface in org.jobrunr.server.jmx
 
JobStatsSseExchange - Class in org.jobrunr.dashboard.sse
 
JobStatsSseExchange(HttpExchange, StorageProvider, JsonMapper) - Constructor for class org.jobrunr.dashboard.sse.JobStatsSseExchange
 
jobTable() - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
JobTable - Class in org.jobrunr.storage.sql.common
 
JobTable(DataSource, JobMapper) - Constructor for class org.jobrunr.storage.sql.common.JobTable
 
JobUtils - Class in org.jobrunr.utils
 
jobVersionKey(UUID) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
jobVersionKey(Job) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
JobZooKeeper - Class in org.jobrunr.server
 
JobZooKeeper(BackgroundJobServer) - Constructor for class org.jobrunr.server.JobZooKeeper
 
JsonbJsonMapper - Class in org.jobrunr.utils.mapper.jsonb
 
JsonbJsonMapper() - Constructor for class org.jobrunr.utils.mapper.jsonb.JsonbJsonMapper
 
JsonMapper - Interface in org.jobrunr.utils.mapper
 
JsonMapperException - Exception in org.jobrunr.utils.mapper
 
JsonMapperException(String) - Constructor for exception org.jobrunr.utils.mapper.JsonMapperException
 
JsonMapperException(String, Throwable) - Constructor for exception org.jobrunr.utils.mapper.JsonMapperException
 

L

LConst0OperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
LConst0OperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.LConst0OperandInstruction
 
LConst1OperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
LConst1OperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.LConst1OperandInstruction
 
LdcInstruction - Class in org.jobrunr.jobs.details.instructions
 
LdcInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.LdcInstruction
 
LettuceRedisPipelinedStream<T> - Class in org.jobrunr.storage.nosql.redis
 
LettuceRedisPipelinedStream(Collection<T>, StatefulRedisConnection) - Constructor for class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
LettuceRedisPipelinedStream(Stream<T>, StatefulRedisConnection) - Constructor for class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
LettuceRedisStorageProvider - Class in org.jobrunr.storage.nosql.redis
 
LettuceRedisStorageProvider(RedisClient) - Constructor for class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
LettuceRedisStorageProvider(RedisClient, RateLimiter) - Constructor for class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
limit(long) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
limit(long) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
limitAndOffset(String) - Method in class org.jobrunr.storage.sql.common.db.dialect.AnsiDialect
 
limitAndOffset(String) - Method in interface org.jobrunr.storage.sql.common.db.dialect.Dialect
 
limitAndOffset(String) - Method in class org.jobrunr.storage.sql.common.db.dialect.OracleDialect
 
listAllChildrenOnClasspath(Class<?>, String...) - Static method in class org.jobrunr.utils.ClassPathUtils
 
listAllChildrenOnClasspath(String...) - Static method in class org.jobrunr.utils.ClassPathUtils
 
LLoadOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
LLoadOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.LLoadOperandInstruction
 
load() - Method in class org.jobrunr.jobs.details.instructions.AAStoreInstruction
 
load() - Method in class org.jobrunr.jobs.details.instructions.DupOperandInstruction
 
load() - Method in class org.jobrunr.jobs.details.instructions.PopOperandInstruction
 
load() - Method in class org.jobrunr.jobs.details.instructions.ReturnOperandInstruction
 
load() - Method in class org.jobrunr.jobs.details.instructions.ZeroOperandInstruction
 
load(int) - Method in class org.jobrunr.jobs.details.instructions.SingleIntOperandInstruction
 
load(int) - Method in class org.jobrunr.jobs.details.instructions.VisitLocalVariableInstruction
 
load(Object) - Method in class org.jobrunr.jobs.details.instructions.LdcInstruction
 
load(String) - Method in class org.jobrunr.jobs.details.instructions.NewOperandInstruction
 
load(String) - Method in class org.jobrunr.jobs.details.instructions.VisitTypeInstruction
 
load(String, String, String) - Method in class org.jobrunr.jobs.details.instructions.VisitFieldInstruction
 
load(String, String, String, boolean) - Method in class org.jobrunr.jobs.details.instructions.VisitMethodInstruction
 
load(String, String, Handle, Object...) - Method in class org.jobrunr.jobs.details.instructions.InvokeDynamicInstruction
 
loadClass(String) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
lock() - Method in class org.jobrunr.jobs.AbstractJob
 
lock() - Method in class org.jobrunr.utils.resilience.Lock
 
lock() - Method in interface org.jobrunr.utils.resilience.Lockable
 
Lock - Class in org.jobrunr.utils.resilience
 
Lock() - Constructor for class org.jobrunr.utils.resilience.Lock
 
Lockable - Interface in org.jobrunr.utils.resilience
 
logger() - Method in class org.jobrunr.jobs.context.JobContext
 
LongTypeAutoboxer - Class in org.jobrunr.utils.reflection.autobox
 
LongTypeAutoboxer() - Constructor for class org.jobrunr.utils.reflection.autobox.LongTypeAutoboxer
 
LStoreInstruction - Class in org.jobrunr.jobs.details.instructions
 
LStoreInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.LStoreInstruction
 

M

main(String[]) - Static method in class org.jobrunr.dashboard.JobRunrDashboardWebServer
 
main(String[]) - Static method in class org.jobrunr.storage.sql.common.DatabaseCreator
 
makeAccessible(AccessibleObject) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
map(Function<? super T, ? extends R>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
map(Function<? super T, ? extends R>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
map(PageRequest) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBPageRequestMapper
 
map(PageRequest) - Method in class org.jobrunr.storage.sql.common.SqlPageRequestMapper
 
mapAfterSync(Function<? super T, ? extends R>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
mapAfterSync(Exceptions.ThrowingFunction<? super T, ? extends R>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
mapToDouble(ToDoubleFunction<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
mapToDouble(ToDoubleFunction<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
mapToInt(ToIntFunction<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
mapToInt(ToIntFunction<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
mapToLong(ToLongFunction<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
mapToLong(ToLongFunction<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
mapToValues() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
mapUsingPipeline(BiFunction<RedisAsyncCommands, T, R>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
mapUsingPipeline(BiFunction<Pipeline, T, R>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
MariaDbStorageProvider - Class in org.jobrunr.storage.sql.mariadb
 
MariaDbStorageProvider(DataSource) - Constructor for class org.jobrunr.storage.sql.mariadb.MariaDbStorageProvider
 
matches(String) - Method in class org.jobrunr.dashboard.server.http.url.TeenyMatchUrl
 
matches(UrlPathPart) - Method in class org.jobrunr.dashboard.server.http.url.UrlParamPathPart
 
matches(UrlPathPart) - Method in interface org.jobrunr.dashboard.server.http.url.UrlPathPart
 
matches(UrlPathPart) - Method in class org.jobrunr.dashboard.server.http.url.UrlStringPathPart
 
matches(StateName, StateName) - Method in class org.jobrunr.server.concurrent.statechanges.AbstractAllowedConcurrentStateChange
 
matches(StateName, StateName) - Method in interface org.jobrunr.server.concurrent.statechanges.AllowedConcurrentStateChange
 
max(Comparator<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
max(Comparator<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
min(Comparator<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
min(Comparator<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
MINUTE - org.jobrunr.scheduling.cron.CronFieldType
 
MINUTE - Static variable in class org.jobrunr.utils.resilience.RateLimiter
 
minutely() - Static method in class org.jobrunr.scheduling.cron.Cron
 
MongoDBPageRequestMapper - Class in org.jobrunr.storage.nosql.mongo
 
MongoDBPageRequestMapper() - Constructor for class org.jobrunr.storage.nosql.mongo.MongoDBPageRequestMapper
 
MongoDBStorageProvider - Class in org.jobrunr.storage.nosql.mongo
 
MongoDBStorageProvider(MongoClient) - Constructor for class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
MongoDBStorageProvider(MongoClient, RateLimiter) - Constructor for class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
MongoDBStorageProvider(String, int) - Constructor for class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
MONTH - org.jobrunr.scheduling.cron.CronFieldType
 
monthly() - Static method in class org.jobrunr.scheduling.cron.Cron
 
monthly(int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
monthly(int, int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
monthly(int, int, int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
MultiLock - Class in org.jobrunr.utils.resilience
 
MultiLock(Collection<? extends Lockable>) - Constructor for class org.jobrunr.utils.resilience.MultiLock
 
MultiLock(Lockable...) - Constructor for class org.jobrunr.utils.resilience.MultiLock
 
mustNotRetry() - Method in class org.jobrunr.jobs.states.FailedState
 

N

name - Variable in class org.jobrunr.jobs.details.instructions.VisitFieldInstruction
 
name - Variable in class org.jobrunr.jobs.details.instructions.VisitMethodInstruction
 
name() - Method in annotation type org.jobrunr.jobs.annotations.Job
 
NAME - Static variable in class org.jobrunr.storage.StorageProviderUtils.BackgroundJobServers
 
NAME - Static variable in class org.jobrunr.storage.StorageProviderUtils.Jobs
 
NAME - Static variable in class org.jobrunr.storage.StorageProviderUtils.JobStats
 
NAME - Static variable in class org.jobrunr.storage.StorageProviderUtils.RecurringJobs
 
newInstance(Class<T>) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
newInstance(Class<T>, Object...) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
newInstance(String, Object...) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
newInstanceAndSetFieldValues(Class<T>, Map<String, String>) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
newInstanceCE(Class<T>, Object...) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
newInstanceOrElse(String, T) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
NewOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
NewOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.NewOperandInstruction
 
next() - Method in class org.jobrunr.scheduling.cron.CronExpression
Calculates the next occurrence based on the current time.
next(int) - Method in class org.jobrunr.scheduling.cron.CronExpression
Calculates the next N occurrences based on current time.
next(Instant) - Method in class org.jobrunr.scheduling.cron.CronExpression
Calculates the next occurrence based on provided base time.
next(Instant, int) - Method in class org.jobrunr.scheduling.cron.CronExpression
Calculates the next N occurrences based on provided base time.
next(ZoneId) - Method in class org.jobrunr.scheduling.cron.CronExpression
 
nextDuration(Instant, TimeUnit) - Method in class org.jobrunr.scheduling.cron.CronExpression
Calculates the number of time units from the provided base time to the next occurrence.
nextDuration(TimeUnit) - Method in class org.jobrunr.scheduling.cron.CronExpression
Calculates the number of time units from the current time to the next occurrence.
noneMatch(Predicate<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
noneMatch(Predicate<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
notAllJobsAreExisting(List<Job>) - Static method in class org.jobrunr.storage.StorageProviderUtils
 
notAllJobsAreNew(List<Job>) - Static method in class org.jobrunr.storage.StorageProviderUtils
 
notFound - Static variable in class org.jobrunr.dashboard.server.http.handlers.HttpRequestHandlers
 
notifyJobStatsOnChangeListeners() - Method in class org.jobrunr.storage.AbstractStorageProvider
 
notifyOnChangeListenersIf(boolean) - Method in class org.jobrunr.storage.AbstractStorageProvider
 
notifyThreadIdle() - Method in class org.jobrunr.server.JobZooKeeper
 
notifyThreadOccupied() - Method in class org.jobrunr.server.JobZooKeeper
 
Null - Static variable in class org.jobrunr.jobs.context.JobContext
 
NullSafeJsonBuilder - Class in org.jobrunr.utils.mapper.jsonb
 
NullSafeJsonBuilder() - Constructor for class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
NullSafeJsonBuilder(JsonObject) - Constructor for class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
nullSafeJsonObjectBuilder() - Static method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
nullSafeJsonObjectBuilder(Jsonb, Object) - Static method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 
nullSafeJsonObjectBuilder(JsonObject) - Static method in class org.jobrunr.utils.mapper.jsonb.NullSafeJsonBuilder
 

O

objectContainsFieldOrProperty(Object, String) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
of(Class<T>) - Static method in class org.jobrunr.utils.mapper.gson.RuntimeClassNameTypeAdapterFactory
Creates a new runtime type adapter for baseType using "type" as the type field name.
of(Class<T>, String) - Static method in class org.jobrunr.utils.mapper.gson.RuntimeClassNameTypeAdapterFactory
Creates a new runtime type adapter using for baseType using typeFieldName as the type field name.
of(Instant, JobStats) - Static method in class org.jobrunr.storage.JobStats
 
of(T1) - Static method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
of(T1) - Static method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
of(T1...) - Static method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
of(T1...) - Static method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
ofType(Collection<X>, Class<Y>) - Static method in class org.jobrunr.utils.streams.StreamUtils
 
ofType(Stream<X>, Class<Y>) - Static method in class org.jobrunr.utils.streams.StreamUtils
 
ok - Static variable in class org.jobrunr.dashboard.server.http.handlers.HttpRequestHandlers
 
onChange(List<BackgroundJobServerStatus>) - Method in class org.jobrunr.dashboard.sse.BackgroundJobServerStatusSseExchange
 
onChange(List<BackgroundJobServerStatus>) - Method in interface org.jobrunr.storage.listeners.BackgroundJobServerStatusChangeListener
 
onChange(Job) - Method in class org.jobrunr.dashboard.sse.JobSseExchange
 
onChange(Job) - Method in interface org.jobrunr.storage.listeners.JobChangeListener
 
onChange(JobStats) - Method in class org.jobrunr.dashboard.sse.JobStatsSseExchange
 
onChange(JobStats) - Method in class org.jobrunr.server.jmx.JobRunrJMXExtensions
 
onChange(JobStats) - Method in interface org.jobrunr.storage.listeners.JobStatsChangeListener
 
onClose(Runnable) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
onClose(Runnable) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
onCreated(AbstractJob) - Method in class org.jobrunr.jobs.filters.DisplayNameFilter
 
onCreated(AbstractJob) - Method in interface org.jobrunr.jobs.filters.JobClientFilter
 
onCreating(AbstractJob) - Method in class org.jobrunr.jobs.filters.DisplayNameFilter
 
onCreating(AbstractJob) - Method in interface org.jobrunr.jobs.filters.JobClientFilter
 
onProcessed(Job) - Method in interface org.jobrunr.jobs.filters.JobServerFilter
 
onProcessing(Job) - Method in interface org.jobrunr.jobs.filters.JobServerFilter
 
onStateApplied(Job, JobState, JobState) - Method in interface org.jobrunr.jobs.filters.ApplyStateFilter
 
onStateElection(Job, JobState) - Method in interface org.jobrunr.jobs.filters.ElectStateFilter
 
onStateElection(Job, JobState) - Method in class org.jobrunr.jobs.filters.RetryFilter
 
OPTIONS - Static variable in class org.jobrunr.dashboard.server.http.handlers.HttpRequestHandlers.RequestMethod
 
OracleDialect - Class in org.jobrunr.storage.sql.common.db.dialect
 
OracleDialect() - Constructor for class org.jobrunr.storage.sql.common.db.dialect.OracleDialect
 
OracleStorageProvider - Class in org.jobrunr.storage.sql.oracle
 
OracleStorageProvider(DataSource) - Constructor for class org.jobrunr.storage.sql.oracle.OracleStorageProvider
 
org.jobrunr - package org.jobrunr
 
org.jobrunr.configuration - package org.jobrunr.configuration
How to configure JobRunr.
org.jobrunr.dashboard - package org.jobrunr.dashboard
All code related to the dashboard
org.jobrunr.dashboard.server - package org.jobrunr.dashboard.server
The embedded webserver to display the dashboard.
org.jobrunr.dashboard.server.http - package org.jobrunr.dashboard.server.http
 
org.jobrunr.dashboard.server.http.handlers - package org.jobrunr.dashboard.server.http.handlers
 
org.jobrunr.dashboard.server.http.url - package org.jobrunr.dashboard.server.http.url
 
org.jobrunr.dashboard.server.sse - package org.jobrunr.dashboard.server.sse
 
org.jobrunr.dashboard.sse - package org.jobrunr.dashboard.sse
 
org.jobrunr.dashboard.ui.model - package org.jobrunr.dashboard.ui.model
 
org.jobrunr.jobs - package org.jobrunr.jobs
Everything related to background jobs.
org.jobrunr.jobs.annotations - package org.jobrunr.jobs.annotations
 
org.jobrunr.jobs.context - package org.jobrunr.jobs.context
 
org.jobrunr.jobs.details - package org.jobrunr.jobs.details
 
org.jobrunr.jobs.details.instructions - package org.jobrunr.jobs.details.instructions
 
org.jobrunr.jobs.filters - package org.jobrunr.jobs.filters
 
org.jobrunr.jobs.lambdas - package org.jobrunr.jobs.lambdas
 
org.jobrunr.jobs.mappers - package org.jobrunr.jobs.mappers
 
org.jobrunr.jobs.states - package org.jobrunr.jobs.states
 
org.jobrunr.scheduling - package org.jobrunr.scheduling
All info on how to enqueue and schedule background jobs.
org.jobrunr.scheduling.cron - package org.jobrunr.scheduling.cron
 
org.jobrunr.scheduling.exceptions - package org.jobrunr.scheduling.exceptions
 
org.jobrunr.server - package org.jobrunr.server
 
org.jobrunr.server.concurrent - package org.jobrunr.server.concurrent
 
org.jobrunr.server.concurrent.statechanges - package org.jobrunr.server.concurrent.statechanges
 
org.jobrunr.server.configuration - package org.jobrunr.server.configuration
 
org.jobrunr.server.jmx - package org.jobrunr.server.jmx
 
org.jobrunr.server.runner - package org.jobrunr.server.runner
 
org.jobrunr.server.strategy - package org.jobrunr.server.strategy
 
org.jobrunr.server.threadpool - package org.jobrunr.server.threadpool
 
org.jobrunr.storage - package org.jobrunr.storage
 
org.jobrunr.storage.listeners - package org.jobrunr.storage.listeners
 
org.jobrunr.storage.nosql.elasticsearch - package org.jobrunr.storage.nosql.elasticsearch
 
org.jobrunr.storage.nosql.mongo - package org.jobrunr.storage.nosql.mongo
 
org.jobrunr.storage.nosql.redis - package org.jobrunr.storage.nosql.redis
 
org.jobrunr.storage.sql - package org.jobrunr.storage.sql
 
org.jobrunr.storage.sql.common - package org.jobrunr.storage.sql.common
 
org.jobrunr.storage.sql.common.db - package org.jobrunr.storage.sql.common.db
 
org.jobrunr.storage.sql.common.db.dialect - package org.jobrunr.storage.sql.common.db.dialect
 
org.jobrunr.storage.sql.db2 - package org.jobrunr.storage.sql.db2
 
org.jobrunr.storage.sql.h2 - package org.jobrunr.storage.sql.h2
 
org.jobrunr.storage.sql.mariadb - package org.jobrunr.storage.sql.mariadb
 
org.jobrunr.storage.sql.oracle - package org.jobrunr.storage.sql.oracle
 
org.jobrunr.storage.sql.postgres - package org.jobrunr.storage.sql.postgres
 
org.jobrunr.storage.sql.sqlite - package org.jobrunr.storage.sql.sqlite
 
org.jobrunr.storage.sql.sqlserver - package org.jobrunr.storage.sql.sqlserver
 
org.jobrunr.utils - package org.jobrunr.utils
 
org.jobrunr.utils.annotations - package org.jobrunr.utils.annotations
 
org.jobrunr.utils.exceptions - package org.jobrunr.utils.exceptions
 
org.jobrunr.utils.mapper - package org.jobrunr.utils.mapper
 
org.jobrunr.utils.mapper.gson - package org.jobrunr.utils.mapper.gson
 
org.jobrunr.utils.mapper.jackson - package org.jobrunr.utils.mapper.jackson
 
org.jobrunr.utils.mapper.jackson.modules - package org.jobrunr.utils.mapper.jackson.modules
 
org.jobrunr.utils.mapper.jsonb - package org.jobrunr.utils.mapper.jsonb
 
org.jobrunr.utils.mapper.jsonb.adapters - package org.jobrunr.utils.mapper.jsonb.adapters
 
org.jobrunr.utils.mapper.jsonb.serializer - package org.jobrunr.utils.mapper.jsonb.serializer
 
org.jobrunr.utils.metadata - package org.jobrunr.utils.metadata
 
org.jobrunr.utils.reflection - package org.jobrunr.utils.reflection
 
org.jobrunr.utils.reflection.autobox - package org.jobrunr.utils.reflection.autobox
 
org.jobrunr.utils.resilience - package org.jobrunr.utils.resilience
 
org.jobrunr.utils.streams - package org.jobrunr.utils.streams
 
owner - Variable in class org.jobrunr.jobs.details.instructions.VisitFieldInstruction
 
owner - Variable in class org.jobrunr.jobs.details.instructions.VisitMethodInstruction
 

P

Page<T> - Class in org.jobrunr.storage
 
Page(long, List<T>, long, int) - Constructor for class org.jobrunr.storage.Page
 
Page(long, List<T>, PageRequest) - Constructor for class org.jobrunr.storage.Page
 
PageRequest - Class in org.jobrunr.storage
 
PageRequest(String, long, int) - Constructor for class org.jobrunr.storage.PageRequest
 
PageRequest.Order - Enum in org.jobrunr.storage
 
parallel() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
parallel() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
param(String) - Method in class org.jobrunr.dashboard.server.http.HttpRequest
 
param(String) - Method in class org.jobrunr.dashboard.server.http.url.TeenyRequestUrl
 
param(String, Class<T>) - Method in class org.jobrunr.dashboard.server.http.HttpRequest
 
param(String, Class<T>) - Method in class org.jobrunr.dashboard.server.http.url.TeenyRequestUrl
 
parse(String) - Static method in class org.jobrunr.jobs.JobId
 
parseAsterisk() - Method in enum org.jobrunr.scheduling.cron.CronFieldType
 
part() - Method in class org.jobrunr.dashboard.server.http.url.UrlParamPathPart
 
part() - Method in interface org.jobrunr.dashboard.server.http.url.UrlPathPart
 
part() - Method in class org.jobrunr.dashboard.server.http.url.UrlStringPathPart
 
PathAdapter - Class in org.jobrunr.utils.mapper.gson
 
PathAdapter() - Constructor for class org.jobrunr.utils.mapper.gson.PathAdapter
 
PathTypeDeserializer - Class in org.jobrunr.utils.mapper.jsonb.serializer
 
PathTypeDeserializer() - Constructor for class org.jobrunr.utils.mapper.jsonb.serializer.PathTypeDeserializer
 
PathTypeSerializer - Class in org.jobrunr.utils.mapper.jsonb.serializer
 
PathTypeSerializer() - Constructor for class org.jobrunr.utils.mapper.jsonb.serializer.PathTypeSerializer
 
pause() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
pause() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
pause() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
pauseProcessing() - Method in class org.jobrunr.server.BackgroundJobServer
 
pauseProcessing() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerMBean
 
peek(Consumer<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
peek(Consumer<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
per(int, ChronoUnit) - Method in class org.jobrunr.utils.resilience.RateLimiter.Builder
 
per(Duration) - Method in class org.jobrunr.utils.resilience.RateLimiter.Builder
 
pollFirstInstruction() - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
PopOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
PopOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.PopOperandInstruction
 
post(String, HttpRequestHandler) - Method in class org.jobrunr.dashboard.server.http.RestHttpHandler
 
POST - Static variable in class org.jobrunr.dashboard.server.http.handlers.HttpRequestHandlers.RequestMethod
 
PostgresStorageProvider - Class in org.jobrunr.storage.sql.postgres
 
PostgresStorageProvider(DataSource) - Constructor for class org.jobrunr.storage.sql.postgres.PostgresStorageProvider
 
problematicConfigurationException(String) - Static method in exception org.jobrunr.JobRunrException
 
problematicException(String, Throwable) - Static method in exception org.jobrunr.JobRunrException
 
PROCESSING - org.jobrunr.jobs.states.StateName
 
ProcessingState - Class in org.jobrunr.jobs.states
 
ProcessingState() - Constructor for class org.jobrunr.jobs.states.ProcessingState
 
ProcessingState(UUID) - Constructor for class org.jobrunr.jobs.states.ProcessingState
 
progressBar(int) - Method in class org.jobrunr.jobs.context.JobContext
 
progressBar(long) - Method in class org.jobrunr.jobs.context.JobContext
 
publishJobStatCounter(StateName, int) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
publishJobStatCounter(StateName, int) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
publishJobStatCounter(StateName, int) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
publishJobStatCounter(StateName, int) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
publishJobStatCounter(StateName, int) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
publishJobStatCounter(StateName, int) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
publishJobStatCounter(StateName, int) - Method in interface org.jobrunr.storage.StorageProvider
 
publishJobStatCounter(StateName, int) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
pushInstructionOnStack(AbstractJVMInstruction) - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
put(String, HttpRequestHandler) - Method in class org.jobrunr.dashboard.server.http.RestHttpHandler
 
PUT - Static variable in class org.jobrunr.dashboard.server.http.handlers.HttpRequestHandlers.RequestMethod
 

Q

queryParam(String) - Method in class org.jobrunr.dashboard.server.http.url.TeenyRequestUrl
 
queryParam(String, Class<T>, T) - Method in class org.jobrunr.dashboard.server.http.HttpRequest
 
queryParam(String, Class<T>, T) - Method in class org.jobrunr.dashboard.server.http.url.TeenyRequestUrl
 
QUEUE_SCHEDULEDJOBS_KEY - Static variable in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
QUEUE_SCHEDULEDJOBS_KEY - Static variable in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 

R

rateLimit() - Static method in class org.jobrunr.utils.resilience.RateLimiter.Builder
 
RateLimiter - Class in org.jobrunr.utils.resilience
 
RateLimiter.Builder - Class in org.jobrunr.utils.resilience
 
read(JsonReader) - Method in class org.jobrunr.utils.mapper.gson.ClassNameObjectTypeAdapter
 
read(JsonReader) - Method in class org.jobrunr.utils.mapper.gson.DurationAdapter
 
read(JsonReader) - Method in class org.jobrunr.utils.mapper.gson.InstantAdapter
 
read(JsonReader) - Method in class org.jobrunr.utils.mapper.gson.PathAdapter
 
RECURRING_JOBS_KEY - Static variable in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
RECURRING_JOBS_KEY - Static variable in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
RecurringJob - Class in org.jobrunr.jobs
 
RecurringJob(String, JobDetails, String, String) - Constructor for class org.jobrunr.jobs.RecurringJob
 
RecurringJob(String, JobDetails, CronExpression, ZoneId) - Constructor for class org.jobrunr.jobs.RecurringJob
 
RecurringJobAdapter - Class in org.jobrunr.utils.mapper.jsonb
 
RecurringJobAdapter() - Constructor for class org.jobrunr.utils.mapper.jsonb.RecurringJobAdapter
 
recurringJobIndex() - Static method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchUtils
 
recurringJobIndexName() - Static method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchUtils
 
recurringJobKey(String) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
recurringJobTable() - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
RecurringJobTable - Class in org.jobrunr.storage.sql.common
 
RecurringJobTable(DataSource, JobMapper) - Constructor for class org.jobrunr.storage.sql.common.RecurringJobTable
 
RecurringJobUIModel - Class in org.jobrunr.dashboard.ui.model
 
RecurringJobUIModel(RecurringJob) - Constructor for class org.jobrunr.dashboard.ui.model.RecurringJobUIModel
 
RedirectHttpHandler - Class in org.jobrunr.dashboard.server.http
 
RedirectHttpHandler(String, String) - Constructor for class org.jobrunr.dashboard.server.http.RedirectHttpHandler
 
RedisUtilities - Class in org.jobrunr.storage.nosql.redis
 
reduce(BinaryOperator<T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
reduce(BinaryOperator<T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
reduce(T, BinaryOperator<T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
reduce(T, BinaryOperator<T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
reduce(U, BiFunction<U, ? super T, U>, BinaryOperator<U>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
reduce(U, BiFunction<U, ? super T, U>, BinaryOperator<U>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
ReflectionUtils - Class in org.jobrunr.utils.reflection
 
registerSubtype(Class<? extends T>) - Method in class org.jobrunr.utils.mapper.gson.RuntimeClassNameTypeAdapterFactory
Registers type identified by its simple name.
registerSubtype(Class<? extends T>, String) - Method in class org.jobrunr.utils.mapper.gson.RuntimeClassNameTypeAdapterFactory
Registers type identified by label.
removeAllWithLastHeartbeatOlderThan(Instant) - Method in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
removeJobStorageOnChangeListener(StorageProviderChangeListener) - Method in class org.jobrunr.storage.AbstractStorageProvider
 
removeJobStorageOnChangeListener(StorageProviderChangeListener) - Method in interface org.jobrunr.storage.StorageProvider
 
removeJobStorageOnChangeListener(StorageProviderChangeListener) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
removeTimedOutBackgroundJobServers(Instant) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
removeTimedOutBackgroundJobServers(Instant) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
removeTimedOutBackgroundJobServers(Instant) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
removeTimedOutBackgroundJobServers(Instant) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
removeTimedOutBackgroundJobServers(Instant) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
removeTimedOutBackgroundJobServers(Instant) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
removeTimedOutBackgroundJobServers(Instant) - Method in interface org.jobrunr.storage.StorageProvider
 
removeTimedOutBackgroundJobServers(Instant) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
replaceLast(String, String, String) - Static method in class org.jobrunr.jobs.details.instructions.InvokeDynamicInstruction
 
resolve(Job) - Method in class org.jobrunr.server.concurrent.ConcurrentJobModificationResolver
 
resolve(Job, Job) - Method in class org.jobrunr.server.concurrent.statechanges.AbstractAllowedConcurrentStateChange
 
resolve(Job, Job) - Method in interface org.jobrunr.server.concurrent.statechanges.AllowedConcurrentStateChange
 
resolve(Job, Job) - Method in class org.jobrunr.server.concurrent.statechanges.DeletedWhileProcessingConcurrentStateChange
 
resolve(ConcurrentJobModificationException) - Method in class org.jobrunr.server.concurrent.ConcurrentJobModificationResolver
 
RestHttpHandler - Class in org.jobrunr.dashboard.server.http
 
RestHttpHandler(String, JsonMapper) - Constructor for class org.jobrunr.dashboard.server.http.RestHttpHandler
 
resume() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
resume() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
resume() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
resumeProcessing() - Method in class org.jobrunr.server.BackgroundJobServer
 
resumeProcessing() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerMBean
 
retries() - Method in annotation type org.jobrunr.jobs.annotations.Job
 
RetryFilter - Class in org.jobrunr.jobs.filters
A JobFilter of type ElectStateFilter that will retry the job if it fails for up to 10 times.
RetryFilter() - Constructor for class org.jobrunr.jobs.filters.RetryFilter
 
RetryFilter(int) - Constructor for class org.jobrunr.jobs.filters.RetryFilter
 
ReturnOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
ReturnOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.ReturnOperandInstruction
 
run() - Method in interface org.jobrunr.jobs.lambdas.JobLambda
 
run() - Method in class org.jobrunr.server.BackgroundJobPerformer
 
run() - Method in class org.jobrunr.server.JobZooKeeper
 
run() - Method in class org.jobrunr.server.runner.AbstractBackgroundJobRunner.BackgroundJobWorker
 
run() - Method in class org.jobrunr.server.runner.BackgroundStaticJobWithoutIocRunner.StaticFieldBackgroundJobWorker
 
run() - Method in class org.jobrunr.server.ServerZooKeeper
 
run() - Method in interface org.jobrunr.utils.exceptions.Exceptions.ThrowingRunnable
 
run(Job) - Method in class org.jobrunr.server.runner.AbstractBackgroundJobRunner
 
run(Job) - Method in interface org.jobrunr.server.runner.BackgroundJobRunner
 
runMigration(Path) - Method in class org.jobrunr.storage.sql.common.DatabaseCreator
 
runMigrations() - Method in class org.jobrunr.storage.sql.common.DatabaseCreator
 
runMigrationStatement(Connection, Path) - Method in class org.jobrunr.storage.sql.common.DatabaseCreator
 
RunnerJobContext - Class in org.jobrunr.server.runner
 
RunnerJobContext(Job) - Constructor for class org.jobrunr.server.runner.RunnerJobContext
 
runOnCreatedFilter(List<Job>) - Method in class org.jobrunr.jobs.filters.JobFilters
 
runOnCreatedFilter(AbstractJob) - Method in class org.jobrunr.jobs.filters.JobFilters
 
runOnCreatingFilter(List<Job>) - Method in class org.jobrunr.jobs.filters.JobFilters
 
runOnCreatingFilter(AbstractJob) - Method in class org.jobrunr.jobs.filters.JobFilters
 
runOnJobProcessedFilters(Job) - Method in class org.jobrunr.jobs.filters.JobFilters
 
runOnJobProcessingFilters(Job) - Method in class org.jobrunr.jobs.filters.JobFilters
 
runOnStateAppliedFilters(List<Job>) - Method in class org.jobrunr.jobs.filters.JobFilters
 
runOnStateAppliedFilters(Job) - Method in class org.jobrunr.jobs.filters.JobFilters
 
runOnStateElectionFilter(List<Job>) - Method in class org.jobrunr.jobs.filters.JobFilters
 
runOnStateElectionFilter(Job) - Method in class org.jobrunr.jobs.filters.JobFilters
 
RuntimeClassNameTypeAdapterFactory<T> - Class in org.jobrunr.utils.mapper.gson
Disclaimer: taken from here https://stackoverflow.com/a/40133286/285091 with some modifications

S

save(List<Job>) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
save(List<Job>) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
save(List<Job>) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
save(List<Job>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
save(List<Job>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
save(List<Job>) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
save(List<Job>) - Method in class org.jobrunr.storage.sql.common.JobTable
 
save(List<Job>) - Method in interface org.jobrunr.storage.StorageProvider
 
save(List<Job>) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
save(Job) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
save(Job) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
save(Job) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
save(Job) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
save(Job) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
save(Job) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
save(Job) - Method in class org.jobrunr.storage.sql.common.JobTable
 
save(Job) - Method in interface org.jobrunr.storage.StorageProvider
 
save(Job) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
save(RecurringJob) - Method in class org.jobrunr.storage.sql.common.RecurringJobTable
 
saveAndRunStateRelatedJobFilters(Job) - Method in class org.jobrunr.server.BackgroundJobPerformer
 
saveRecurringJob(RecurringJob) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
saveRecurringJob(RecurringJob) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
saveRecurringJob(RecurringJob) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
saveRecurringJob(RecurringJob) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
saveRecurringJob(RecurringJob) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
saveRecurringJob(RecurringJob) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
saveRecurringJob(RecurringJob) - Method in interface org.jobrunr.storage.StorageProvider
 
saveRecurringJob(RecurringJob) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
schedule(IocJobLambda<S>, Instant) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(IocJobLambda<S>, Instant) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(IocJobLambda<S>, LocalDateTime) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(IocJobLambda<S>, LocalDateTime) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(IocJobLambda<S>, OffsetDateTime) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(IocJobLambda<S>, OffsetDateTime) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(IocJobLambda<S>, ZonedDateTime) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(IocJobLambda<S>, ZonedDateTime) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(JobLambda, Instant) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(JobLambda, Instant) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(JobLambda, LocalDateTime) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(JobLambda, LocalDateTime) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(JobLambda, OffsetDateTime) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(JobLambda, OffsetDateTime) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(JobLambda, ZonedDateTime) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
schedule(JobLambda, ZonedDateTime) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new fire-and-forget job based on the given lambda and schedules it to be enqueued at the given moment of time.
scheduleAt(Instant, String) - Method in class org.jobrunr.jobs.Job
 
SCHEDULED - org.jobrunr.jobs.states.StateName
 
ScheduledState - Class in org.jobrunr.jobs.states
 
ScheduledState() - Constructor for class org.jobrunr.jobs.states.ScheduledState
 
ScheduledState(Instant) - Constructor for class org.jobrunr.jobs.states.ScheduledState
 
ScheduledState(Instant, String) - Constructor for class org.jobrunr.jobs.states.ScheduledState
 
ScheduledThreadPoolJobRunrExecutor - Class in org.jobrunr.server.threadpool
 
ScheduledThreadPoolJobRunrExecutor(int, String) - Constructor for class org.jobrunr.server.threadpool.ScheduledThreadPoolJobRunrExecutor
 
scheduleRecurringly(String, IocJobLambda<S>, String) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new recurring job based on the given id, lambda and cron expression.
scheduleRecurringly(String, IocJobLambda<S>, String) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new recurring job based on the given id, lambda and cron expression.
scheduleRecurringly(String, IocJobLambda<S>, String, ZoneId) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new recurring job based on the given id, lambda, cron expression and ZoneId.
scheduleRecurringly(String, IocJobLambda<S>, String, ZoneId) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new recurring job based on the given id, lambda, cron expression and ZoneId.
scheduleRecurringly(String, JobLambda, String) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new recurring job based on the given id, lambda and cron expression.
scheduleRecurringly(String, JobLambda, String) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new recurring job based on the given id, lambda and cron expression.
scheduleRecurringly(String, JobLambda, String, ZoneId) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new recurring job based on the given id, lambda, cron expression and ZoneId.
scheduleRecurringly(String, JobLambda, String, ZoneId) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new recurring job based on the given id, lambda, cron expression and ZoneId.
scheduleRecurringly(IocJobLambda<S>, String) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new recurring job based on the given lambda and the given cron expression.
scheduleRecurringly(IocJobLambda<S>, String) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new recurring job based on the given lambda and the given cron expression.
scheduleRecurringly(JobLambda, String) - Static method in class org.jobrunr.scheduling.BackgroundJob
Creates a new recurring job based on the given lambda and the given cron expression.
scheduleRecurringly(JobLambda, String) - Method in class org.jobrunr.scheduling.JobScheduler
Creates a new recurring job based on the given lambda and the given cron expression.
SECOND - org.jobrunr.scheduling.cron.CronFieldType
 
SECOND - Static variable in class org.jobrunr.utils.resilience.RateLimiter
 
select(String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
selectAll() - Method in class org.jobrunr.storage.sql.common.RecurringJobTable
 
selectCount(String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
selectExists(String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
selectJobById(UUID) - Method in class org.jobrunr.storage.sql.common.JobTable
 
selectJobsByState(StateName, Instant, PageRequest) - Method in class org.jobrunr.storage.sql.common.JobTable
 
selectJobsByState(StateName, PageRequest) - Method in class org.jobrunr.storage.sql.common.JobTable
 
selectJobsScheduledBefore(Instant, PageRequest) - Method in class org.jobrunr.storage.sql.common.JobTable
 
selectOptional(Optional<T>...) - Static method in class org.jobrunr.utils.metadata.VersionRetriever
 
sendMessage(String) - Method in class org.jobrunr.dashboard.server.sse.SseExchange
 
sendObject(Object) - Method in class org.jobrunr.dashboard.sse.AbstractObjectSseExchange
 
sequential() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
sequential() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
serialize(File, JsonGenerator, SerializationContext) - Method in class org.jobrunr.utils.mapper.jsonb.serializer.FileTypeSerializer
 
serialize(OutputStream, Object) - Method in class org.jobrunr.utils.mapper.gson.GsonJsonMapper
 
serialize(OutputStream, Object) - Method in class org.jobrunr.utils.mapper.jackson.JacksonJsonMapper
 
serialize(OutputStream, Object) - Method in class org.jobrunr.utils.mapper.jsonb.JsonbJsonMapper
 
serialize(OutputStream, Object) - Method in interface org.jobrunr.utils.mapper.JsonMapper
 
serialize(Writer, Object) - Method in class org.jobrunr.utils.mapper.gson.GsonJsonMapper
 
serialize(Writer, Object) - Method in class org.jobrunr.utils.mapper.jackson.JacksonJsonMapper
 
serialize(Writer, Object) - Method in class org.jobrunr.utils.mapper.jsonb.JsonbJsonMapper
 
serialize(Writer, Object) - Method in interface org.jobrunr.utils.mapper.JsonMapper
 
serialize(Object) - Method in class org.jobrunr.utils.mapper.gson.GsonJsonMapper
 
serialize(Object) - Method in class org.jobrunr.utils.mapper.jackson.JacksonJsonMapper
 
serialize(Object) - Method in class org.jobrunr.utils.mapper.jsonb.JsonbJsonMapper
 
serialize(Object) - Method in interface org.jobrunr.utils.mapper.JsonMapper
 
serialize(Path, JsonGenerator, SerializationContext) - Method in class org.jobrunr.utils.mapper.jsonb.serializer.PathTypeSerializer
 
serialize(Duration, JsonGenerator, SerializerProvider) - Method in class org.jobrunr.utils.mapper.jackson.modules.DurationSerializer
 
serialize(Duration, JsonGenerator, SerializationContext) - Method in class org.jobrunr.utils.mapper.jsonb.serializer.DurationTypeSerializer
 
serialize(Instant, JsonGenerator, SerializerProvider) - Method in class org.jobrunr.utils.mapper.jackson.modules.InstantSerializer
 
serialize(JobParameter, JsonGenerator, SerializerProvider) - Method in class org.jobrunr.utils.mapper.jackson.modules.JobParameterSerializer
 
SerializedLambdaConverter - Class in org.jobrunr.jobs.details
 
SerializedLambdaConverter() - Constructor for class org.jobrunr.jobs.details.SerializedLambdaConverter
 
serializeJob(Job) - Method in class org.jobrunr.jobs.mappers.JobMapper
 
serializeRecurringJob(RecurringJob) - Method in class org.jobrunr.jobs.mappers.JobMapper
 
ServerSentEventHandler - Class in org.jobrunr.dashboard.server.sse
 
ServerSentEventHandler() - Constructor for class org.jobrunr.dashboard.server.sse.ServerSentEventHandler
 
ServerSentEventHandler(String) - Constructor for class org.jobrunr.dashboard.server.sse.ServerSentEventHandler
 
ServerTimedOutException - Exception in org.jobrunr.storage
 
ServerTimedOutException(BackgroundJobServerStatus, StorageException) - Constructor for exception org.jobrunr.storage.ServerTimedOutException
 
ServerZooKeeper - Class in org.jobrunr.server
 
ServerZooKeeper(BackgroundJobServer) - Constructor for class org.jobrunr.server.ServerZooKeeper
 
ServerZooKeeper.BackgroundJobServerStatusWriteModel - Class in org.jobrunr.server
 
setBitSet(BitSet, int) - Method in enum org.jobrunr.scheduling.cron.CronFieldType
 
setClassName(String) - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
setFieldUsingAutoboxing(Field, Object, Object) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
setFieldUsingAutoboxing(String, Object, Object) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
setId(UUID) - Method in class org.jobrunr.jobs.Job
 
setIsMaster(boolean) - Method in class org.jobrunr.server.JobZooKeeper
 
setJob(Job) - Static method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
setJobFilters(List<JobFilter>) - Method in class org.jobrunr.server.BackgroundJobServer
 
setJobMapper(JobMapper) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
setJobMapper(JobMapper) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
setJobMapper(JobMapper) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
setJobMapper(JobMapper) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
setJobMapper(JobMapper) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
setJobMapper(JobMapper) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
setJobMapper(JobMapper) - Method in interface org.jobrunr.storage.StorageProvider
 
setJobMapper(JobMapper) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
setJobName(String) - Method in class org.jobrunr.jobs.AbstractJob
 
setJobParameters(List<JobParameter>) - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
setJobScheduler(JobScheduler) - Static method in class org.jobrunr.scheduling.BackgroundJob
 
setMethodName(String) - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
setStaticFieldName(String) - Method in class org.jobrunr.jobs.details.JobDetailsFinderContext
 
setUpdatedAt(Instant) - Method in class org.jobrunr.jobs.states.ProcessingState
 
setValue(int) - Method in class org.jobrunr.jobs.context.JobDashboardProgressBar
 
setValue(long) - Method in class org.jobrunr.jobs.context.JobDashboardProgressBar
 
SHOULD_NOT_HAPPEN_MESSAGE - Static variable in exception org.jobrunr.JobRunrException
 
shouldNotHappenException(String) - Static method in exception org.jobrunr.JobRunrException
 
shouldNotHappenException(Throwable) - Static method in exception org.jobrunr.JobRunrException
 
signalBackgroundJobServerAlive(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
signalBackgroundJobServerAlive(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
signalBackgroundJobServerAlive(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
signalBackgroundJobServerAlive(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
signalBackgroundJobServerAlive(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
signalBackgroundJobServerAlive(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
signalBackgroundJobServerAlive(BackgroundJobServerStatus) - Method in interface org.jobrunr.storage.StorageProvider
 
signalBackgroundJobServerAlive(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
signalBackgroundJobServerStopped(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.InMemoryStorageProvider
 
signalBackgroundJobServerStopped(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchStorageProvider
 
signalBackgroundJobServerStopped(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
signalBackgroundJobServerStopped(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisStorageProvider
 
signalBackgroundJobServerStopped(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisStorageProvider
 
signalBackgroundJobServerStopped(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.sql.common.DefaultSqlStorageProvider
 
signalBackgroundJobServerStopped(BackgroundJobServerStatus) - Method in interface org.jobrunr.storage.StorageProvider
 
signalBackgroundJobServerStopped(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.ThreadSafeStorageProvider
 
signalServerAlive(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
signalServerStopped(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.sql.common.BackgroundJobServerTable
 
single() - Static method in class org.jobrunr.utils.streams.StreamUtils
 
SingleIntOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
SingleIntOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.SingleIntOperandInstruction
 
skip(long) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
skip(long) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
SKIP_CREATE - org.jobrunr.storage.sql.common.DefaultSqlStorageProvider.DatabaseOptions
 
sorted() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
sorted() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
sorted(Comparator<? super T>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
sorted(Comparator<? super T>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
spliterator() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
spliterator() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
Sql<T> - Class in org.jobrunr.storage.sql.common.db
 
Sql() - Constructor for class org.jobrunr.storage.sql.common.db.Sql
 
SqLiteStorageProvider - Class in org.jobrunr.storage.sql.sqlite
 
SqLiteStorageProvider(DataSource) - Constructor for class org.jobrunr.storage.sql.sqlite.SqLiteStorageProvider
 
SqlPageRequestMapper - Class in org.jobrunr.storage.sql.common
 
SqlPageRequestMapper() - Constructor for class org.jobrunr.storage.sql.common.SqlPageRequestMapper
 
SqlResultSet - Class in org.jobrunr.storage.sql.common.db
 
SqlResultSet(ResultSet) - Constructor for class org.jobrunr.storage.sql.common.db.SqlResultSet
 
SQLServerStorageProvider - Class in org.jobrunr.storage.sql.sqlserver
 
SQLServerStorageProvider(DataSource) - Constructor for class org.jobrunr.storage.sql.sqlserver.SQLServerStorageProvider
 
SqlSpliterator - Class in org.jobrunr.storage.sql.common.db
 
SqlSpliterator(DataSource, String, Consumer<PreparedStatement>) - Constructor for class org.jobrunr.storage.sql.common.db.SqlSpliterator
 
SqlStorageProvider - Interface in org.jobrunr.storage.sql
 
SqlStorageProviderFactory - Class in org.jobrunr.storage.sql.common
 
SqlStorageProviderFactory() - Constructor for class org.jobrunr.storage.sql.common.SqlStorageProviderFactory
 
SseExchange - Class in org.jobrunr.dashboard.server.sse
 
SseExchange(HttpExchange) - Constructor for class org.jobrunr.dashboard.server.sse.SseExchange
 
start() - Method in class org.jobrunr.dashboard.JobRunrDashboardWebServer
 
start() - Method in class org.jobrunr.dashboard.server.TeenyWebServer
 
start() - Method in class org.jobrunr.server.BackgroundJobServer
 
start() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerMBean
 
start() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
start() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
start() - Method in interface org.jobrunr.server.threadpool.JobRunrExecutor
 
start() - Method in class org.jobrunr.server.threadpool.ScheduledThreadPoolJobRunrExecutor
 
start() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
startProcessing(Job, Thread) - Method in class org.jobrunr.server.JobZooKeeper
 
startProcessingOn(BackgroundJobServer) - Method in class org.jobrunr.jobs.Job
 
StateName - Enum in org.jobrunr.jobs.states
 
StaticFieldBackgroundJobWorker(Job) - Constructor for class org.jobrunr.server.runner.BackgroundStaticJobWithoutIocRunner.StaticFieldBackgroundJobWorker
 
StaticFileHttpHandler - Class in org.jobrunr.dashboard.server.http
 
StaticFileHttpHandler(String, String) - Constructor for class org.jobrunr.dashboard.server.http.StaticFileHttpHandler
 
StaticFileHttpHandler(String, String, boolean) - Constructor for class org.jobrunr.dashboard.server.http.StaticFileHttpHandler
 
statusCode(int) - Method in class org.jobrunr.dashboard.server.http.HttpResponse
 
stop() - Method in class org.jobrunr.dashboard.JobRunrDashboardWebServer
 
stop() - Method in class org.jobrunr.dashboard.server.TeenyWebServer
 
stop() - Method in class org.jobrunr.server.BackgroundJobServer
 
stop() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerMBean
 
stop() - Method in interface org.jobrunr.server.jmx.BackgroundJobServerStatusMBean
 
stop() - Method in class org.jobrunr.server.JobZooKeeper
 
stop() - Method in class org.jobrunr.server.ServerZooKeeper.BackgroundJobServerStatusWriteModel
 
stop() - Method in class org.jobrunr.server.ServerZooKeeper
 
stop() - Method in interface org.jobrunr.server.threadpool.JobRunrExecutor
 
stop() - Method in class org.jobrunr.server.threadpool.ScheduledThreadPoolJobRunrExecutor
 
stop() - Method in class org.jobrunr.storage.BackgroundJobServerStatus
 
stopProcessing(Job) - Method in class org.jobrunr.server.JobZooKeeper
 
StorageException - Exception in org.jobrunr.storage
 
StorageException(String) - Constructor for exception org.jobrunr.storage.StorageException
 
StorageException(String, Throwable) - Constructor for exception org.jobrunr.storage.StorageException
 
StorageException(Throwable) - Constructor for exception org.jobrunr.storage.StorageException
 
StorageProvider - Interface in org.jobrunr.storage
The StorageProvider allows to store, retrieve and delete background jobs.
StorageProviderChangeListener - Interface in org.jobrunr.storage.listeners
Marker interface for listeners to JobStorage changes
StorageProviderUtils - Class in org.jobrunr.storage
 
StorageProviderUtils.BackgroundJobServers - Class in org.jobrunr.storage
 
StorageProviderUtils.Jobs - Class in org.jobrunr.storage
 
StorageProviderUtils.JobStats - Class in org.jobrunr.storage
 
StorageProviderUtils.RecurringJobs - Class in org.jobrunr.storage
 
StoreVariableInstruction - Class in org.jobrunr.jobs.details.instructions
 
StoreVariableInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.StoreVariableInstruction
 
StreamUtils - Class in org.jobrunr.utils.streams
 
StringTypeAutoboxer - Class in org.jobrunr.utils.reflection.autobox
 
StringTypeAutoboxer() - Constructor for class org.jobrunr.utils.reflection.autobox.StringTypeAutoboxer
 
StringUtils - Class in org.jobrunr.utils
 
succeeded() - Method in class org.jobrunr.jobs.Job
 
succeeded(Job) - Static method in class org.jobrunr.server.concurrent.ConcurrentJobModificationResolveResult
 
SUCCEEDED - org.jobrunr.jobs.states.StateName
 
SucceededState - Class in org.jobrunr.jobs.states
 
SucceededState() - Constructor for class org.jobrunr.jobs.states.SucceededState
 
SucceededState(Duration, Duration) - Constructor for class org.jobrunr.jobs.states.SucceededState
 
supports(Class<?>) - Method in class org.jobrunr.utils.reflection.autobox.BooleanTypeAutoboxer
 
supports(Class<?>) - Method in class org.jobrunr.utils.reflection.autobox.DoubleTypeAutoboxer
 
supports(Class<?>) - Method in class org.jobrunr.utils.reflection.autobox.EnumAutoboxer
 
supports(Class<?>) - Method in class org.jobrunr.utils.reflection.autobox.FloatTypeAutoboxer
 
supports(Class<?>) - Method in class org.jobrunr.utils.reflection.autobox.InstantTypeAutoboxer
 
supports(Class<?>) - Method in class org.jobrunr.utils.reflection.autobox.IntegerTypeAutoboxer
 
supports(Class<?>) - Method in class org.jobrunr.utils.reflection.autobox.LongTypeAutoboxer
 
supports(Class<?>) - Method in class org.jobrunr.utils.reflection.autobox.StringTypeAutoboxer
 
supports(Class<?>) - Method in interface org.jobrunr.utils.reflection.autobox.TypeAutoboxer
 
supports(Class<?>) - Method in class org.jobrunr.utils.reflection.autobox.UUIDTypeAutoboxer
 
supports(Job) - Method in interface org.jobrunr.server.runner.BackgroundJobRunner
 
supports(Job) - Method in class org.jobrunr.server.runner.BackgroundJobWithIocRunner
 
supports(Job) - Method in class org.jobrunr.server.runner.BackgroundJobWithoutIocRunner
 
supports(Job) - Method in class org.jobrunr.server.runner.BackgroundStaticJobWithoutIocRunner
 

T

TeenyHttpHandler - Interface in org.jobrunr.dashboard.server
 
TeenyMatchUrl - Class in org.jobrunr.dashboard.server.http.url
 
TeenyMatchUrl(String) - Constructor for class org.jobrunr.dashboard.server.http.url.TeenyMatchUrl
 
TeenyRequestUrl - Class in org.jobrunr.dashboard.server.http.url
 
TeenyRequestUrl(String, Map<String, String>) - Constructor for class org.jobrunr.dashboard.server.http.url.TeenyRequestUrl
 
TeenyWebServer - Class in org.jobrunr.dashboard.server
 
TeenyWebServer(int) - Constructor for class org.jobrunr.dashboard.server.TeenyWebServer
 
TEXT_CSS - Static variable in class org.jobrunr.dashboard.server.http.ContentType
 
TEXT_HTML - Static variable in class org.jobrunr.dashboard.server.http.ContentType
 
TEXT_JAVASCRIPT - Static variable in class org.jobrunr.dashboard.server.http.ContentType
 
TEXT_PLAIN - Static variable in class org.jobrunr.dashboard.server.http.ContentType
 
ThreadSafeStorageProvider - Class in org.jobrunr.storage
 
ThreadSafeStorageProvider(StorageProvider) - Constructor for class org.jobrunr.storage.ThreadSafeStorageProvider
 
toArray() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
toArray() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
toArray(IntFunction<A[]>) - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
toArray(IntFunction<A[]>) - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
toBackgroundJobServerStatus(Document) - Method in class org.jobrunr.storage.nosql.mongo.BackgroundJobServerStatusDocumentMapper
 
toBackgroundJobServerStatus(SearchHit) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchDocumentMapper
 
toClass(String) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
toClassFromPath(Path) - Static method in class org.jobrunr.utils.reflection.ReflectionUtils
 
toEnqueuedJob() - Method in class org.jobrunr.jobs.RecurringJob
 
toFQClassName(String) - Static method in class org.jobrunr.jobs.details.JobDetailsGeneratorUtils
 
toFQResource(String) - Static method in class org.jobrunr.jobs.details.JobDetailsGeneratorUtils
 
toInsertDocument(Job) - Method in class org.jobrunr.storage.nosql.mongo.JobDocumentMapper
 
toInsertDocument(RecurringJob) - Method in class org.jobrunr.storage.nosql.mongo.JobDocumentMapper
 
toInsertDocument(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.mongo.BackgroundJobServerStatusDocumentMapper
 
toJob(Document) - Method in class org.jobrunr.storage.nosql.mongo.JobDocumentMapper
 
toJob(GetResponse) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchDocumentMapper
 
toJob(SearchHit) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchDocumentMapper
 
toJobDetails(T) - Method in class org.jobrunr.jobs.details.JobDetailsAsmGenerator
 
toJobDetails(T) - Method in interface org.jobrunr.jobs.details.JobDetailsGenerator
 
toJobDetails(T, IocJobLambdaFromStream<S, T>) - Method in class org.jobrunr.jobs.details.JobDetailsAsmGenerator
 
toJobDetails(T, IocJobLambdaFromStream<S, T>) - Method in interface org.jobrunr.jobs.details.JobDetailsGenerator
 
toJobDetails(T, JobLambdaFromStream<T>) - Method in class org.jobrunr.jobs.details.JobDetailsAsmGenerator
 
toJobDetails(T, JobLambdaFromStream<T>) - Method in interface org.jobrunr.jobs.details.JobDetailsGenerator
 
toJson(Object) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
toJson(Object, OutputStream) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
toJson(Object, Writer) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
toJson(Object, Type) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
toJson(Object, Type, OutputStream) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
toJson(Object, Type, Writer) - Method in class org.jobrunr.utils.mapper.jsonb.JobRunrJsonb
 
toMicroSeconds(Instant) - Static method in class org.jobrunr.storage.nosql.redis.RedisUtilities
 
toMongoId(String) - Static method in class org.jobrunr.storage.nosql.mongo.MongoDBStorageProvider
 
toPathsOnClasspath(Class<?>, String...) - Static method in class org.jobrunr.utils.ClassPathUtils
 
toPathsOnClasspath(Package, String...) - Static method in class org.jobrunr.utils.ClassPathUtils
 
toPathsOnClasspath(String...) - Static method in class org.jobrunr.utils.ClassPathUtils
 
toRecurringJob(Document) - Method in class org.jobrunr.storage.nosql.mongo.JobDocumentMapper
 
toRecurringJob(SearchHit) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchDocumentMapper
 
toRequestUrl(String) - Method in class org.jobrunr.dashboard.server.http.url.TeenyMatchUrl
 
toScheduledJob() - Method in class org.jobrunr.jobs.RecurringJob
 
toSerializedLambda(T) - Method in class org.jobrunr.jobs.details.SerializedLambdaConverter
 
toString() - Method in class org.jobrunr.jobs.Job
 
toString() - Method in class org.jobrunr.jobs.JobId
 
toString() - Method in class org.jobrunr.storage.PageRequest
 
toUpdateDocument(Job) - Method in class org.jobrunr.storage.nosql.mongo.JobDocumentMapper
 
toUpdateDocument(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.mongo.BackgroundJobServerStatusDocumentMapper
 
toUpdateOneModel(Job) - Method in class org.jobrunr.storage.nosql.mongo.JobDocumentMapper
 
toXContentBuilder(Job) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchDocumentMapper
 
toXContentBuilder(RecurringJob) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchDocumentMapper
 
toXContentBuilderForInsert(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchDocumentMapper
 
toXContentBuilderForUpdate(BackgroundJobServerStatus) - Method in class org.jobrunr.storage.nosql.elasticsearch.ElasticSearchDocumentMapper
 
trace(String) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
trace(String, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
trace(String, Object...) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
trace(String, Object, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
trace(String, Throwable) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
trace(Marker, String) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
trace(Marker, String, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
trace(Marker, String, Object...) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
trace(Marker, String, Object, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
trace(Marker, String, Throwable) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
tryAdvance(Consumer<? super SqlResultSet>) - Method in class org.jobrunr.storage.sql.common.db.SqlSpliterator
 
trySplit() - Method in class org.jobrunr.storage.sql.common.db.SqlSpliterator
 
type - Variable in class org.jobrunr.jobs.details.instructions.VisitTypeInstruction
 
TYPE_FIELD_NAME - Static variable in class org.jobrunr.utils.mapper.gson.RuntimeClassNameTypeAdapterFactory
 
TypeAutoboxer<T> - Interface in org.jobrunr.utils.reflection.autobox
 

U

unlock() - Method in class org.jobrunr.utils.resilience.Lock
 
unlock() - Method in class org.jobrunr.utils.resilience.MultiLock
 
unordered() - Method in class org.jobrunr.storage.nosql.redis.JedisRedisPipelinedStream
 
unordered() - Method in class org.jobrunr.storage.nosql.redis.LettuceRedisPipelinedStream
 
update(String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
update(Connection, String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
update(Connection, T, String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
update(T, String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
updateAll(List<T>, String) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
updateMigrationsTable(Connection, Path) - Method in class org.jobrunr.storage.sql.common.DatabaseCreator
 
updateProcessing() - Method in class org.jobrunr.jobs.Job
 
UrlParamPathPart - Class in org.jobrunr.dashboard.server.http.url
 
UrlParamPathPart(String) - Constructor for class org.jobrunr.dashboard.server.http.url.UrlParamPathPart
 
UrlPathPart - Interface in org.jobrunr.dashboard.server.http.url
 
UrlStringPathPart - Class in org.jobrunr.dashboard.server.http.url
 
UrlStringPathPart(String) - Constructor for class org.jobrunr.dashboard.server.http.url.UrlStringPathPart
 
useBackgroundJobServer(BackgroundJobServer) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides JobRunr with the given BackgroundJobServer
useBackgroundJobServerIf(boolean, BackgroundJobServer) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides JobRunr with the given BackgroundJobServer if the guard is true
useDashboard() - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a dashboard on port 8000
useDashboard(int) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a dashboard on the given port
useDashboard(JobRunrDashboardWebServerConfiguration) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a dashboard using the given JobRunrDashboardWebServerConfiguration
useDashboardIf(boolean) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a dashboard on port 8000 if the guard is true
useDashboardIf(boolean, int) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a dashboard on the given port if the guard is true
useDashboardIf(boolean, JobRunrDashboardWebServerConfiguration) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a dashboard using the given JobRunrDashboardWebServerConfiguration if the guard is true
useDefaultBackgroundJobServer() - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a default BackgroundJobServer that is configured using a number of threads depending on the amount of CPU.
useDefaultBackgroundJobServer(int) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a default BackgroundJobServer that is configured using a given number of threads.
useDefaultBackgroundJobServer(BackgroundJobServerConfiguration) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a default BackgroundJobServer that is configured using the given BackgroundJobServerConfiguration
useDefaultBackgroundJobServerIf(boolean) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a default BackgroundJobServer if the guard is true and that is configured using a number of threads depending on the amount of CPU.
useDefaultBackgroundJobServerIf(boolean, int) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a default BackgroundJobServer if the guard is true and that is configured using a given number of threads.
useDefaultBackgroundJobServerIf(boolean, BackgroundJobServerConfiguration) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Provides a default BackgroundJobServer if the guard is true and that is configured using the given BackgroundJobServerConfiguration
useJmxExtensions() - Method in class org.jobrunr.configuration.JobRunrConfiguration
If called, this method will register JMX Extensions to monitor JobRunr via JMX
useJobActivator(JobActivator) - Method in class org.jobrunr.configuration.JobRunrConfiguration
The JobActivator is used to resolve jobs from the IoC framework
useStorageProvider(StorageProvider) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Allows to set the StorageProvider that JobRunr will use.
using(DataSource) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
using(DataSource) - Static method in class org.jobrunr.storage.sql.common.SqlStorageProviderFactory
 
usingStandardBackgroundJobServerConfiguration() - Static method in class org.jobrunr.server.BackgroundJobServerConfiguration
This returns the default configuration with the BackgroundJobServer with a poll interval of 15 seconds and a worker count based on the CPU
usingStandardDashboardConfiguration() - Static method in class org.jobrunr.dashboard.JobRunrDashboardWebServerConfiguration
This returns the default configuration with the JobRunrDashboard running on port 8000
UUIDTypeAutoboxer - Class in org.jobrunr.utils.reflection.autobox
 
UUIDTypeAutoboxer() - Constructor for class org.jobrunr.utils.reflection.autobox.UUIDTypeAutoboxer
 

V

validateTables() - Method in class org.jobrunr.storage.sql.common.DatabaseCreator
 
value() - Method in annotation type org.jobrunr.utils.annotations.Because
 
value() - Method in annotation type org.jobrunr.utils.annotations.VisibleFor
 
valueOf(String) - Static method in enum org.jobrunr.jobs.context.JobDashboardLogger.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jobrunr.jobs.states.StateName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jobrunr.scheduling.cron.CronFieldType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jobrunr.storage.PageRequest.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jobrunr.storage.sql.common.DefaultSqlStorageProvider.DatabaseOptions
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.jobrunr.jobs.context.JobDashboardLogger.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jobrunr.jobs.states.StateName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jobrunr.scheduling.cron.CronFieldType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jobrunr.storage.PageRequest.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jobrunr.storage.sql.common.DefaultSqlStorageProvider.DatabaseOptions
Returns an array containing the constants of this enum type, in the order they are declared.
variable - Variable in class org.jobrunr.jobs.details.instructions.VisitLocalVariableInstruction
 
VersionRetriever - Class in org.jobrunr.utils.metadata
 
VisibleFor - Annotation Type in org.jobrunr.utils.annotations
Documents why a class, field or method is visible
VisitFieldInstruction - Class in org.jobrunr.jobs.details.instructions
 
VisitFieldInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.VisitFieldInstruction
 
VisitLocalVariableInstruction - Class in org.jobrunr.jobs.details.instructions
 
VisitLocalVariableInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.VisitLocalVariableInstruction
 
VisitMethodInstruction - Class in org.jobrunr.jobs.details.instructions
 
VisitMethodInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.VisitMethodInstruction
 
VisitTypeInstruction - Class in org.jobrunr.jobs.details.instructions
 
VisitTypeInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.VisitTypeInstruction
 

W

warn(String) - Method in class org.jobrunr.jobs.context.JobDashboardLogger
 
warn(String) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
warn(String, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
warn(String, Object...) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
warn(String, Object, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
warn(String, Throwable) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
warn(Marker, String) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
warn(Marker, String, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
warn(Marker, String, Object...) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
warn(Marker, String, Object, Object) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
warn(Marker, String, Throwable) - Method in class org.jobrunr.jobs.context.JobRunrDashboardLogger
 
WARN - org.jobrunr.jobs.context.JobDashboardLogger.Level
 
weekly() - Static method in class org.jobrunr.scheduling.cron.Cron
 
weekly(DayOfWeek) - Static method in class org.jobrunr.scheduling.cron.Cron
 
weekly(DayOfWeek, int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
weekly(DayOfWeek, int, int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
with(String, Enum<?>) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
with(String, Object) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
with(String, Function<T, Object>) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
withAwaitingOn(UUID) - Method in class org.jobrunr.storage.sql.common.JobTable
 
withExceptionMapping(Class<T>, ExceptionHandler<T>) - Method in class org.jobrunr.dashboard.server.http.RestHttpHandler
 
withId(String) - Method in class org.jobrunr.storage.sql.common.RecurringJobTable
 
withId(UUID) - Method in class org.jobrunr.storage.sql.common.JobTable
 
withJobFilter(JobFilter...) - Method in class org.jobrunr.configuration.JobRunrConfiguration
Allows to set extra JobFilters or to provide another implementation of the RetryFilter
withOrderLimitAndOffset(String, int, long) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
withOrderLimitAndOffset(String, int, long) - Method in class org.jobrunr.storage.sql.common.JobTable
 
withoutLimits() - Method in class org.jobrunr.utils.resilience.RateLimiter.Builder
 
withoutType() - Static method in class org.jobrunr.storage.sql.common.db.Sql
 
withPriority(int) - Method in class org.jobrunr.storage.sql.common.JobTable
 
withScheduledAt(Instant) - Method in class org.jobrunr.storage.sql.common.JobTable
 
withState(StateName) - Method in class org.jobrunr.storage.sql.common.JobTable
 
withUpdatedBefore(Instant) - Method in class org.jobrunr.storage.sql.common.JobTable
 
withVersion(Function<T, Integer>) - Method in class org.jobrunr.storage.sql.common.db.Sql
 
WorkDistributionStrategy - Interface in org.jobrunr.server.strategy
 
write(JsonWriter, Object) - Method in class org.jobrunr.utils.mapper.gson.ClassNameObjectTypeAdapter
 
write(JsonWriter, Path) - Method in class org.jobrunr.utils.mapper.gson.PathAdapter
 
write(JsonWriter, Duration) - Method in class org.jobrunr.utils.mapper.gson.DurationAdapter
 
write(JsonWriter, Instant) - Method in class org.jobrunr.utils.mapper.gson.InstantAdapter
 

Y

yearly() - Static method in class org.jobrunr.scheduling.cron.Cron
 
yearly(int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
yearly(int, int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
yearly(int, int, int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
yearly(int, int, int, int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
yearly(Month) - Static method in class org.jobrunr.scheduling.cron.Cron
 
yearly(Month, int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
yearly(Month, int, int) - Static method in class org.jobrunr.scheduling.cron.Cron
 
yearly(Month, int, int, int) - Static method in class org.jobrunr.scheduling.cron.Cron
 

Z

ZeroOperandInstruction - Class in org.jobrunr.jobs.details.instructions
 
ZeroOperandInstruction(JobDetailsFinderContext) - Constructor for class org.jobrunr.jobs.details.instructions.ZeroOperandInstruction
 

_

_HEADER_NAME - Static variable in class org.jobrunr.dashboard.server.http.ContentType
 
A B C D E F G H I J L M N O P Q R S T U V W Y Z _ 
All Classes All Packages