Class ContentEngineConfiguration
- All Implemented Interfaces:
CoreContentEngineConfigurationApi,ContentEngineConfigurationApi
- Direct Known Subclasses:
SpringContentEngineConfiguration,StandaloneContentEngineConfiguration
-
Field Summary
FieldsModifier and TypeFieldDescriptionprotected booleanprotected AsyncExecutorprotected booleanBoolean flag to be set to activate theAsyncExecutorautomatically after the engine has booted up.protected booleanWhether or not core threads can time out (which is needed to scale down the threads).protected AsyncJobExecutorConfigurationprotected intThe minimal number of threads that are kept alive in the threadpool for job execution.protected ExecuteAsyncRunnableFactoryAllows to define a custom factory for creating theRunnablethat is executed by the async executor.protected intThe maximum number of threads that are created in the threadpool for job execution.protected intThe number of retries for a job.protected intThe amount of time (in milliseconds) a job can maximum be in the 'executable' state before being deemed expired.protected longThe 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 ThreadFactoryThe thread factory that the async task executor should use.protected longThe time (in milliseconds) a thread used for job execution must be kept alive before it is destroyed.protected BlockingQueue<Runnable>The queue onto which jobs will be placed before they are actually executed.protected intThe size of the queue on which jobs to be executed are placed, before they are actually executed.protected intDefines the default wait time for a failed async job in secondsprotected AsyncExecutorprotected AsyncTaskExecutorprotected ChangeTenantIdManagerprotected ContentAsyncHistoryManagerprotected ContentCryptoHandlerprotected Stringprotected ContentItemDataManagerprotected ContentItemEntityManagerprotected ContentManagementServiceprotected Map<String,ContentRenditionManager> protected Stringprotected CoreContentServiceprotected Map<String,ContentStorage> protected booleanprotected List<AsyncRunnableExecutionExceptionHandler>protected List<JobHandler>protected List<VariableType>protected List<VariableType>protected DatabaseContentObjectDataManagerprotected DatabaseContentObjectEntityManagerstatic final Stringstatic final Stringprotected intDefine the default wait time for a failed job in secondsprotected DocumentDeploymentManagerprotected DeploymentCache<DocumentDefinitionCacheEntry>protected intprotected DocumentDefinitionDataManagerprotected DocumentDefinitionDeployerprotected DocumentDefinitionEntityManagerprotected DocumentDeploymentDataManagerprotected DocumentDeploymentEntityManagerprotected DocumentRepositoryServiceprotected DocumentResourceConverterprotected DocumentResourceDataManagerprotected DocumentResourceEntityManagerprotected booleanprotected FailedJobCommandFactoryprotected booleanprotected InternalJobManagerprotected InternalJobParentStateResolverprotected Stringprotected Map<String,JobHandler> protected JobManagerprotected SchemaManagerprotected JobServiceConfigurationprotected booleanThis flag determines whether variables of the type 'json' and 'longJson' will be tracked.static final Stringprotected intDefine the default lock time for an async job in seconds.protected MetadataInstanceDataManagerprotected MetadataInstanceEntityManagerprotected MetadataServiceprotected List<RenditionConverter>protected Map<String,RenditionEnhancer> protected RenditionItemDataManagerprotected RenditionItemEntityManagerprotected RenditionServiceprotected booleanprotected booleanprotected VariableTypesFields inherited from class org.flowable.common.engine.impl.AbstractEngineConfiguration
additionalEventDispatchActions, agendaOperationExecutionListeners, 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, objectMapper, 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 -
Method Summary
Modifier and TypeMethodDescriptionvoidaddContentRenditionManager(ContentRenditionManager contentRenditionManager) addContentStorage(ContentStorage contentStorage) addRenditionItemEnhancer(RenditionEnhancer renditionEnhancer) static ContentEngineConfigurationstatic ContentEngineConfigurationcreateContentEngineConfigurationFromInputStream(InputStream inputStream, String beanName) static ContentEngineConfigurationstatic ContentEngineConfigurationcreateContentEngineConfigurationFromResource(String resource, String beanName) static ContentEngineConfigurationstatic ContentEngineConfigurationstatic ContentEngineConfigurationintDeprecated.intintintintDeprecated.intintintintintDeprecated.intlongDeprecated.longintintgetContentRenditionManager(String contentStoreName) getContentStorage(String contentStorageName) Collection<? extends EngineDeployer>intintintprotected AsyncJobExecutorConfigurationgetRenditionItemEnhancer(String contentStoreId) protected voidinit()voidprotected voidvoidvoidprotected voidvoidvoidvoidvoidprotected voidprotected voidprotected voidprotected voidprotected voidvoidvoidvoidprotected voidvoidvoidinitMybatisTypeHandlers(org.apache.ibatis.session.Configuration configuration) voidvoidvoidprotected voidvoidvoidbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleansetAsyncExecutor(AsyncExecutor asyncExecutor) setAsyncExecutorActivate(boolean asyncExecutorActivate) setAsyncExecutorAllowCoreThreadTimeout(boolean asyncExecutorAllowCoreThreadTimeout) setAsyncExecutorAsyncJobAcquisitionEnabled(boolean isAsyncExecutorAsyncJobAcquisitionEnabled) setAsyncExecutorAsyncJobLockTimeInMillis(int asyncExecutorAsyncJobLockTimeInMillis) setAsyncExecutorConfiguration(AsyncJobExecutorConfiguration asyncExecutorConfiguration) setAsyncExecutorCorePoolSize(int asyncExecutorCorePoolSize) setAsyncExecutorDefaultAsyncJobAcquireWaitTime(int asyncExecutorDefaultAsyncJobAcquireWaitTime) setAsyncExecutorDefaultQueueSizeFullWaitTime(int asyncExecutorDefaultQueueSizeFullWaitTime) setAsyncExecutorDefaultTimerJobAcquireWaitTime(int asyncExecutorDefaultTimerJobAcquireWaitTime) setAsyncExecutorExecuteAsyncRunnableFactory(ExecuteAsyncRunnableFactory asyncExecutorExecuteAsyncRunnableFactory) setAsyncExecutorLockOwner(String asyncExecutorLockOwner) Deprecated.setAsyncExecutorMaxAsyncJobsDuePerAcquisition(int asyncExecutorMaxAsyncJobsDuePerAcquisition) setAsyncExecutorMaxPoolSize(int asyncExecutorMaxPoolSize) setAsyncExecutorNumberOfRetries(int asyncExecutorNumberOfRetries) setAsyncExecutorResetExpiredJobsEnabled(boolean isAsyncExecutorResetExpiredJobsEnabled) setAsyncExecutorResetExpiredJobsInterval(int asyncExecutorResetExpiredJobsInterval) setAsyncExecutorResetExpiredJobsMaxTimeout(int asyncExecutorResetExpiredJobsMaxTimeout) setAsyncExecutorResetExpiredJobsPageSize(int asyncExecutorResetExpiredJobsPageSize) setAsyncExecutorSecondsToWaitOnShutdown(long asyncExecutorSecondsToWaitOnShutdown) setAsyncExecutorTenantId(String asyncExecutorTenantId) Deprecated.setAsyncExecutorThreadFactory(ThreadFactory asyncExecutorThreadFactory) setAsyncExecutorThreadKeepAliveTime(long asyncExecutorThreadKeepAliveTime) setAsyncExecutorThreadPoolQueue(BlockingQueue<Runnable> asyncExecutorThreadPoolQueue) setAsyncExecutorThreadPoolQueueSize(int asyncExecutorThreadPoolQueueSize) setAsyncFailedJobWaitTime(int asyncFailedJobWaitTime) setAsyncHistoryExecutor(AsyncExecutor asyncHistoryExecutor) setAsyncTaskExecutor(AsyncTaskExecutor asyncTaskExecutor) voidsetChangeTenantIdManager(ChangeTenantIdManager changeTenantIdManager) setContentAsyncHistoryManager(ContentAsyncHistoryManager contentAsyncHistoryManager) voidsetContentCryptoHandler(ContentCryptoHandler contentCryptoHandler) voidsetContentItemContentObjectStorageMetadataProvider(CoreContentItemContentObjectStorageMetadataProvider contentItemContentObjectStorageMetadataProvider) setContentItemDataManager(ContentItemDataManager contentItemDataManager) setContentItemEntityManager(ContentItemEntityManager contentItemEntityManager) setContentManagementService(ContentManagementService contentManagementService) setContentRootFolder(String contentRootFolder) setContentService(CoreContentService contentService) setContentStorages(Map<String, ContentStorage> contentStorages) setCreateContentRootFolder(boolean createContentRootFolder) setCustomAsyncRunnableExecutionExceptionHandlers(List<AsyncRunnableExecutionExceptionHandler> customAsyncRunnableExecutionExceptionHandlers) setCustomJobHandlers(List<JobHandler> customJobHandlers) setCustomMybatisMappers(Set<Class<?>> customMybatisMappers) setCustomMybatisXMLMappers(Set<String> customMybatisXMLMappers) setCustomPostVariableTypes(List<VariableType> customPostVariableTypes) setCustomPreVariableTypes(List<VariableType> customPreVariableTypes) setCustomSessionFactories(List<SessionFactory> customSessionFactories) setDatabaseCatalog(String databaseCatalog) setDatabaseContentObjectEntityManager(DatabaseContentObjectEntityManager databaseContentObjectEntityManager) setDatabaseSchema(String databaseSchema) setDatabaseSchemaUpdate(String databaseSchemaUpdate) setDatabaseTablePrefix(String databaseTablePrefix) setDatabaseType(String databaseType) setDataSource(DataSource dataSource) setDataSourceJndiName(String dataSourceJndiName) setDefaultFailedJobWaitTime(int defaultFailedJobWaitTime) setDeploymentManager(DocumentDeploymentManager deploymentManager) setDocumentDefinitionCache(DeploymentCache<DocumentDefinitionCacheEntry> documentDefinitionCache) setDocumentDefinitionCacheLimit(int documentDefinitionCacheLimit) setDocumentDefinitionDataManager(DocumentDefinitionDataManager documentDefinitionDataManager) setDocumentDefinitionDeployer(DocumentDefinitionDeployer documentDefinitionDeployer) setDocumentDefinitionEntityManager(DocumentDefinitionEntityManager documentDefinitionEntityManager) setDocumentDeploymentDataManager(DocumentDeploymentDataManager documentDeploymentDataManager) setDocumentDeploymentEntityManager(DocumentDeploymentEntityManager documentDeploymentEntityManager) setDocumentRepositoryService(DocumentRepositoryService documentRepositoryService) setDocumentResourceConverter(DocumentResourceConverter documentResourceConverter) setDocumentResourceDataManager(DocumentResourceDataManager documentResourceDataManager) setDocumentResourceEntityManager(DocumentResourceEntityManager documentResourceEntityManager) setEngineName(String contentEngineName) setExecuteServiceSchemaManagers(boolean executeServiceSchemaManagers) setFailedJobCommandFactory(FailedJobCommandFactory failedJobCommandFactory) setInternalJobManager(InternalJobManager internalJobManager) setInternalJobParentStateResolver(InternalJobParentStateResolver internalJobParentStateResolver) setJdbcDefaultTransactionIsolationLevel(int jdbcDefaultTransactionIsolationLevel) setJdbcDriver(String jdbcDriver) setJdbcMaxActiveConnections(int jdbcMaxActiveConnections) setJdbcMaxCheckoutTime(int jdbcMaxCheckoutTime) setJdbcMaxIdleConnections(int jdbcMaxIdleConnections) setJdbcMaxWaitTime(int jdbcMaxWaitTime) setJdbcPassword(String jdbcPassword) setJdbcPingConnectionNotUsedFor(int jdbcPingConnectionNotUsedFor) setJdbcPingEnabled(boolean jdbcPingEnabled) setJdbcPingQuery(String jdbcPingQuery) setJdbcUrl(String jdbcUrl) setJdbcUsername(String jdbcUsername) setJobExecutionScope(String jobExecutionScope) setJobHandlers(Map<String, JobHandler> jobHandlers) setJobManager(JobManager jobManager) setJobSchemaManager(SchemaManager jobSchemaManager) setJobServiceConfiguration(JobServiceConfiguration jobServiceConfiguration) setJsonVariableTypeTrackObjects(boolean jsonVariableTypeTrackObjects) setLockTimeAsyncJobWaitTime(int lockTimeAsyncJobWaitTime) setMetadataInstanceDataManager(MetadataInstanceDataManager metadataInstanceDataManager) setMetadataInstanceEntityManager(MetadataInstanceEntityManager metadataInstanceEntityManager) setMetadataService(MetadataService metadataService) setObjectMapper(com.fasterxml.jackson.databind.ObjectMapper objectMapper) voidsetRenditionConverters(List<RenditionConverter> renditionConverters) voidsetRenditionItemContentObjectStorageMetadataProvider(RenditionItemContentObjectStorageMetadataProvider renditionItemContentObjectStorageMetadataProvider) setRenditionItemDataManager(RenditionItemDataManager renditionItemDataManager) setRenditionItemEntityManager(RenditionItemEntityManager renditionItemEntityManager) setRenditionService(RenditionService renditionService) setSessionFactories(Map<Class<?>, SessionFactory> sessionFactories) setShutdownAsyncTaskExecutor(boolean shutdownAsyncTaskExecutor) setSqlSessionFactory(org.apache.ibatis.session.SqlSessionFactory sqlSessionFactory) setTableDataManager(TableDataManager tableDataManager) setTablePrefixIsSchema(boolean tablePrefixIsSchema) setTransactionFactory(org.apache.ibatis.transaction.TransactionFactory transactionFactory) setUsingRelationalDatabase(boolean usingRelationalDatabase) setVariableTypes(VariableTypes variableTypes) Methods inherited from class org.flowable.common.engine.impl.AbstractEngineConfiguration
addAgendaOperationExecutionListener, addConfigurator, addCustomPostCommandInterceptor, addCustomPreCommandInterceptor, addCustomSessionFactory, addEngineConfiguration, addEngineLifecycleListener, addEventRegistryEventConsumer, addServiceConfiguration, addSessionFactory, applyCustomMybatisCustomizations, close, configuratorsAfterInit, configuratorsBeforeInit, defaultInitDbSqlSessionFactoryEntitySettings, getAdditionalDefaultCommandInterceptors, getAdditionalEventDispatchActions, getAgendaOperationExecutionListeners, 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, 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, getObjectMapper, getPropertyDataManager, getPropertyEntityManager, getResourceAsStream, getSchemaCommandConfig, getSchemaLockWaitTime, getSchemaManagementCmd, getSchemaManager, getServiceConfigurations, getSessionFactories, getSqlSessionFactory, getTableDataManager, getTransactionContextFactory, getTransactionFactory, getTypedEventListeners, getXmlEncoding, initAdditionalEventDispatchActions, initBeans, initClock, initCommandContextFactory, initCommandExecutor, initCommandInterceptors, initCommandInvoker, initConfigurators, initCustomMybatisInterceptors, initCustomMybatisMappers, initDatabaseType, initDataSource, initDefaultCommandConfig, initEngineConfigurations, initEventDispatcher, initEventListeners, initIdGenerator, initInterceptorChain, initMybatisConfiguration, initMyBatisLogSqlExecutionTimePlugin, initObjectMapper, 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, setAgendaOperationExecutionListeners, 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 Details
-
DEFAULT_MYBATIS_MAPPING_FILE
- See Also:
-
LIQUIBASE_CHANGELOG_PREFIX
- See Also:
-
DEFAULT_RENDITION_MANAGER_KEY
- See Also:
-
contentEngineName
-
contentManagementService
-
documentRepositoryService
-
contentService
-
renditionService
-
metadataService
-
contentRenditionManagers
-
changeTenantIdManager
-
documentDeploymentDataManager
-
documentDefinitionDataManager
-
documentResourceDataManager
-
contentItemDataManager
-
renditionItemDataManager
-
metadataInstanceDataManager
-
databaseContentObjectDataManager
-
contentStorages
-
renditionEnhancers
-
contentRootFolder
-
createContentRootFolder
protected boolean createContentRootFolder -
contentItemContentObjectStorageMetadataProvider
protected CoreContentItemContentObjectStorageMetadataProvider contentItemContentObjectStorageMetadataProvider -
renditionItemContentObjectStorageMetadataProvider
protected RenditionItemContentObjectStorageMetadataProvider renditionItemContentObjectStorageMetadataProvider -
documentDeploymentEntityManager
-
documentDefinitionEntityManager
-
documentResourceEntityManager
-
contentItemEntityManager
-
renditionItemEntityManager
-
metadataInstanceEntityManager
-
databaseContentObjectEntityManager
-
jobSchemaManager
-
executeServiceSchemaManagers
protected boolean executeServiceSchemaManagers -
documentDefinitionDeployer
-
deploymentManager
-
documentResourceConverter
-
documentDefinitionCacheLimit
protected int documentDefinitionCacheLimit -
documentDefinitionCache
-
enginesBuild
-
jobServiceConfiguration
-
asyncExecutorConfiguration
-
asyncExecutor
-
asyncTaskExecutor
-
shutdownAsyncTaskExecutor
protected boolean shutdownAsyncTaskExecutor -
jobManager
-
customJobHandlers
-
jobHandlers
-
internalJobManager
-
customAsyncRunnableExecutionExceptionHandlers
protected List<AsyncRunnableExecutionExceptionHandler> customAsyncRunnableExecutionExceptionHandlers -
addDefaultExceptionHandler
protected boolean addDefaultExceptionHandler -
failedJobCommandFactory
-
internalJobParentStateResolver
-
jobExecutionScope
-
handleContentEngineExecutorsAfterEngineCreate
protected boolean handleContentEngineExecutorsAfterEngineCreate -
variableTypes
-
customPreVariableTypes
-
customPostVariableTypes
-
serializableVariableTypeTrackDeserializedObjects
protected boolean serializableVariableTypeTrackDeserializedObjects -
asyncExecutorActivate
protected boolean asyncExecutorActivateBoolean flag to be set to activate theAsyncExecutorautomatically after the engine has booted up. -
asyncExecutorNumberOfRetries
protected int asyncExecutorNumberOfRetriesThe number of retries for a job. -
lockTimeAsyncJobWaitTime
protected int lockTimeAsyncJobWaitTimeDefine 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 defaultFailedJobWaitTimeDefine the default wait time for a failed job in seconds -
asyncFailedJobWaitTime
protected int asyncFailedJobWaitTimeDefines the default wait time for a failed async job in seconds -
asyncExecutorCorePoolSize
protected int asyncExecutorCorePoolSizeThe 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 asyncExecutorMaxPoolSizeThe 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 asyncExecutorThreadKeepAliveTimeThe 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 asyncExecutorThreadPoolQueueSizeThe 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
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
ArrayBlockingQueuewill 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 asyncExecutorSecondsToWaitOnShutdownThe 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 asyncExecutorAllowCoreThreadTimeoutWhether 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
The thread factory that the async task executor should use. -
asyncExecutorResetExpiredJobsMaxTimeout
protected int asyncExecutorResetExpiredJobsMaxTimeoutThe 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.
-
asyncExecutorExecuteAsyncRunnableFactory
Allows to define a custom factory for creating theRunnablethat is executed by the async executor.This property is only applicable when using the threadpool-based async executor.
-
asyncHistoryExecutor
-
contentAsyncHistoryManager
-
contentCryptoHandler
-
renditionConverters
-
jsonVariableTypeTrackObjects
protected boolean jsonVariableTypeTrackObjectsThis 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");
-
-
Constructor Details
-
ContentEngineConfiguration
public ContentEngineConfiguration()
-
-
Method Details
-
createContentEngineConfigurationFromResourceDefault
-
createContentEngineConfigurationFromResource
public static ContentEngineConfiguration createContentEngineConfigurationFromResource(String resource) -
createContentEngineConfigurationFromResource
public static ContentEngineConfiguration createContentEngineConfigurationFromResource(String resource, String beanName) -
createContentEngineConfigurationFromInputStream
public static ContentEngineConfiguration createContentEngineConfigurationFromInputStream(InputStream inputStream) -
createContentEngineConfigurationFromInputStream
public static ContentEngineConfiguration createContentEngineConfigurationFromInputStream(InputStream inputStream, String beanName) -
createStandaloneContentEngineConfiguration
-
createStandaloneInMemContentEngineConfiguration
-
buildContentEngine
-
init
protected void init() -
initServices
protected void initServices() -
initDataManagers
public void initDataManagers()- Overrides:
initDataManagersin classAbstractEngineConfiguration
-
initEntityManagers
public void initEntityManagers()- Overrides:
initEntityManagersin classAbstractEngineConfiguration
-
initContentStorage
public void initContentStorage() -
initRenditionEnhancer
public void initRenditionEnhancer() -
initSchemaManager
public void initSchemaManager()- Overrides:
initSchemaManagerin classAbstractEngineConfiguration
-
initSchemaManagementCommand
public void initSchemaManagementCommand() -
initCommonSchemaManager
protected void initCommonSchemaManager() -
initJobSchemaManager
protected void initJobSchemaManager() -
initSessionFactories
public void initSessionFactories()- Overrides:
initSessionFactoriesin classAbstractEngineConfiguration
-
initDbSqlSessionFactory
public void initDbSqlSessionFactory()- Overrides:
initDbSqlSessionFactoryin classAbstractEngineConfiguration
-
createDbSqlSessionFactory
- Overrides:
createDbSqlSessionFactoryin classAbstractEngineConfiguration
-
initDbSqlSessionFactoryEntitySettings
protected void initDbSqlSessionFactoryEntitySettings()- Specified by:
initDbSqlSessionFactoryEntitySettingsin classAbstractEngineConfiguration
-
initMybatisTypeHandlers
public void initMybatisTypeHandlers(org.apache.ibatis.session.Configuration configuration) - Overrides:
initMybatisTypeHandlersin classAbstractEngineConfiguration
-
initVariableTypes
public void initVariableTypes() -
initCommandExecutors
public void initCommandExecutors()- Overrides:
initCommandExecutorsin classAbstractEngineConfiguration
-
getEngineCfgKey
- Specified by:
getEngineCfgKeyin classAbstractEngineConfiguration
-
getEngineScopeType
- Specified by:
getEngineScopeTypein classAbstractEngineConfiguration
-
createTransactionInterceptor
- Specified by:
createTransactionInterceptorin classAbstractEngineConfiguration
-
getMyBatisXmlConfigurationStream
- Specified by:
getMyBatisXmlConfigurationStreamin classAbstractEngineConfiguration
-
initDeployers
protected void initDeployers() -
getDefaultDeployers
-
initDocumentDefinitionCache
protected void initDocumentDefinitionCache() -
initDocumentResourceConverter
protected void initDocumentResourceConverter() -
initDeploymentManager
protected void initDeploymentManager() -
initContentRenditionManager
public void initContentRenditionManager() -
initChangeTenantIdManager
public void initChangeTenantIdManager() -
initJobHandlers
public void initJobHandlers() -
initFailedJobCommandFactory
public void initFailedJobCommandFactory() -
initJobServiceConfiguration
public void initJobServiceConfiguration() -
initAsyncTaskExecutor
protected void initAsyncTaskExecutor() -
initAsyncExecutor
public void initAsyncExecutor() -
getOrCreateAsyncExecutorConfiguration
-
getEngineName
- Specified by:
getEngineNamein classAbstractEngineConfiguration
-
setEngineName
-
setDatabaseType
- Overrides:
setDatabaseTypein classAbstractEngineConfiguration
-
setDataSource
- Overrides:
setDataSourcein classAbstractEngineConfiguration
-
setJdbcDriver
- Overrides:
setJdbcDriverin classAbstractEngineConfiguration
-
setJdbcUrl
- Overrides:
setJdbcUrlin classAbstractEngineConfiguration
-
setJdbcUsername
- Overrides:
setJdbcUsernamein classAbstractEngineConfiguration
-
setJdbcPassword
- Overrides:
setJdbcPasswordin classAbstractEngineConfiguration
-
setJdbcMaxActiveConnections
- Overrides:
setJdbcMaxActiveConnectionsin classAbstractEngineConfiguration
-
setJdbcMaxIdleConnections
- Overrides:
setJdbcMaxIdleConnectionsin classAbstractEngineConfiguration
-
setJdbcMaxCheckoutTime
- Overrides:
setJdbcMaxCheckoutTimein classAbstractEngineConfiguration
-
setJdbcMaxWaitTime
- Overrides:
setJdbcMaxWaitTimein classAbstractEngineConfiguration
-
setJdbcPingEnabled
- Overrides:
setJdbcPingEnabledin classAbstractEngineConfiguration
-
setJdbcPingConnectionNotUsedFor
- Overrides:
setJdbcPingConnectionNotUsedForin classAbstractEngineConfiguration
-
setJdbcDefaultTransactionIsolationLevel
public ContentEngineConfiguration setJdbcDefaultTransactionIsolationLevel(int jdbcDefaultTransactionIsolationLevel) - Overrides:
setJdbcDefaultTransactionIsolationLevelin classAbstractEngineConfiguration
-
setJdbcPingQuery
- Overrides:
setJdbcPingQueryin classAbstractEngineConfiguration
-
setDataSourceJndiName
- Overrides:
setDataSourceJndiNamein classAbstractEngineConfiguration
-
getContentManagementService
- Specified by:
getContentManagementServicein interfaceContentEngineConfigurationApi
-
setContentManagementService
public ContentEngineConfiguration setContentManagementService(ContentManagementService contentManagementService) -
getDocumentRepositoryService
- Specified by:
getDocumentRepositoryServicein interfaceCoreContentEngineConfigurationApi
-
setDocumentRepositoryService
public ContentEngineConfiguration setDocumentRepositoryService(DocumentRepositoryService documentRepositoryService) -
getContentService
- Specified by:
getContentServicein interfaceContentEngineConfigurationApi- Specified by:
getContentServicein interfaceCoreContentEngineConfigurationApi
-
setContentService
-
getRenditionService
- Specified by:
getRenditionServicein interfaceCoreContentEngineConfigurationApi
-
setRenditionService
-
getMetadataService
- Specified by:
getMetadataServicein interfaceCoreContentEngineConfigurationApi
-
setMetadataService
-
getContentEngineConfiguration
-
getDocumentDeploymentDataManager
-
setDocumentDeploymentDataManager
public ContentEngineConfiguration setDocumentDeploymentDataManager(DocumentDeploymentDataManager documentDeploymentDataManager) -
getDocumentDefinitionDataManager
-
setDocumentDefinitionDataManager
public ContentEngineConfiguration setDocumentDefinitionDataManager(DocumentDefinitionDataManager documentDefinitionDataManager) -
getDocumentResourceDataManager
-
setDocumentResourceDataManager
public ContentEngineConfiguration setDocumentResourceDataManager(DocumentResourceDataManager documentResourceDataManager) -
getContentItemDataManager
-
setContentItemDataManager
public ContentEngineConfiguration setContentItemDataManager(ContentItemDataManager contentItemDataManager) -
getRenditionItemDataManager
-
setRenditionItemDataManager
public ContentEngineConfiguration setRenditionItemDataManager(RenditionItemDataManager renditionItemDataManager) -
getMetadataInstanceDataManager
-
setMetadataInstanceDataManager
public ContentEngineConfiguration setMetadataInstanceDataManager(MetadataInstanceDataManager metadataInstanceDataManager) -
getDocumentDeploymentEntityManager
-
setDocumentDeploymentEntityManager
public ContentEngineConfiguration setDocumentDeploymentEntityManager(DocumentDeploymentEntityManager documentDeploymentEntityManager) -
getDocumentDefinitionEntityManager
-
setDocumentDefinitionEntityManager
public ContentEngineConfiguration setDocumentDefinitionEntityManager(DocumentDefinitionEntityManager documentDefinitionEntityManager) -
getDocumentResourceEntityManager
-
setDocumentResourceEntityManager
public ContentEngineConfiguration setDocumentResourceEntityManager(DocumentResourceEntityManager documentResourceEntityManager) -
getContentItemEntityManager
-
setContentItemEntityManager
public ContentEngineConfiguration setContentItemEntityManager(ContentItemEntityManager contentItemEntityManager) -
getRenditionItemEntityManager
-
setRenditionItemEntityManager
public ContentEngineConfiguration setRenditionItemEntityManager(RenditionItemEntityManager renditionItemEntityManager) -
getMetadataInstanceEntityManager
-
setMetadataInstanceEntityManager
public ContentEngineConfiguration setMetadataInstanceEntityManager(MetadataInstanceEntityManager metadataInstanceEntityManager) -
getDatabaseContentObjectEntityManager
-
setDatabaseContentObjectEntityManager
public ContentEngineConfiguration setDatabaseContentObjectEntityManager(DatabaseContentObjectEntityManager databaseContentObjectEntityManager) -
setTableDataManager
- Overrides:
setTableDataManagerin classAbstractEngineConfiguration
-
addContentStorage
-
getContentStorages
-
setContentStorages
-
getContentStorage
-
getContentRootFolder
-
setContentRootFolder
-
isCreateContentRootFolder
public boolean isCreateContentRootFolder() -
setCreateContentRootFolder
-
getContentItemContentObjectStorageMetadataProvider
public CoreContentItemContentObjectStorageMetadataProvider getContentItemContentObjectStorageMetadataProvider() -
setContentItemContentObjectStorageMetadataProvider
public void setContentItemContentObjectStorageMetadataProvider(CoreContentItemContentObjectStorageMetadataProvider contentItemContentObjectStorageMetadataProvider) -
getRenditionItemContentObjectStorageMetadataProvider
public RenditionItemContentObjectStorageMetadataProvider getRenditionItemContentObjectStorageMetadataProvider() -
setRenditionItemContentObjectStorageMetadataProvider
public void setRenditionItemContentObjectStorageMetadataProvider(RenditionItemContentObjectStorageMetadataProvider renditionItemContentObjectStorageMetadataProvider) -
getContentRenditionManager
-
addContentRenditionManager
-
getChangeTenantIdManager
-
setChangeTenantIdManager
-
getContentCryptoHandler
-
setContentCryptoHandler
-
getRenditionConverters
-
setRenditionConverters
-
setSqlSessionFactory
public ContentEngineConfiguration setSqlSessionFactory(org.apache.ibatis.session.SqlSessionFactory sqlSessionFactory) - Overrides:
setSqlSessionFactoryin classAbstractEngineConfiguration
-
setTransactionFactory
public ContentEngineConfiguration setTransactionFactory(org.apache.ibatis.transaction.TransactionFactory transactionFactory) - Overrides:
setTransactionFactoryin classAbstractEngineConfiguration
-
setCustomMybatisMappers
- Overrides:
setCustomMybatisMappersin classAbstractEngineConfiguration
-
setCustomMybatisXMLMappers
- Overrides:
setCustomMybatisXMLMappersin classAbstractEngineConfiguration
-
setCustomSessionFactories
public ContentEngineConfiguration setCustomSessionFactories(List<SessionFactory> customSessionFactories) - Overrides:
setCustomSessionFactoriesin classAbstractEngineConfiguration
-
setUsingRelationalDatabase
- Overrides:
setUsingRelationalDatabasein classAbstractEngineConfiguration
-
setDatabaseTablePrefix
- Overrides:
setDatabaseTablePrefixin classAbstractEngineConfiguration
-
setDatabaseCatalog
- Overrides:
setDatabaseCatalogin classAbstractEngineConfiguration
-
setDatabaseSchema
- Overrides:
setDatabaseSchemain classAbstractEngineConfiguration
-
setTablePrefixIsSchema
- Overrides:
setTablePrefixIsSchemain classAbstractEngineConfiguration
-
setSessionFactories
public ContentEngineConfiguration setSessionFactories(Map<Class<?>, SessionFactory> sessionFactories) - Overrides:
setSessionFactoriesin classAbstractEngineConfiguration
-
setDatabaseSchemaUpdate
- Overrides:
setDatabaseSchemaUpdatein classAbstractEngineConfiguration
-
getJobSchemaManager
-
setJobSchemaManager
-
isExecuteServiceSchemaManagers
public boolean isExecuteServiceSchemaManagers() -
setExecuteServiceSchemaManagers
public ContentEngineConfiguration setExecuteServiceSchemaManagers(boolean executeServiceSchemaManagers) -
getDocumentDefinitionDeployer
-
setDocumentDefinitionDeployer
public ContentEngineConfiguration setDocumentDefinitionDeployer(DocumentDefinitionDeployer documentDefinitionDeployer) -
getDeploymentManager
-
setDeploymentManager
-
getDocumentResourceConverter
- Specified by:
getDocumentResourceConverterin interfaceCoreContentEngineConfigurationApi
-
setDocumentResourceConverter
public ContentEngineConfiguration setDocumentResourceConverter(DocumentResourceConverter documentResourceConverter) -
getDocumentDefinitionCacheLimit
public int getDocumentDefinitionCacheLimit() -
setDocumentDefinitionCacheLimit
-
getDocumentDefinitionCache
-
setDocumentDefinitionCache
public ContentEngineConfiguration setDocumentDefinitionCache(DeploymentCache<DocumentDefinitionCacheEntry> documentDefinitionCache) -
getJobServiceConfiguration
-
setJobServiceConfiguration
public ContentEngineConfiguration setJobServiceConfiguration(JobServiceConfiguration jobServiceConfiguration) -
getAsyncExecutor
-
setAsyncExecutor
-
getJobManager
-
setJobManager
-
getCustomJobHandlers
-
setCustomJobHandlers
-
getJobHandlers
-
setJobHandlers
-
getInternalJobManager
-
setInternalJobManager
-
getCustomAsyncRunnableExecutionExceptionHandlers
public List<AsyncRunnableExecutionExceptionHandler> getCustomAsyncRunnableExecutionExceptionHandlers() -
setCustomAsyncRunnableExecutionExceptionHandlers
public ContentEngineConfiguration setCustomAsyncRunnableExecutionExceptionHandlers(List<AsyncRunnableExecutionExceptionHandler> customAsyncRunnableExecutionExceptionHandlers) -
getFailedJobCommandFactory
-
setFailedJobCommandFactory
public ContentEngineConfiguration setFailedJobCommandFactory(FailedJobCommandFactory failedJobCommandFactory) -
getInternalJobParentStateResolver
-
setInternalJobParentStateResolver
public ContentEngineConfiguration setInternalJobParentStateResolver(InternalJobParentStateResolver internalJobParentStateResolver) -
getJobExecutionScope
-
setJobExecutionScope
-
isAsyncExecutorActivate
public boolean isAsyncExecutorActivate() -
setAsyncExecutorActivate
-
getAsyncExecutorNumberOfRetries
public int getAsyncExecutorNumberOfRetries() -
setAsyncExecutorNumberOfRetries
-
getLockTimeAsyncJobWaitTime
public int getLockTimeAsyncJobWaitTime() -
setLockTimeAsyncJobWaitTime
-
getDefaultFailedJobWaitTime
public int getDefaultFailedJobWaitTime() -
setDefaultFailedJobWaitTime
-
getAsyncFailedJobWaitTime
public int getAsyncFailedJobWaitTime() -
setAsyncFailedJobWaitTime
-
getAsyncExecutorCorePoolSize
public int getAsyncExecutorCorePoolSize() -
setAsyncExecutorCorePoolSize
-
getAsyncExecutorMaxPoolSize
public int getAsyncExecutorMaxPoolSize() -
setAsyncExecutorMaxPoolSize
-
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
-
getAsyncExecutorConfiguration
-
setAsyncExecutorConfiguration
public ContentEngineConfiguration setAsyncExecutorConfiguration(AsyncJobExecutorConfiguration asyncExecutorConfiguration) -
getAsyncExecutorDefaultTimerJobAcquireWaitTime
-
setAsyncExecutorDefaultTimerJobAcquireWaitTime
@Deprecated public ContentEngineConfiguration setAsyncExecutorDefaultTimerJobAcquireWaitTime(int asyncExecutorDefaultTimerJobAcquireWaitTime) -
getAsyncExecutorTenantId
Deprecated. -
setAsyncExecutorTenantId
@Deprecated public ContentEngineConfiguration setAsyncExecutorTenantId(String asyncExecutorTenantId) Deprecated. -
getAsyncExecutorThreadPoolQueue
-
setAsyncExecutorThreadPoolQueue
public ContentEngineConfiguration setAsyncExecutorThreadPoolQueue(BlockingQueue<Runnable> asyncExecutorThreadPoolQueue) -
getAsyncExecutorSecondsToWaitOnShutdown
public long getAsyncExecutorSecondsToWaitOnShutdown() -
setAsyncExecutorSecondsToWaitOnShutdown
public ContentEngineConfiguration setAsyncExecutorSecondsToWaitOnShutdown(long asyncExecutorSecondsToWaitOnShutdown) -
getAsyncTaskExecutor
-
setAsyncTaskExecutor
-
isAsyncExecutorAllowCoreThreadTimeout
public boolean isAsyncExecutorAllowCoreThreadTimeout() -
setAsyncExecutorAllowCoreThreadTimeout
public ContentEngineConfiguration setAsyncExecutorAllowCoreThreadTimeout(boolean asyncExecutorAllowCoreThreadTimeout) -
getAsyncExecutorThreadFactory
-
setAsyncExecutorThreadFactory
public ContentEngineConfiguration setAsyncExecutorThreadFactory(ThreadFactory asyncExecutorThreadFactory) -
getAsyncExecutorMaxAsyncJobsDuePerAcquisition
-
setAsyncExecutorMaxAsyncJobsDuePerAcquisition
@Deprecated public ContentEngineConfiguration setAsyncExecutorMaxAsyncJobsDuePerAcquisition(int asyncExecutorMaxAsyncJobsDuePerAcquisition) -
getAsyncExecutorDefaultAsyncJobAcquireWaitTime
-
setAsyncExecutorDefaultAsyncJobAcquireWaitTime
@Deprecated public ContentEngineConfiguration setAsyncExecutorDefaultAsyncJobAcquireWaitTime(int asyncExecutorDefaultAsyncJobAcquireWaitTime) -
getAsyncExecutorDefaultQueueSizeFullWaitTime
-
setAsyncExecutorDefaultQueueSizeFullWaitTime
@Deprecated public ContentEngineConfiguration setAsyncExecutorDefaultQueueSizeFullWaitTime(int asyncExecutorDefaultQueueSizeFullWaitTime) -
getAsyncExecutorLockOwner
Deprecated. -
setAsyncExecutorLockOwner
@Deprecated public ContentEngineConfiguration setAsyncExecutorLockOwner(String asyncExecutorLockOwner) Deprecated. -
getAsyncExecutorAsyncJobLockTimeInMillis
Deprecated. -
setAsyncExecutorAsyncJobLockTimeInMillis
@Deprecated public ContentEngineConfiguration setAsyncExecutorAsyncJobLockTimeInMillis(int asyncExecutorAsyncJobLockTimeInMillis) -
getAsyncExecutorResetExpiredJobsInterval
-
setAsyncExecutorResetExpiredJobsInterval
@Deprecated public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsInterval(int asyncExecutorResetExpiredJobsInterval) -
getAsyncExecutorResetExpiredJobsMaxTimeout
Deprecated. -
setAsyncExecutorResetExpiredJobsMaxTimeout
public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsMaxTimeout(int asyncExecutorResetExpiredJobsMaxTimeout) -
getAsyncExecutorResetExpiredJobsPageSize
-
setAsyncExecutorResetExpiredJobsPageSize
@Deprecated public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsPageSize(int asyncExecutorResetExpiredJobsPageSize) -
getAsyncExecutorExecuteAsyncRunnableFactory
-
setAsyncExecutorExecuteAsyncRunnableFactory
public ContentEngineConfiguration setAsyncExecutorExecuteAsyncRunnableFactory(ExecuteAsyncRunnableFactory asyncExecutorExecuteAsyncRunnableFactory) -
isAsyncExecutorAsyncJobAcquisitionEnabled
-
setAsyncExecutorAsyncJobAcquisitionEnabled
@Deprecated public ContentEngineConfiguration setAsyncExecutorAsyncJobAcquisitionEnabled(boolean isAsyncExecutorAsyncJobAcquisitionEnabled) -
isAsyncExecutorResetExpiredJobsEnabled
-
setAsyncExecutorResetExpiredJobsEnabled
@Deprecated public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsEnabled(boolean isAsyncExecutorResetExpiredJobsEnabled) -
getAsyncHistoryExecutor
-
setAsyncHistoryExecutor
-
getContentAsyncHistoryManager
-
setContentAsyncHistoryManager
public ContentEngineConfiguration setContentAsyncHistoryManager(ContentAsyncHistoryManager contentAsyncHistoryManager) -
getVariableTypes
-
setVariableTypes
-
getCustomPreVariableTypes
-
setCustomPreVariableTypes
public ContentEngineConfiguration setCustomPreVariableTypes(List<VariableType> customPreVariableTypes) -
getCustomPostVariableTypes
-
setCustomPostVariableTypes
public ContentEngineConfiguration setCustomPostVariableTypes(List<VariableType> customPostVariableTypes) -
isJsonVariableTypeTrackObjects
public boolean isJsonVariableTypeTrackObjects() -
setJsonVariableTypeTrackObjects
public ContentEngineConfiguration setJsonVariableTypeTrackObjects(boolean jsonVariableTypeTrackObjects) -
setObjectMapper
public ContentEngineConfiguration setObjectMapper(com.fasterxml.jackson.databind.ObjectMapper objectMapper) - Overrides:
setObjectMapperin classAbstractEngineConfiguration
-
getRenditionItemEnhancer
-
addRenditionItemEnhancer
-
AsyncJobExecutorConfiguration.getAsyncJobLockTime()viagetAsyncExecutorConfiguration()