Class ContentEngineConfiguration
- java.lang.Object
-
- org.flowable.common.engine.impl.AbstractEngineConfiguration
-
- com.flowable.content.engine.ContentEngineConfiguration
-
- All Implemented Interfaces:
CoreContentEngineConfigurationApi
,org.flowable.content.api.ContentEngineConfigurationApi
- Direct Known Subclasses:
SpringContentEngineConfiguration
,StandaloneContentEngineConfiguration
public class ContentEngineConfiguration extends org.flowable.common.engine.impl.AbstractEngineConfiguration implements CoreContentEngineConfigurationApi
-
-
Field Summary
Fields Modifier and Type Field Description protected boolean
addDefaultExceptionHandler
protected org.flowable.job.service.impl.asyncexecutor.AsyncExecutor
asyncExecutor
protected boolean
asyncExecutorActivate
Boolean flag to be set to activate theAsyncExecutor
automatically after the engine has booted up.protected boolean
asyncExecutorAllowCoreThreadTimeout
Whether or not core threads can time out (which is needed to scale down the threads).protected int
asyncExecutorAsyncJobLockTimeInMillis
The amount of time (in milliseconds) an async job is locked when acquired by the async executor.protected int
asyncExecutorCorePoolSize
The minimal number of threads that are kept alive in the threadpool for job execution.protected int
asyncExecutorDefaultAsyncJobAcquireWaitTime
The time (in milliseconds) the async job acquisition thread will wait to execute the next acquirement query.protected int
asyncExecutorDefaultQueueSizeFullWaitTime
The time (in milliseconds) the async job (both timer and async continuations) acquisition thread will wait when the queue is full to execute the next query.protected int
asyncExecutorDefaultTimerJobAcquireWaitTime
The time (in milliseconds) the timer acquisition thread will wait to execute the next acquirement query.protected org.flowable.job.service.impl.asyncexecutor.ExecuteAsyncRunnableFactory
asyncExecutorExecuteAsyncRunnableFactory
Allows to define a custom factory for creating theRunnable
that is executed by the async executor.protected java.lang.String
asyncExecutorLockOwner
When a job is acquired, it is locked so other async executors can't lock and execute it.protected int
asyncExecutorMaxAsyncJobsDuePerAcquisition
The number of async jobs that are acquired during one query (before a job is executed, an acquirement thread fetches jobs from the database and puts them on the queue).protected int
asyncExecutorMaxPoolSize
The maximum number of threads that are created in the threadpool for job execution.protected boolean
asyncExecutorMessageQueueMode
Experimental!protected int
asyncExecutorNumberOfRetries
The number of retries for a job.protected int
asyncExecutorResetExpiredJobsInterval
The amount of time (in milliseconds) that is between two consecutive checks of 'expired jobs'.protected int
asyncExecutorResetExpiredJobsMaxTimeout
The amount of time (in milliseconds) a job can maximum be in the 'executable' state before being deemed expired.protected int
asyncExecutorResetExpiredJobsPageSize
The defaultAsyncExecutor
has a 'cleanup' thread that resets expired jobs so they can be re-acquired by other executors.protected long
asyncExecutorSecondsToWaitOnShutdown
The time (in seconds) that is waited to gracefully shut down the threadpool used for job execution when a shutdown on the executor (or engine) is requested.protected java.lang.String
asyncExecutorTenantId
Tenant for the async executor, if any.protected java.util.concurrent.ThreadFactory
asyncExecutorThreadFactory
The thread factory that the async task executor should use.protected long
asyncExecutorThreadKeepAliveTime
The time (in milliseconds) a thread used for job execution must be kept alive before it is destroyed.protected java.util.concurrent.BlockingQueue<java.lang.Runnable>
asyncExecutorThreadPoolQueue
The queue onto which jobs will be placed before they are actually executed.protected int
asyncExecutorThreadPoolQueueSize
The size of the queue on which jobs to be executed are placed, before they are actually executed.protected int
asyncFailedJobWaitTime
Defines the default wait time for a failed async job in secondsprotected org.flowable.job.service.impl.asyncexecutor.AsyncExecutor
asyncHistoryExecutor
protected org.flowable.job.service.impl.history.async.AsyncHistoryListener
asyncHistoryListener
protected org.flowable.common.engine.api.async.AsyncTaskExecutor
asyncTaskExecutor
protected ContentAsyncHistoryManager
contentAsyncHistoryManager
protected ContentCryptoHandler
contentCryptoHandler
protected java.lang.String
contentEngineName
protected CoreContentItemContentObjectStorageMetadataProvider
contentItemContentObjectStorageMetadataProvider
protected ContentItemDataManager
contentItemDataManager
protected ContentItemEntityManager
contentItemEntityManager
protected org.flowable.content.api.ContentManagementService
contentManagementService
protected ContentRenditionManager
contentRenditionManager
protected java.lang.String
contentRootFolder
protected CoreContentService
contentService
protected org.flowable.content.api.ContentStorage
contentStorage
protected boolean
createContentRootFolder
protected java.util.List<org.flowable.job.service.impl.asyncexecutor.AsyncRunnableExecutionExceptionHandler>
customAsyncRunnableExecutionExceptionHandlers
protected java.util.List<org.flowable.job.service.JobHandler>
customJobHandlers
protected java.util.List<org.flowable.variable.api.types.VariableType>
customPostVariableTypes
protected java.util.List<org.flowable.variable.api.types.VariableType>
customPreVariableTypes
protected DatabaseContentObjectDataManager
databaseContentObjectDataManager
protected DatabaseContentObjectEntityManager
databaseContentObjectEntityManager
static java.lang.String
DEFAULT_MYBATIS_MAPPING_FILE
protected int
defaultFailedJobWaitTime
Define the default wait time for a failed job in secondsprotected DocumentDeploymentManager
deploymentManager
protected org.flowable.common.engine.impl.persistence.deploy.DeploymentCache<DocumentDefinitionCacheEntry>
documentDefinitionCache
protected int
documentDefinitionCacheLimit
protected DocumentDefinitionDataManager
documentDefinitionDataManager
protected DocumentDefinitionDeployer
documentDefinitionDeployer
protected DocumentDefinitionEntityManager
documentDefinitionEntityManager
protected DocumentDeploymentDataManager
documentDeploymentDataManager
protected DocumentDeploymentEntityManager
documentDeploymentEntityManager
protected DocumentRepositoryService
documentRepositoryService
protected DocumentResourceConverter
documentResourceConverter
protected DocumentResourceDataManager
documentResourceDataManager
protected DocumentResourceEntityManager
documentResourceEntityManager
protected java.util.List<java.lang.String>
enginesBuild
protected boolean
executeServiceSchemaManagers
protected org.flowable.job.service.impl.asyncexecutor.FailedJobCommandFactory
failedJobCommandFactory
protected org.flowable.job.service.InternalJobManager
internalJobManager
protected org.flowable.job.service.InternalJobParentStateResolver
internalJobParentStateResolver
protected boolean
isAsyncExecutorAsyncJobAcquisitionEnabled
Flags to control which threads (when using the default threadpool-based async executor) are started.protected boolean
isAsyncExecutorResetExpiredJobsEnabled
protected boolean
isAsyncHistoryEnabled
protected java.lang.String
jobExecutionScope
protected java.util.Map<java.lang.String,org.flowable.job.service.JobHandler>
jobHandlers
protected org.flowable.job.service.impl.asyncexecutor.JobManager
jobManager
protected org.flowable.common.engine.impl.db.SchemaManager
jobSchemaManager
protected org.flowable.job.service.JobServiceConfiguration
jobServiceConfiguration
protected boolean
jsonVariableTypeTrackObjects
This flag determines whether variables of the type 'json' and 'longJson' will be tracked.static java.lang.String
LIQUIBASE_CHANGELOG_PREFIX
protected int
lockTimeAsyncJobWaitTime
Define the default lock time for an async job in seconds.protected static org.slf4j.Logger
LOGGER
protected MetadataInstanceDataManager
metadataInstanceDataManager
protected MetadataInstanceEntityManager
metadataInstanceEntityManager
protected MetadataService
metadataService
protected com.fasterxml.jackson.databind.ObjectMapper
objectMapper
protected java.util.List<RenditionConverter>
renditionConverters
protected RenditionItemContentObjectStorageMetadataProvider
renditionItemContentObjectStorageMetadataProvider
protected RenditionItemDataManager
renditionItemDataManager
protected RenditionItemEntityManager
renditionItemEntityManager
protected RenditionService
renditionService
protected boolean
serializableVariableTypeTrackDeserializedObjects
protected boolean
shutdownAsyncTaskExecutor
protected org.flowable.variable.api.types.VariableTypes
variableTypes
-
Fields inherited from class org.flowable.common.engine.impl.AbstractEngineConfiguration
additionalEventDispatchActions, agendaOperationRunner, allConfigurators, alwaysLookupLatestDefinitionVersion, beans, byteArrayDataManager, byteArrayEntityManager, classLoader, clock, commandContextFactory, commandExecutor, commandInterceptors, commandInvoker, commonSchemaManager, configurators, customMybatisInterceptors, customMybatisMappers, customMybatisXMLMappers, customPostCommandInterceptors, customPostDeployers, customPreCommandInterceptors, customPreDeployers, customSessionFactories, DATABASE_TYPE_COCKROACHDB, DATABASE_TYPE_DB2, DATABASE_TYPE_H2, DATABASE_TYPE_HSQL, DATABASE_TYPE_MSSQL, DATABASE_TYPE_MYSQL, DATABASE_TYPE_ORACLE, DATABASE_TYPE_POSTGRES, databaseCatalog, databaseSchema, databaseSchemaUpdate, databaseTablePrefix, databaseType, databaseTypeMappings, databaseWildcardEscapeCharacter, dataSource, dataSourceJndiName, DB_SCHEMA_UPDATE_CREATE, DB_SCHEMA_UPDATE_CREATE_DROP, DB_SCHEMA_UPDATE_DROP_CREATE, DB_SCHEMA_UPDATE_FALSE, DB_SCHEMA_UPDATE_TRUE, dbSqlSessionFactory, DEFAULT_GENERIC_MAX_LENGTH_STRING, DEFAULT_MAX_NR_OF_STATEMENTS_BULK_INSERT_SQL_SERVER, DEFAULT_ORACLE_MAX_LENGTH_STRING, defaultCommandConfig, defaultCommandInterceptors, defaultTenantProvider, dependentEngineMybatisTypeAliasConfigs, dependentEngineMybatisTypeHandlerConfigs, dependentEngineMyBatisXmlMappers, deployers, enableConfiguratorServiceLoader, enableEventDispatcher, enableLogSqlExecutionTime, engineConfigurations, engineLifecycleListeners, eventDispatcher, eventListeners, eventRegistryConfigurator, eventRegistryEventConsumers, fallbackToDefaultTenant, forceCloseMybatisConnectionPool, idGenerator, idmEngineConfigurator, isBulkInsertEnabled, isDbHistoryUsed, jdbcDefaultTransactionIsolationLevel, jdbcDriver, jdbcMaxActiveConnections, jdbcMaxCheckoutTime, jdbcMaxIdleConnections, jdbcMaxWaitTime, jdbcPassword, jdbcPingConnectionNotUsedFor, jdbcPingEnabled, jdbcPingQuery, jdbcUrl, jdbcUsername, lockPollRate, logger, loggingListener, maxLengthStringVariableType, maxNrOfStatementsInBulkInsert, mybatisMappingFile, NO_TENANT_ID, PRODUCT_NAME_CRDB, PRODUCT_NAME_POSTGRES, propertyDataManager, propertyEntityManager, schemaCommandConfig, schemaLockWaitTime, schemaManagementCmd, schemaManager, serviceConfigurations, sessionFactories, sqlSessionFactory, tableDataManager, tablePrefixIsSchema, transactionContextFactory, transactionFactory, transactionsExternallyManaged, typedEventListeners, useClassForNameClassLoading, useLockForDatabaseSchemaUpdate, usePrefixId, usingRelationalDatabase, usingSchemaMgmt, xmlEncoding
-
-
Constructor Summary
Constructors Constructor Description ContentEngineConfiguration()
-
Method Summary
-
Methods inherited from class org.flowable.common.engine.impl.AbstractEngineConfiguration
addConfigurator, addCustomSessionFactory, addEngineConfiguration, addEngineLifecycleListener, addEventRegistryEventConsumer, addServiceConfiguration, addSessionFactory, close, configuratorsAfterInit, configuratorsBeforeInit, defaultInitDbSqlSessionFactoryEntitySettings, getAdditionalDefaultCommandInterceptors, getAdditionalEventDispatchActions, getAgendaOperationRunner, getAllConfigurators, getBeans, getByteArrayDataManager, getByteArrayEntityManager, getClassLoader, getClock, getCommandContextFactory, getCommandExecutor, getCommandInterceptors, getCommandInvoker, getCommonSchemaManager, getConfigurators, getCustomMybatisInterceptors, getCustomMybatisMappers, getCustomMybatisXMLMappers, getCustomPostCommandInterceptors, getCustomPostDeployers, getCustomPreCommandInterceptors, getCustomPreDeployers, getCustomSessionFactories, getDatabaseCatalog, getDatabaseSchema, getDatabaseSchemaUpdate, getDatabaseTablePrefix, getDatabaseType, getDatabaseWildcardEscapeCharacter, getDataSource, getDataSourceJndiName, getDbSqlSessionFactory, getDefaultCommandConfig, getDefaultCommandInterceptors, getDefaultDatabaseTypeMappings, getDefaultTenantProvider, getDefaultTenantValue, getDependentEngineMybatisTypeAliasConfigs, getDependentEngineMybatisTypeHandlerConfigs, getDependentEngineMyBatisXmlMappers, getDeployers, getEngineConfigurations, getEngineLifecycleListeners, getEngineSpecificEngineConfigurators, getEventDispatcher, getEventListeners, getEventRegistryConfigurator, getEventRegistryEventConsumers, getIdGenerator, getIdmEngineConfigurator, getJdbcDefaultTransactionIsolationLevel, getJdbcDriver, getJdbcMaxActiveConnections, getJdbcMaxCheckoutTime, getJdbcMaxIdleConnections, getJdbcMaxWaitTime, getJdbcPassword, getJdbcPingConnectionNotUsedFor, getJdbcPingQuery, getJdbcUrl, getJdbcUsername, getLockManager, getLockPollRate, getLoggingListener, getMaxLengthString, getMaxLengthStringVariableType, getMaxNrOfStatementsInBulkInsert, getMybatisMappingFile, getPropertyDataManager, getPropertyEntityManager, getResourceAsStream, getSchemaCommandConfig, getSchemaLockWaitTime, getSchemaManagementCmd, getSchemaManager, getServiceConfigurations, getSessionFactories, getSqlSessionFactory, getTableDataManager, getTransactionContextFactory, getTransactionFactory, getTypedEventListeners, getXmlEncoding, initAdditionalEventDispatchActions, initBeans, initClock, initCommandContextFactory, initCommandExecutor, initCommandInvoker, initConfigurators, initCustomMybatisInterceptors, initCustomMybatisMappers, initDatabaseType, initDataSource, initDefaultCommandConfig, initEngineConfigurations, initEventDispatcher, initEventListeners, initIdGenerator, initInterceptorChain, initMybatisConfiguration, initMyBatisLogSqlExecutionTimePlugin, initSchemaCommandConfig, initService, initSqlSessionFactory, initTransactionContextFactory, initTransactionFactory, initTypedEventListeners, isAlwaysLookupLatestDefinitionVersion, isBulkInsertEnabled, isDbHistoryUsed, isEnableConfiguratorServiceLoader, isEnableEventDispatcher, isEnableLogSqlExecutionTime, isFallbackToDefaultTenant, isForceCloseMybatisConnectionPool, isJdbcPingEnabled, isLoggingSessionEnabled, isTablePrefixIsSchema, isTransactionsExternallyManaged, isUseClassForNameClassLoading, isUseLockForDatabaseSchemaUpdate, isUsePrefixId, isUsingRelationalDatabase, isUsingSchemaMgmt, parseCustomMybatisXMLMappers, parseDependentEngineMybatisXMLMappers, parseMybatisConfiguration, parseMybatisXmlMapping, pathToEngineDbProperties, setAdditionalEventDispatchActions, setAgendaOperationRunner, setAlwaysLookupLatestDefinitionVersion, setBeans, setBulkInsertEnabled, setByteArrayDataManager, setByteArrayEntityManager, setClassLoader, setClock, setCommandContextFactory, setCommandExecutor, setCommandInterceptors, setCommandInvoker, setCommonSchemaManager, setConfigurators, setCustomMybatisInterceptors, setCustomPostCommandInterceptors, setCustomPostDeployers, setCustomPreCommandInterceptors, setCustomPreDeployers, setDatabaseWildcardEscapeCharacter, setDbHistoryUsed, setDbSqlSessionFactory, setDefaultCommandConfig, setDefaultCommandInterceptors, setDefaultTenantProvider, setDefaultTenantValue, setDependentEngineMybatisTypeAliasConfigs, setDependentEngineMybatisTypeHandlerConfigs, setDependentEngineMyBatisXmlMappers, setDeployers, setEnableConfiguratorServiceLoader, setEnableEventDispatcher, setEnableLogSqlExecutionTime, setEngineConfigurations, setEngineLifecycleListeners, setEventDispatcher, setEventListeners, setEventRegistryConfigurator, setEventRegistryEventConsumers, setFallbackToDefaultTenant, setForceCloseMybatisConnectionPool, setIdGenerator, setIdmEngineConfigurator, setLockPollRate, setLoggingListener, setMaxLengthStringVariableType, setMaxNrOfStatementsInBulkInsert, setMybatisMappingFile, setPropertyDataManager, setPropertyEntityManager, setSchemaCommandConfig, setSchemaLockWaitTime, setSchemaManagementCmd, setSchemaManager, setServiceConfigurations, setTransactionContextFactory, setTransactionsExternallyManaged, setTypedEventListeners, setUseClassForNameClassLoading, setUseLockForDatabaseSchemaUpdate, setUsePrefixId, setUsingSchemaMgmt, setXmlEncoding
-
-
-
-
Field Detail
-
LOGGER
protected static final org.slf4j.Logger LOGGER
-
DEFAULT_MYBATIS_MAPPING_FILE
public static final java.lang.String DEFAULT_MYBATIS_MAPPING_FILE
- See Also:
- Constant Field Values
-
LIQUIBASE_CHANGELOG_PREFIX
public static final java.lang.String LIQUIBASE_CHANGELOG_PREFIX
- See Also:
- Constant Field Values
-
contentEngineName
protected java.lang.String contentEngineName
-
contentManagementService
protected org.flowable.content.api.ContentManagementService contentManagementService
-
documentRepositoryService
protected DocumentRepositoryService documentRepositoryService
-
contentService
protected CoreContentService contentService
-
renditionService
protected RenditionService renditionService
-
metadataService
protected MetadataService metadataService
-
contentRenditionManager
protected ContentRenditionManager contentRenditionManager
-
documentDeploymentDataManager
protected DocumentDeploymentDataManager documentDeploymentDataManager
-
documentDefinitionDataManager
protected DocumentDefinitionDataManager documentDefinitionDataManager
-
documentResourceDataManager
protected DocumentResourceDataManager documentResourceDataManager
-
contentItemDataManager
protected ContentItemDataManager contentItemDataManager
-
renditionItemDataManager
protected RenditionItemDataManager renditionItemDataManager
-
metadataInstanceDataManager
protected MetadataInstanceDataManager metadataInstanceDataManager
-
databaseContentObjectDataManager
protected DatabaseContentObjectDataManager databaseContentObjectDataManager
-
contentStorage
protected org.flowable.content.api.ContentStorage contentStorage
-
contentRootFolder
protected java.lang.String contentRootFolder
-
createContentRootFolder
protected boolean createContentRootFolder
-
contentItemContentObjectStorageMetadataProvider
protected CoreContentItemContentObjectStorageMetadataProvider contentItemContentObjectStorageMetadataProvider
-
renditionItemContentObjectStorageMetadataProvider
protected RenditionItemContentObjectStorageMetadataProvider renditionItemContentObjectStorageMetadataProvider
-
documentDeploymentEntityManager
protected DocumentDeploymentEntityManager documentDeploymentEntityManager
-
documentDefinitionEntityManager
protected DocumentDefinitionEntityManager documentDefinitionEntityManager
-
documentResourceEntityManager
protected DocumentResourceEntityManager documentResourceEntityManager
-
contentItemEntityManager
protected ContentItemEntityManager contentItemEntityManager
-
renditionItemEntityManager
protected RenditionItemEntityManager renditionItemEntityManager
-
metadataInstanceEntityManager
protected MetadataInstanceEntityManager metadataInstanceEntityManager
-
databaseContentObjectEntityManager
protected DatabaseContentObjectEntityManager databaseContentObjectEntityManager
-
jobSchemaManager
protected org.flowable.common.engine.impl.db.SchemaManager jobSchemaManager
-
executeServiceSchemaManagers
protected boolean executeServiceSchemaManagers
-
documentDefinitionDeployer
protected DocumentDefinitionDeployer documentDefinitionDeployer
-
deploymentManager
protected DocumentDeploymentManager deploymentManager
-
documentResourceConverter
protected DocumentResourceConverter documentResourceConverter
-
documentDefinitionCacheLimit
protected int documentDefinitionCacheLimit
-
documentDefinitionCache
protected org.flowable.common.engine.impl.persistence.deploy.DeploymentCache<DocumentDefinitionCacheEntry> documentDefinitionCache
-
enginesBuild
protected java.util.List<java.lang.String> enginesBuild
-
jobServiceConfiguration
protected org.flowable.job.service.JobServiceConfiguration jobServiceConfiguration
-
asyncExecutor
protected org.flowable.job.service.impl.asyncexecutor.AsyncExecutor asyncExecutor
-
asyncTaskExecutor
protected org.flowable.common.engine.api.async.AsyncTaskExecutor asyncTaskExecutor
-
shutdownAsyncTaskExecutor
protected boolean shutdownAsyncTaskExecutor
-
jobManager
protected org.flowable.job.service.impl.asyncexecutor.JobManager jobManager
-
customJobHandlers
protected java.util.List<org.flowable.job.service.JobHandler> customJobHandlers
-
jobHandlers
protected java.util.Map<java.lang.String,org.flowable.job.service.JobHandler> jobHandlers
-
internalJobManager
protected org.flowable.job.service.InternalJobManager internalJobManager
-
customAsyncRunnableExecutionExceptionHandlers
protected java.util.List<org.flowable.job.service.impl.asyncexecutor.AsyncRunnableExecutionExceptionHandler> customAsyncRunnableExecutionExceptionHandlers
-
addDefaultExceptionHandler
protected boolean addDefaultExceptionHandler
-
failedJobCommandFactory
protected org.flowable.job.service.impl.asyncexecutor.FailedJobCommandFactory failedJobCommandFactory
-
internalJobParentStateResolver
protected org.flowable.job.service.InternalJobParentStateResolver internalJobParentStateResolver
-
jobExecutionScope
protected java.lang.String jobExecutionScope
-
variableTypes
protected org.flowable.variable.api.types.VariableTypes variableTypes
-
customPreVariableTypes
protected java.util.List<org.flowable.variable.api.types.VariableType> customPreVariableTypes
-
customPostVariableTypes
protected java.util.List<org.flowable.variable.api.types.VariableType> customPostVariableTypes
-
serializableVariableTypeTrackDeserializedObjects
protected boolean serializableVariableTypeTrackDeserializedObjects
-
asyncExecutorActivate
protected boolean asyncExecutorActivate
Boolean flag to be set to activate theAsyncExecutor
automatically after the engine has booted up.
-
asyncExecutorMessageQueueMode
protected boolean asyncExecutorMessageQueueMode
Experimental!Set this to true when using the message queue based job executor.
-
asyncExecutorNumberOfRetries
protected int asyncExecutorNumberOfRetries
The number of retries for a job.
-
lockTimeAsyncJobWaitTime
protected int lockTimeAsyncJobWaitTime
Define the default lock time for an async job in seconds. The lock time is used when creating an async job and when it expires the async executor assumes that the job has failed. It will be retried again.
-
defaultFailedJobWaitTime
protected int defaultFailedJobWaitTime
Define the default wait time for a failed job in seconds
-
asyncFailedJobWaitTime
protected int asyncFailedJobWaitTime
Defines the default wait time for a failed async job in seconds
-
asyncExecutorCorePoolSize
protected int asyncExecutorCorePoolSize
The minimal number of threads that are kept alive in the threadpool for job execution. Default value = 2.This property is only applicable when using the threadpool-based async executor.
-
asyncExecutorMaxPoolSize
protected int asyncExecutorMaxPoolSize
The maximum number of threads that are created in the threadpool for job execution. Default value = 10.This property is only applicable when using the threadpool-based async executor.
-
asyncExecutorThreadKeepAliveTime
protected long asyncExecutorThreadKeepAliveTime
The time (in milliseconds) a thread used for job execution must be kept alive before it is destroyed. Default setting is 5 seconds. Having a setting greater than 0 takes resources, but in the case of many job executions it avoids creating new threads all the time. If 0, threads will be destroyed after they've been used for job execution.This property is only applicable when using the threadpool-based async executor.
-
asyncExecutorThreadPoolQueueSize
protected int asyncExecutorThreadPoolQueueSize
The size of the queue on which jobs to be executed are placed, before they are actually executed. Default value = 100.This property is only applicable when using the threadpool-based async executor.
-
asyncExecutorThreadPoolQueue
protected java.util.concurrent.BlockingQueue<java.lang.Runnable> asyncExecutorThreadPoolQueue
The queue onto which jobs will be placed before they are actually executed. Threads form the async executor threadpool will take work from this queue.By default null. If null, an
ArrayBlockingQueue
will be created of sizeasyncExecutorThreadPoolQueueSize
.When the queue is full, the job will be executed by the calling thread (ThreadPoolExecutor.CallerRunsPolicy())
This property is only applicable when using the threadpool-based async executor.
-
asyncExecutorSecondsToWaitOnShutdown
protected long asyncExecutorSecondsToWaitOnShutdown
The time (in seconds) that is waited to gracefully shut down the threadpool used for job execution when a shutdown on the executor (or engine) is requested. Default value = 60.This property is only applicable when using the threadpool-based async executor.
-
asyncExecutorAllowCoreThreadTimeout
protected boolean asyncExecutorAllowCoreThreadTimeout
Whether or not core threads can time out (which is needed to scale down the threads). Default true. This property is only applicable when using the threadpool-based async executor.
-
asyncExecutorThreadFactory
protected java.util.concurrent.ThreadFactory asyncExecutorThreadFactory
The thread factory that the async task executor should use.
-
asyncExecutorMaxAsyncJobsDuePerAcquisition
protected int asyncExecutorMaxAsyncJobsDuePerAcquisition
The number of async jobs that are acquired during one query (before a job is executed, an acquirement thread fetches jobs from the database and puts them on the queue).Default value = 1, as this lowers the potential on optimistic locking exceptions. A larger value means more jobs will be fetched at the same time. Change this value if you know what you are doing.
This property is only applicable when using the threadpool-based async executor.
-
asyncExecutorDefaultTimerJobAcquireWaitTime
protected int asyncExecutorDefaultTimerJobAcquireWaitTime
The time (in milliseconds) the timer acquisition thread will wait to execute the next acquirement query. This happens when no new timer jobs were found or when less timer jobs have been fetched than set in asyncExecutorMaxTimerJobsPerAcquisition. Default value = 10 seconds.(This property is only applicable when using the
DefaultAsyncJobExecutor
).
-
asyncExecutorDefaultAsyncJobAcquireWaitTime
protected int asyncExecutorDefaultAsyncJobAcquireWaitTime
The time (in milliseconds) the async job acquisition thread will wait to execute the next acquirement query. This happens when no new async jobs were found or when less async jobs have been fetched than set inasyncExecutorMaxAsyncJobsDuePerAcquisition
. Default value = 10 seconds.This property is only applicable when using the threadpool-based async executor.
-
asyncExecutorDefaultQueueSizeFullWaitTime
protected int asyncExecutorDefaultQueueSizeFullWaitTime
The time (in milliseconds) the async job (both timer and async continuations) acquisition thread will wait when the queue is full to execute the next query.
-
asyncExecutorLockOwner
protected java.lang.String asyncExecutorLockOwner
When a job is acquired, it is locked so other async executors can't lock and execute it. While doing this, the 'name' of the lock owner is written into a column of the job.By default, a random UUID will be generated when the executor is created.
It is important that each async executor instance in a cluster of Flowable engines has a different name!
This property is only applicable when using the threadpool-based async executor.
-
asyncExecutorTenantId
protected java.lang.String asyncExecutorTenantId
Tenant for the async executor, if any.
-
asyncExecutorAsyncJobLockTimeInMillis
protected int asyncExecutorAsyncJobLockTimeInMillis
The amount of time (in milliseconds) an async job is locked when acquired by the async executor. During this period of time, no other async executor will try to acquire and lock this job. This property is only applicable when using the threadpool-based async executor.
-
asyncExecutorResetExpiredJobsInterval
protected int asyncExecutorResetExpiredJobsInterval
The amount of time (in milliseconds) that is between two consecutive checks of 'expired jobs'. Expired jobs are jobs that were locked (a lock owner + time was written by some executor, but the job was never completed).During such a check, jobs that are expired are again made available, meaning the lock owner and lock time will be removed. Other executors will now be able to pick it up.
A job is deemed expired if the current time has passed the lock time.
By default one minute.
-
asyncExecutorResetExpiredJobsMaxTimeout
protected int asyncExecutorResetExpiredJobsMaxTimeout
The amount of time (in milliseconds) a job can maximum be in the 'executable' state before being deemed expired. Note that this won't happen when using the threadpool based executor, as the acquire thread will fetch these kind of jobs earlier. However, in the message queue based execution, it could be some job is posted to a queue but then never is locked nor executed.By default 24 hours, as this should be a very exceptional case.
-
asyncExecutorResetExpiredJobsPageSize
protected int asyncExecutorResetExpiredJobsPageSize
The defaultAsyncExecutor
has a 'cleanup' thread that resets expired jobs so they can be re-acquired by other executors. This setting defines the size of the page being used when fetching these expired jobs.
-
asyncExecutorExecuteAsyncRunnableFactory
protected org.flowable.job.service.impl.asyncexecutor.ExecuteAsyncRunnableFactory asyncExecutorExecuteAsyncRunnableFactory
Allows to define a custom factory for creating theRunnable
that is executed by the async executor.This property is only applicable when using the threadpool-based async executor.
-
isAsyncExecutorAsyncJobAcquisitionEnabled
protected boolean isAsyncExecutorAsyncJobAcquisitionEnabled
Flags to control which threads (when using the default threadpool-based async executor) are started. This can be used to boot up engine instances that still execute jobs originating from this instance itself, but don't fetch new jobs themselves.
-
isAsyncExecutorResetExpiredJobsEnabled
protected boolean isAsyncExecutorResetExpiredJobsEnabled
-
asyncHistoryExecutor
protected org.flowable.job.service.impl.asyncexecutor.AsyncExecutor asyncHistoryExecutor
-
isAsyncHistoryEnabled
protected boolean isAsyncHistoryEnabled
-
asyncHistoryListener
protected org.flowable.job.service.impl.history.async.AsyncHistoryListener asyncHistoryListener
-
contentAsyncHistoryManager
protected ContentAsyncHistoryManager contentAsyncHistoryManager
-
objectMapper
protected com.fasterxml.jackson.databind.ObjectMapper objectMapper
-
contentCryptoHandler
protected ContentCryptoHandler contentCryptoHandler
-
renditionConverters
protected java.util.List<RenditionConverter> renditionConverters
-
jsonVariableTypeTrackObjects
protected boolean jsonVariableTypeTrackObjects
This flag determines whether variables of the type 'json' and 'longJson' will be tracked.This means that, when true, in a JavaDelegate you can write:
And the changes to the JsonNode will be reflected in the database. Otherwise, a manual call to setVariable will be needed.JsonNode jsonNode = (JsonNode) execution.getVariable("customer"); customer.put("name", "Kermit");
-
-
Method Detail
-
createContentEngineConfigurationFromResourceDefault
public static ContentEngineConfiguration createContentEngineConfigurationFromResourceDefault()
-
createContentEngineConfigurationFromResource
public static ContentEngineConfiguration createContentEngineConfigurationFromResource(java.lang.String resource)
-
createContentEngineConfigurationFromResource
public static ContentEngineConfiguration createContentEngineConfigurationFromResource(java.lang.String resource, java.lang.String beanName)
-
createContentEngineConfigurationFromInputStream
public static ContentEngineConfiguration createContentEngineConfigurationFromInputStream(java.io.InputStream inputStream)
-
createContentEngineConfigurationFromInputStream
public static ContentEngineConfiguration createContentEngineConfigurationFromInputStream(java.io.InputStream inputStream, java.lang.String beanName)
-
createStandaloneContentEngineConfiguration
public static ContentEngineConfiguration createStandaloneContentEngineConfiguration()
-
createStandaloneInMemContentEngineConfiguration
public static ContentEngineConfiguration createStandaloneInMemContentEngineConfiguration()
-
buildContentEngine
public ContentEngine buildContentEngine()
-
init
protected void init()
-
initServices
protected void initServices()
-
initDataManagers
public void initDataManagers()
- Overrides:
initDataManagers
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
initEntityManagers
public void initEntityManagers()
- Overrides:
initEntityManagers
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
initContentStorage
public void initContentStorage()
-
initSchemaManager
public void initSchemaManager()
- Overrides:
initSchemaManager
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
initSchemaManagementCommand
public void initSchemaManagementCommand()
-
initCommonSchemaManager
protected void initCommonSchemaManager()
-
initJobSchemaManager
protected void initJobSchemaManager()
-
initSessionFactories
public void initSessionFactories()
- Overrides:
initSessionFactories
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
initDbSqlSessionFactory
public void initDbSqlSessionFactory()
- Overrides:
initDbSqlSessionFactory
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
createDbSqlSessionFactory
public org.flowable.common.engine.impl.db.DbSqlSessionFactory createDbSqlSessionFactory()
- Overrides:
createDbSqlSessionFactory
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
initDbSqlSessionFactoryEntitySettings
protected void initDbSqlSessionFactoryEntitySettings()
- Specified by:
initDbSqlSessionFactoryEntitySettings
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
initMybatisTypeHandlers
public void initMybatisTypeHandlers(org.apache.ibatis.session.Configuration configuration)
- Overrides:
initMybatisTypeHandlers
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
initAsyncHistorySessionFactory
public void initAsyncHistorySessionFactory()
-
initDefaultAsyncHistoryListener
protected void initDefaultAsyncHistoryListener()
-
initVariableTypes
public void initVariableTypes()
-
initCommandExecutors
public void initCommandExecutors()
- Overrides:
initCommandExecutors
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
initCommandInterceptors
public void initCommandInterceptors()
- Overrides:
initCommandInterceptors
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
getEngineCfgKey
public java.lang.String getEngineCfgKey()
- Specified by:
getEngineCfgKey
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
getEngineScopeType
public java.lang.String getEngineScopeType()
- Specified by:
getEngineScopeType
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
createTransactionInterceptor
public org.flowable.common.engine.impl.interceptor.CommandInterceptor createTransactionInterceptor()
- Specified by:
createTransactionInterceptor
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
getMyBatisXmlConfigurationStream
public java.io.InputStream getMyBatisXmlConfigurationStream()
- Specified by:
getMyBatisXmlConfigurationStream
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
initObjectMapper
public void initObjectMapper()
-
initDeployers
protected void initDeployers()
-
getDefaultDeployers
public java.util.Collection<? extends org.flowable.common.engine.impl.EngineDeployer> getDefaultDeployers()
-
initDocumentDefinitionCache
protected void initDocumentDefinitionCache()
-
initDocumentResourceConverter
protected void initDocumentResourceConverter()
-
initDeploymentManager
protected void initDeploymentManager()
-
initContentRenditionManager
public void initContentRenditionManager()
-
initJobHandlers
public void initJobHandlers()
-
initFailedJobCommandFactory
public void initFailedJobCommandFactory()
-
initJobServiceConfiguration
public void initJobServiceConfiguration()
-
initAsyncTaskExecutor
protected void initAsyncTaskExecutor()
-
initAsyncExecutor
public void initAsyncExecutor()
-
getEngineName
public java.lang.String getEngineName()
- Specified by:
getEngineName
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setEngineName
public ContentEngineConfiguration setEngineName(java.lang.String contentEngineName)
-
setDatabaseType
public ContentEngineConfiguration setDatabaseType(java.lang.String databaseType)
- Overrides:
setDatabaseType
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setDataSource
public ContentEngineConfiguration setDataSource(javax.sql.DataSource dataSource)
- Overrides:
setDataSource
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcDriver
public ContentEngineConfiguration setJdbcDriver(java.lang.String jdbcDriver)
- Overrides:
setJdbcDriver
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcUrl
public ContentEngineConfiguration setJdbcUrl(java.lang.String jdbcUrl)
- Overrides:
setJdbcUrl
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcUsername
public ContentEngineConfiguration setJdbcUsername(java.lang.String jdbcUsername)
- Overrides:
setJdbcUsername
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcPassword
public ContentEngineConfiguration setJdbcPassword(java.lang.String jdbcPassword)
- Overrides:
setJdbcPassword
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcMaxActiveConnections
public ContentEngineConfiguration setJdbcMaxActiveConnections(int jdbcMaxActiveConnections)
- Overrides:
setJdbcMaxActiveConnections
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcMaxIdleConnections
public ContentEngineConfiguration setJdbcMaxIdleConnections(int jdbcMaxIdleConnections)
- Overrides:
setJdbcMaxIdleConnections
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcMaxCheckoutTime
public ContentEngineConfiguration setJdbcMaxCheckoutTime(int jdbcMaxCheckoutTime)
- Overrides:
setJdbcMaxCheckoutTime
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcMaxWaitTime
public ContentEngineConfiguration setJdbcMaxWaitTime(int jdbcMaxWaitTime)
- Overrides:
setJdbcMaxWaitTime
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcPingEnabled
public ContentEngineConfiguration setJdbcPingEnabled(boolean jdbcPingEnabled)
- Overrides:
setJdbcPingEnabled
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcPingConnectionNotUsedFor
public ContentEngineConfiguration setJdbcPingConnectionNotUsedFor(int jdbcPingConnectionNotUsedFor)
- Overrides:
setJdbcPingConnectionNotUsedFor
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcDefaultTransactionIsolationLevel
public ContentEngineConfiguration setJdbcDefaultTransactionIsolationLevel(int jdbcDefaultTransactionIsolationLevel)
- Overrides:
setJdbcDefaultTransactionIsolationLevel
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setJdbcPingQuery
public ContentEngineConfiguration setJdbcPingQuery(java.lang.String jdbcPingQuery)
- Overrides:
setJdbcPingQuery
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setDataSourceJndiName
public ContentEngineConfiguration setDataSourceJndiName(java.lang.String dataSourceJndiName)
- Overrides:
setDataSourceJndiName
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
getContentManagementService
public org.flowable.content.api.ContentManagementService getContentManagementService()
- Specified by:
getContentManagementService
in interfaceorg.flowable.content.api.ContentEngineConfigurationApi
-
setContentManagementService
public ContentEngineConfiguration setContentManagementService(org.flowable.content.api.ContentManagementService contentManagementService)
-
getDocumentRepositoryService
public DocumentRepositoryService getDocumentRepositoryService()
- Specified by:
getDocumentRepositoryService
in interfaceCoreContentEngineConfigurationApi
-
setDocumentRepositoryService
public ContentEngineConfiguration setDocumentRepositoryService(DocumentRepositoryService documentRepositoryService)
-
getContentService
public CoreContentService getContentService()
- Specified by:
getContentService
in interfaceorg.flowable.content.api.ContentEngineConfigurationApi
- Specified by:
getContentService
in interfaceCoreContentEngineConfigurationApi
-
setContentService
public ContentEngineConfiguration setContentService(CoreContentService contentService)
-
getRenditionService
public RenditionService getRenditionService()
- Specified by:
getRenditionService
in interfaceCoreContentEngineConfigurationApi
-
setRenditionService
public ContentEngineConfiguration setRenditionService(RenditionService renditionService)
-
getMetadataService
public MetadataService getMetadataService()
- Specified by:
getMetadataService
in interfaceCoreContentEngineConfigurationApi
-
setMetadataService
public ContentEngineConfiguration setMetadataService(MetadataService metadataService)
-
getContentEngineConfiguration
public ContentEngineConfiguration getContentEngineConfiguration()
-
getDocumentDeploymentDataManager
public DocumentDeploymentDataManager getDocumentDeploymentDataManager()
-
setDocumentDeploymentDataManager
public ContentEngineConfiguration setDocumentDeploymentDataManager(DocumentDeploymentDataManager documentDeploymentDataManager)
-
getDocumentDefinitionDataManager
public DocumentDefinitionDataManager getDocumentDefinitionDataManager()
-
setDocumentDefinitionDataManager
public ContentEngineConfiguration setDocumentDefinitionDataManager(DocumentDefinitionDataManager documentDefinitionDataManager)
-
getDocumentResourceDataManager
public DocumentResourceDataManager getDocumentResourceDataManager()
-
setDocumentResourceDataManager
public ContentEngineConfiguration setDocumentResourceDataManager(DocumentResourceDataManager documentResourceDataManager)
-
getContentItemDataManager
public ContentItemDataManager getContentItemDataManager()
-
setContentItemDataManager
public ContentEngineConfiguration setContentItemDataManager(ContentItemDataManager contentItemDataManager)
-
getRenditionItemDataManager
public RenditionItemDataManager getRenditionItemDataManager()
-
setRenditionItemDataManager
public ContentEngineConfiguration setRenditionItemDataManager(RenditionItemDataManager renditionItemDataManager)
-
getMetadataInstanceDataManager
public MetadataInstanceDataManager getMetadataInstanceDataManager()
-
setMetadataInstanceDataManager
public ContentEngineConfiguration setMetadataInstanceDataManager(MetadataInstanceDataManager metadataInstanceDataManager)
-
getDocumentDeploymentEntityManager
public DocumentDeploymentEntityManager getDocumentDeploymentEntityManager()
-
setDocumentDeploymentEntityManager
public ContentEngineConfiguration setDocumentDeploymentEntityManager(DocumentDeploymentEntityManager documentDeploymentEntityManager)
-
getDocumentDefinitionEntityManager
public DocumentDefinitionEntityManager getDocumentDefinitionEntityManager()
-
setDocumentDefinitionEntityManager
public ContentEngineConfiguration setDocumentDefinitionEntityManager(DocumentDefinitionEntityManager documentDefinitionEntityManager)
-
getDocumentResourceEntityManager
public DocumentResourceEntityManager getDocumentResourceEntityManager()
-
setDocumentResourceEntityManager
public ContentEngineConfiguration setDocumentResourceEntityManager(DocumentResourceEntityManager documentResourceEntityManager)
-
getContentItemEntityManager
public ContentItemEntityManager getContentItemEntityManager()
-
setContentItemEntityManager
public ContentEngineConfiguration setContentItemEntityManager(ContentItemEntityManager contentItemEntityManager)
-
getRenditionItemEntityManager
public RenditionItemEntityManager getRenditionItemEntityManager()
-
setRenditionItemEntityManager
public ContentEngineConfiguration setRenditionItemEntityManager(RenditionItemEntityManager renditionItemEntityManager)
-
getMetadataInstanceEntityManager
public MetadataInstanceEntityManager getMetadataInstanceEntityManager()
-
setMetadataInstanceEntityManager
public ContentEngineConfiguration setMetadataInstanceEntityManager(MetadataInstanceEntityManager metadataInstanceEntityManager)
-
getDatabaseContentObjectEntityManager
public DatabaseContentObjectEntityManager getDatabaseContentObjectEntityManager()
-
setDatabaseContentObjectEntityManager
public ContentEngineConfiguration setDatabaseContentObjectEntityManager(DatabaseContentObjectEntityManager databaseContentObjectEntityManager)
-
setTableDataManager
public ContentEngineConfiguration setTableDataManager(org.flowable.common.engine.impl.persistence.entity.TableDataManager tableDataManager)
- Overrides:
setTableDataManager
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
getContentStorage
public org.flowable.content.api.ContentStorage getContentStorage()
-
setContentStorage
public ContentEngineConfiguration setContentStorage(org.flowable.content.api.ContentStorage contentStorage)
-
getContentRootFolder
public java.lang.String getContentRootFolder()
-
setContentRootFolder
public ContentEngineConfiguration setContentRootFolder(java.lang.String contentRootFolder)
-
isCreateContentRootFolder
public boolean isCreateContentRootFolder()
-
setCreateContentRootFolder
public ContentEngineConfiguration setCreateContentRootFolder(boolean createContentRootFolder)
-
getContentItemContentObjectStorageMetadataProvider
public CoreContentItemContentObjectStorageMetadataProvider getContentItemContentObjectStorageMetadataProvider()
-
setContentItemContentObjectStorageMetadataProvider
public void setContentItemContentObjectStorageMetadataProvider(CoreContentItemContentObjectStorageMetadataProvider contentItemContentObjectStorageMetadataProvider)
-
getRenditionItemContentObjectStorageMetadataProvider
public RenditionItemContentObjectStorageMetadataProvider getRenditionItemContentObjectStorageMetadataProvider()
-
setRenditionItemContentObjectStorageMetadataProvider
public void setRenditionItemContentObjectStorageMetadataProvider(RenditionItemContentObjectStorageMetadataProvider renditionItemContentObjectStorageMetadataProvider)
-
getContentRenditionManager
public ContentRenditionManager getContentRenditionManager()
-
setContentRenditionManager
public void setContentRenditionManager(ContentRenditionManager contentRenditionManager)
-
getContentCryptoHandler
public ContentCryptoHandler getContentCryptoHandler()
-
setContentCryptoHandler
public void setContentCryptoHandler(ContentCryptoHandler contentCryptoHandler)
-
getRenditionConverters
public java.util.List<RenditionConverter> getRenditionConverters()
-
setRenditionConverters
public void setRenditionConverters(java.util.List<RenditionConverter> renditionConverters)
-
setSqlSessionFactory
public ContentEngineConfiguration setSqlSessionFactory(org.apache.ibatis.session.SqlSessionFactory sqlSessionFactory)
- Overrides:
setSqlSessionFactory
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setTransactionFactory
public ContentEngineConfiguration setTransactionFactory(org.apache.ibatis.transaction.TransactionFactory transactionFactory)
- Overrides:
setTransactionFactory
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setCustomMybatisMappers
public ContentEngineConfiguration setCustomMybatisMappers(java.util.Set<java.lang.Class<?>> customMybatisMappers)
- Overrides:
setCustomMybatisMappers
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setCustomMybatisXMLMappers
public ContentEngineConfiguration setCustomMybatisXMLMappers(java.util.Set<java.lang.String> customMybatisXMLMappers)
- Overrides:
setCustomMybatisXMLMappers
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setCustomSessionFactories
public ContentEngineConfiguration setCustomSessionFactories(java.util.List<org.flowable.common.engine.impl.interceptor.SessionFactory> customSessionFactories)
- Overrides:
setCustomSessionFactories
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setUsingRelationalDatabase
public ContentEngineConfiguration setUsingRelationalDatabase(boolean usingRelationalDatabase)
- Overrides:
setUsingRelationalDatabase
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setDatabaseTablePrefix
public ContentEngineConfiguration setDatabaseTablePrefix(java.lang.String databaseTablePrefix)
- Overrides:
setDatabaseTablePrefix
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setDatabaseCatalog
public ContentEngineConfiguration setDatabaseCatalog(java.lang.String databaseCatalog)
- Overrides:
setDatabaseCatalog
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setDatabaseSchema
public ContentEngineConfiguration setDatabaseSchema(java.lang.String databaseSchema)
- Overrides:
setDatabaseSchema
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setTablePrefixIsSchema
public ContentEngineConfiguration setTablePrefixIsSchema(boolean tablePrefixIsSchema)
- Overrides:
setTablePrefixIsSchema
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setSessionFactories
public ContentEngineConfiguration setSessionFactories(java.util.Map<java.lang.Class<?>,org.flowable.common.engine.impl.interceptor.SessionFactory> sessionFactories)
- Overrides:
setSessionFactories
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setDatabaseSchemaUpdate
public ContentEngineConfiguration setDatabaseSchemaUpdate(java.lang.String databaseSchemaUpdate)
- Overrides:
setDatabaseSchemaUpdate
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
getJobSchemaManager
public org.flowable.common.engine.impl.db.SchemaManager getJobSchemaManager()
-
setJobSchemaManager
public ContentEngineConfiguration setJobSchemaManager(org.flowable.common.engine.impl.db.SchemaManager jobSchemaManager)
-
isExecuteServiceSchemaManagers
public boolean isExecuteServiceSchemaManagers()
-
setExecuteServiceSchemaManagers
public ContentEngineConfiguration setExecuteServiceSchemaManagers(boolean executeServiceSchemaManagers)
-
getDocumentDefinitionDeployer
public DocumentDefinitionDeployer getDocumentDefinitionDeployer()
-
setDocumentDefinitionDeployer
public ContentEngineConfiguration setDocumentDefinitionDeployer(DocumentDefinitionDeployer documentDefinitionDeployer)
-
getDeploymentManager
public DocumentDeploymentManager getDeploymentManager()
-
setDeploymentManager
public ContentEngineConfiguration setDeploymentManager(DocumentDeploymentManager deploymentManager)
-
getDocumentResourceConverter
public DocumentResourceConverter getDocumentResourceConverter()
- Specified by:
getDocumentResourceConverter
in interfaceCoreContentEngineConfigurationApi
-
setDocumentResourceConverter
public ContentEngineConfiguration setDocumentResourceConverter(DocumentResourceConverter documentResourceConverter)
-
getDocumentDefinitionCacheLimit
public int getDocumentDefinitionCacheLimit()
-
setDocumentDefinitionCacheLimit
public ContentEngineConfiguration setDocumentDefinitionCacheLimit(int documentDefinitionCacheLimit)
-
getDocumentDefinitionCache
public org.flowable.common.engine.impl.persistence.deploy.DeploymentCache<DocumentDefinitionCacheEntry> getDocumentDefinitionCache()
-
setDocumentDefinitionCache
public ContentEngineConfiguration setDocumentDefinitionCache(org.flowable.common.engine.impl.persistence.deploy.DeploymentCache<DocumentDefinitionCacheEntry> documentDefinitionCache)
-
getJobServiceConfiguration
public org.flowable.job.service.JobServiceConfiguration getJobServiceConfiguration()
-
setJobServiceConfiguration
public ContentEngineConfiguration setJobServiceConfiguration(org.flowable.job.service.JobServiceConfiguration jobServiceConfiguration)
-
getAsyncExecutor
public org.flowable.job.service.impl.asyncexecutor.AsyncExecutor getAsyncExecutor()
-
setAsyncExecutor
public ContentEngineConfiguration setAsyncExecutor(org.flowable.job.service.impl.asyncexecutor.AsyncExecutor asyncExecutor)
-
getJobManager
public org.flowable.job.service.impl.asyncexecutor.JobManager getJobManager()
-
setJobManager
public ContentEngineConfiguration setJobManager(org.flowable.job.service.impl.asyncexecutor.JobManager jobManager)
-
getCustomJobHandlers
public java.util.List<org.flowable.job.service.JobHandler> getCustomJobHandlers()
-
setCustomJobHandlers
public ContentEngineConfiguration setCustomJobHandlers(java.util.List<org.flowable.job.service.JobHandler> customJobHandlers)
-
getJobHandlers
public java.util.Map<java.lang.String,org.flowable.job.service.JobHandler> getJobHandlers()
-
setJobHandlers
public ContentEngineConfiguration setJobHandlers(java.util.Map<java.lang.String,org.flowable.job.service.JobHandler> jobHandlers)
-
getInternalJobManager
public org.flowable.job.service.InternalJobManager getInternalJobManager()
-
setInternalJobManager
public ContentEngineConfiguration setInternalJobManager(org.flowable.job.service.InternalJobManager internalJobManager)
-
getCustomAsyncRunnableExecutionExceptionHandlers
public java.util.List<org.flowable.job.service.impl.asyncexecutor.AsyncRunnableExecutionExceptionHandler> getCustomAsyncRunnableExecutionExceptionHandlers()
-
setCustomAsyncRunnableExecutionExceptionHandlers
public ContentEngineConfiguration setCustomAsyncRunnableExecutionExceptionHandlers(java.util.List<org.flowable.job.service.impl.asyncexecutor.AsyncRunnableExecutionExceptionHandler> customAsyncRunnableExecutionExceptionHandlers)
-
getFailedJobCommandFactory
public org.flowable.job.service.impl.asyncexecutor.FailedJobCommandFactory getFailedJobCommandFactory()
-
setFailedJobCommandFactory
public ContentEngineConfiguration setFailedJobCommandFactory(org.flowable.job.service.impl.asyncexecutor.FailedJobCommandFactory failedJobCommandFactory)
-
getInternalJobParentStateResolver
public org.flowable.job.service.InternalJobParentStateResolver getInternalJobParentStateResolver()
-
setInternalJobParentStateResolver
public ContentEngineConfiguration setInternalJobParentStateResolver(org.flowable.job.service.InternalJobParentStateResolver internalJobParentStateResolver)
-
getJobExecutionScope
public java.lang.String getJobExecutionScope()
-
setJobExecutionScope
public ContentEngineConfiguration setJobExecutionScope(java.lang.String jobExecutionScope)
-
isAsyncExecutorActivate
public boolean isAsyncExecutorActivate()
-
setAsyncExecutorActivate
public ContentEngineConfiguration setAsyncExecutorActivate(boolean asyncExecutorActivate)
-
isAsyncExecutorMessageQueueMode
public boolean isAsyncExecutorMessageQueueMode()
-
setAsyncExecutorMessageQueueMode
public ContentEngineConfiguration setAsyncExecutorMessageQueueMode(boolean asyncExecutorMessageQueueMode)
-
getAsyncExecutorNumberOfRetries
public int getAsyncExecutorNumberOfRetries()
-
setAsyncExecutorNumberOfRetries
public ContentEngineConfiguration setAsyncExecutorNumberOfRetries(int asyncExecutorNumberOfRetries)
-
getLockTimeAsyncJobWaitTime
public int getLockTimeAsyncJobWaitTime()
-
setLockTimeAsyncJobWaitTime
public ContentEngineConfiguration setLockTimeAsyncJobWaitTime(int lockTimeAsyncJobWaitTime)
-
getDefaultFailedJobWaitTime
public int getDefaultFailedJobWaitTime()
-
setDefaultFailedJobWaitTime
public ContentEngineConfiguration setDefaultFailedJobWaitTime(int defaultFailedJobWaitTime)
-
getAsyncFailedJobWaitTime
public int getAsyncFailedJobWaitTime()
-
setAsyncFailedJobWaitTime
public ContentEngineConfiguration setAsyncFailedJobWaitTime(int asyncFailedJobWaitTime)
-
getAsyncExecutorCorePoolSize
public int getAsyncExecutorCorePoolSize()
-
setAsyncExecutorCorePoolSize
public ContentEngineConfiguration setAsyncExecutorCorePoolSize(int asyncExecutorCorePoolSize)
-
getAsyncExecutorMaxPoolSize
public int getAsyncExecutorMaxPoolSize()
-
setAsyncExecutorMaxPoolSize
public ContentEngineConfiguration setAsyncExecutorMaxPoolSize(int asyncExecutorMaxPoolSize)
-
getAsyncExecutorThreadKeepAliveTime
public long getAsyncExecutorThreadKeepAliveTime()
-
setAsyncExecutorThreadKeepAliveTime
public ContentEngineConfiguration setAsyncExecutorThreadKeepAliveTime(long asyncExecutorThreadKeepAliveTime)
-
getAsyncExecutorThreadPoolQueueSize
public int getAsyncExecutorThreadPoolQueueSize()
-
setAsyncExecutorThreadPoolQueueSize
public ContentEngineConfiguration setAsyncExecutorThreadPoolQueueSize(int asyncExecutorThreadPoolQueueSize)
-
isShutdownAsyncTaskExecutor
public boolean isShutdownAsyncTaskExecutor()
-
setShutdownAsyncTaskExecutor
public ContentEngineConfiguration setShutdownAsyncTaskExecutor(boolean shutdownAsyncTaskExecutor)
-
getAsyncExecutorDefaultTimerJobAcquireWaitTime
public int getAsyncExecutorDefaultTimerJobAcquireWaitTime()
-
setAsyncExecutorDefaultTimerJobAcquireWaitTime
public ContentEngineConfiguration setAsyncExecutorDefaultTimerJobAcquireWaitTime(int asyncExecutorDefaultTimerJobAcquireWaitTime)
-
getAsyncExecutorTenantId
public java.lang.String getAsyncExecutorTenantId()
-
setAsyncExecutorTenantId
public ContentEngineConfiguration setAsyncExecutorTenantId(java.lang.String asyncExecutorTenantId)
-
getAsyncExecutorThreadPoolQueue
public java.util.concurrent.BlockingQueue<java.lang.Runnable> getAsyncExecutorThreadPoolQueue()
-
setAsyncExecutorThreadPoolQueue
public ContentEngineConfiguration setAsyncExecutorThreadPoolQueue(java.util.concurrent.BlockingQueue<java.lang.Runnable> asyncExecutorThreadPoolQueue)
-
getAsyncExecutorSecondsToWaitOnShutdown
public long getAsyncExecutorSecondsToWaitOnShutdown()
-
setAsyncExecutorSecondsToWaitOnShutdown
public ContentEngineConfiguration setAsyncExecutorSecondsToWaitOnShutdown(long asyncExecutorSecondsToWaitOnShutdown)
-
getAsyncTaskExecutor
public org.flowable.common.engine.api.async.AsyncTaskExecutor getAsyncTaskExecutor()
-
setAsyncTaskExecutor
public ContentEngineConfiguration setAsyncTaskExecutor(org.flowable.common.engine.api.async.AsyncTaskExecutor asyncTaskExecutor)
-
isAsyncExecutorAllowCoreThreadTimeout
public boolean isAsyncExecutorAllowCoreThreadTimeout()
-
setAsyncExecutorAllowCoreThreadTimeout
public ContentEngineConfiguration setAsyncExecutorAllowCoreThreadTimeout(boolean asyncExecutorAllowCoreThreadTimeout)
-
getAsyncExecutorThreadFactory
public java.util.concurrent.ThreadFactory getAsyncExecutorThreadFactory()
-
setAsyncExecutorThreadFactory
public ContentEngineConfiguration setAsyncExecutorThreadFactory(java.util.concurrent.ThreadFactory asyncExecutorThreadFactory)
-
getAsyncExecutorMaxAsyncJobsDuePerAcquisition
public int getAsyncExecutorMaxAsyncJobsDuePerAcquisition()
-
setAsyncExecutorMaxAsyncJobsDuePerAcquisition
public ContentEngineConfiguration setAsyncExecutorMaxAsyncJobsDuePerAcquisition(int asyncExecutorMaxAsyncJobsDuePerAcquisition)
-
getAsyncExecutorDefaultAsyncJobAcquireWaitTime
public int getAsyncExecutorDefaultAsyncJobAcquireWaitTime()
-
setAsyncExecutorDefaultAsyncJobAcquireWaitTime
public ContentEngineConfiguration setAsyncExecutorDefaultAsyncJobAcquireWaitTime(int asyncExecutorDefaultAsyncJobAcquireWaitTime)
-
getAsyncExecutorDefaultQueueSizeFullWaitTime
public int getAsyncExecutorDefaultQueueSizeFullWaitTime()
-
setAsyncExecutorDefaultQueueSizeFullWaitTime
public ContentEngineConfiguration setAsyncExecutorDefaultQueueSizeFullWaitTime(int asyncExecutorDefaultQueueSizeFullWaitTime)
-
getAsyncExecutorLockOwner
public java.lang.String getAsyncExecutorLockOwner()
-
setAsyncExecutorLockOwner
public ContentEngineConfiguration setAsyncExecutorLockOwner(java.lang.String asyncExecutorLockOwner)
-
getAsyncExecutorAsyncJobLockTimeInMillis
public int getAsyncExecutorAsyncJobLockTimeInMillis()
-
setAsyncExecutorAsyncJobLockTimeInMillis
public ContentEngineConfiguration setAsyncExecutorAsyncJobLockTimeInMillis(int asyncExecutorAsyncJobLockTimeInMillis)
-
getAsyncExecutorResetExpiredJobsInterval
public int getAsyncExecutorResetExpiredJobsInterval()
-
setAsyncExecutorResetExpiredJobsInterval
public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsInterval(int asyncExecutorResetExpiredJobsInterval)
-
getAsyncExecutorResetExpiredJobsMaxTimeout
public int getAsyncExecutorResetExpiredJobsMaxTimeout()
-
setAsyncExecutorResetExpiredJobsMaxTimeout
public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsMaxTimeout(int asyncExecutorResetExpiredJobsMaxTimeout)
-
getAsyncExecutorResetExpiredJobsPageSize
public int getAsyncExecutorResetExpiredJobsPageSize()
-
setAsyncExecutorResetExpiredJobsPageSize
public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsPageSize(int asyncExecutorResetExpiredJobsPageSize)
-
getAsyncExecutorExecuteAsyncRunnableFactory
public org.flowable.job.service.impl.asyncexecutor.ExecuteAsyncRunnableFactory getAsyncExecutorExecuteAsyncRunnableFactory()
-
setAsyncExecutorExecuteAsyncRunnableFactory
public ContentEngineConfiguration setAsyncExecutorExecuteAsyncRunnableFactory(org.flowable.job.service.impl.asyncexecutor.ExecuteAsyncRunnableFactory asyncExecutorExecuteAsyncRunnableFactory)
-
isAsyncExecutorAsyncJobAcquisitionEnabled
public boolean isAsyncExecutorAsyncJobAcquisitionEnabled()
-
setAsyncExecutorAsyncJobAcquisitionEnabled
public ContentEngineConfiguration setAsyncExecutorAsyncJobAcquisitionEnabled(boolean isAsyncExecutorAsyncJobAcquisitionEnabled)
-
isAsyncExecutorResetExpiredJobsEnabled
public boolean isAsyncExecutorResetExpiredJobsEnabled()
-
setAsyncExecutorResetExpiredJobsEnabled
public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsEnabled(boolean isAsyncExecutorResetExpiredJobsEnabled)
-
getAsyncHistoryExecutor
public org.flowable.job.service.impl.asyncexecutor.AsyncExecutor getAsyncHistoryExecutor()
-
setAsyncHistoryExecutor
public ContentEngineConfiguration setAsyncHistoryExecutor(org.flowable.job.service.impl.asyncexecutor.AsyncExecutor asyncHistoryExecutor)
-
isAsyncHistoryEnabled
public boolean isAsyncHistoryEnabled()
-
setAsyncHistoryEnabled
public ContentEngineConfiguration setAsyncHistoryEnabled(boolean isAsyncHistoryEnabled)
-
getAsyncHistoryListener
public org.flowable.job.service.impl.history.async.AsyncHistoryListener getAsyncHistoryListener()
-
setAsyncHistoryListener
public ContentEngineConfiguration setAsyncHistoryListener(org.flowable.job.service.impl.history.async.AsyncHistoryListener asyncHistoryListener)
-
getContentAsyncHistoryManager
public ContentAsyncHistoryManager getContentAsyncHistoryManager()
-
setContentAsyncHistoryManager
public ContentEngineConfiguration setContentAsyncHistoryManager(ContentAsyncHistoryManager contentAsyncHistoryManager)
-
getVariableTypes
public org.flowable.variable.api.types.VariableTypes getVariableTypes()
-
setVariableTypes
public ContentEngineConfiguration setVariableTypes(org.flowable.variable.api.types.VariableTypes variableTypes)
-
getCustomPreVariableTypes
public java.util.List<org.flowable.variable.api.types.VariableType> getCustomPreVariableTypes()
-
setCustomPreVariableTypes
public ContentEngineConfiguration setCustomPreVariableTypes(java.util.List<org.flowable.variable.api.types.VariableType> customPreVariableTypes)
-
getCustomPostVariableTypes
public java.util.List<org.flowable.variable.api.types.VariableType> getCustomPostVariableTypes()
-
setCustomPostVariableTypes
public ContentEngineConfiguration setCustomPostVariableTypes(java.util.List<org.flowable.variable.api.types.VariableType> customPostVariableTypes)
-
isJsonVariableTypeTrackObjects
public boolean isJsonVariableTypeTrackObjects()
-
setJsonVariableTypeTrackObjects
public ContentEngineConfiguration setJsonVariableTypeTrackObjects(boolean jsonVariableTypeTrackObjects)
-
getObjectMapper
public com.fasterxml.jackson.databind.ObjectMapper getObjectMapper()
- Overrides:
getObjectMapper
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
setObjectMapper
public ContentEngineConfiguration setObjectMapper(com.fasterxml.jackson.databind.ObjectMapper objectMapper)
- Overrides:
setObjectMapper
in classorg.flowable.common.engine.impl.AbstractEngineConfiguration
-
-