public class ContentEngineConfiguration extends AbstractEngineConfiguration implements CoreContentEngineConfigurationApi
Modifier and Type | Field and Description |
---|---|
protected boolean |
addDefaultExceptionHandler |
protected AsyncExecutor |
asyncExecutor |
protected boolean |
asyncExecutorActivate
Boolean flag to be set to activate the
AsyncExecutor 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 ExecuteAsyncRunnableFactory |
asyncExecutorExecuteAsyncRunnableFactory
Allows to define a custom factory for creating the
Runnable that is executed by the async executor. |
protected 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 default
AsyncExecutor 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 String |
asyncExecutorTenantId
Tenant for the async executor, if any.
|
protected 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 BlockingQueue<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 seconds
|
protected AsyncExecutor |
asyncHistoryExecutor |
protected AsyncHistoryListener |
asyncHistoryListener |
protected AsyncTaskExecutor |
asyncTaskExecutor |
protected ContentAsyncHistoryManager |
contentAsyncHistoryManager |
protected ContentCryptoHandler |
contentCryptoHandler |
protected String |
contentEngineName |
protected CoreContentItemContentObjectStorageMetadataProvider |
contentItemContentObjectStorageMetadataProvider |
protected ContentItemDataManager |
contentItemDataManager |
protected ContentItemEntityManager |
contentItemEntityManager |
protected ContentManagementService |
contentManagementService |
protected ContentRenditionManager |
contentRenditionManager |
protected String |
contentRootFolder |
protected CoreContentService |
contentService |
protected ContentStorage |
contentStorage |
protected boolean |
createContentRootFolder |
protected List<AsyncRunnableExecutionExceptionHandler> |
customAsyncRunnableExecutionExceptionHandlers |
protected List<JobHandler> |
customJobHandlers |
protected List<VariableType> |
customPostVariableTypes |
protected List<VariableType> |
customPreVariableTypes |
protected DatabaseContentObjectDataManager |
databaseContentObjectDataManager |
protected DatabaseContentObjectEntityManager |
databaseContentObjectEntityManager |
static String |
DEFAULT_MYBATIS_MAPPING_FILE |
protected int |
defaultFailedJobWaitTime
Define the default wait time for a failed job in seconds
|
protected DocumentDeploymentManager |
deploymentManager |
protected 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 List<String> |
enginesBuild |
protected boolean |
executeServiceSchemaManagers |
protected FailedJobCommandFactory |
failedJobCommandFactory |
protected boolean |
handleContentEngineExecutorsAfterEngineCreate |
protected InternalJobManager |
internalJobManager |
protected 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 String |
jobExecutionScope |
protected Map<String,JobHandler> |
jobHandlers |
protected JobManager |
jobManager |
protected SchemaManager |
jobSchemaManager |
protected JobServiceConfiguration |
jobServiceConfiguration |
protected boolean |
jsonVariableTypeTrackObjects
This flag determines whether variables of the type 'json' and 'longJson' will be tracked.
|
static 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 List<RenditionConverter> |
renditionConverters |
protected RenditionItemContentObjectStorageMetadataProvider |
renditionItemContentObjectStorageMetadataProvider |
protected RenditionItemDataManager |
renditionItemDataManager |
protected RenditionItemEntityManager |
renditionItemEntityManager |
protected RenditionService |
renditionService |
protected boolean |
serializableVariableTypeTrackDeserializedObjects |
protected boolean |
shutdownAsyncTaskExecutor |
protected VariableTypes |
variableTypes |
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, 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 and Description |
---|
ContentEngineConfiguration() |
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, getObjectMapper, 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, 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, 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
protected static final org.slf4j.Logger LOGGER
public static final String DEFAULT_MYBATIS_MAPPING_FILE
public static final String LIQUIBASE_CHANGELOG_PREFIX
protected String contentEngineName
protected ContentManagementService contentManagementService
protected DocumentRepositoryService documentRepositoryService
protected CoreContentService contentService
protected RenditionService renditionService
protected MetadataService metadataService
protected ContentRenditionManager contentRenditionManager
protected DocumentDeploymentDataManager documentDeploymentDataManager
protected DocumentDefinitionDataManager documentDefinitionDataManager
protected DocumentResourceDataManager documentResourceDataManager
protected ContentItemDataManager contentItemDataManager
protected RenditionItemDataManager renditionItemDataManager
protected MetadataInstanceDataManager metadataInstanceDataManager
protected DatabaseContentObjectDataManager databaseContentObjectDataManager
protected ContentStorage contentStorage
protected String contentRootFolder
protected boolean createContentRootFolder
protected CoreContentItemContentObjectStorageMetadataProvider contentItemContentObjectStorageMetadataProvider
protected RenditionItemContentObjectStorageMetadataProvider renditionItemContentObjectStorageMetadataProvider
protected DocumentDeploymentEntityManager documentDeploymentEntityManager
protected DocumentDefinitionEntityManager documentDefinitionEntityManager
protected DocumentResourceEntityManager documentResourceEntityManager
protected ContentItemEntityManager contentItemEntityManager
protected RenditionItemEntityManager renditionItemEntityManager
protected MetadataInstanceEntityManager metadataInstanceEntityManager
protected DatabaseContentObjectEntityManager databaseContentObjectEntityManager
protected SchemaManager jobSchemaManager
protected boolean executeServiceSchemaManagers
protected DocumentDefinitionDeployer documentDefinitionDeployer
protected DocumentDeploymentManager deploymentManager
protected DocumentResourceConverter documentResourceConverter
protected int documentDefinitionCacheLimit
protected DeploymentCache<DocumentDefinitionCacheEntry> documentDefinitionCache
protected JobServiceConfiguration jobServiceConfiguration
protected AsyncExecutor asyncExecutor
protected AsyncTaskExecutor asyncTaskExecutor
protected boolean shutdownAsyncTaskExecutor
protected JobManager jobManager
protected List<JobHandler> customJobHandlers
protected Map<String,JobHandler> jobHandlers
protected InternalJobManager internalJobManager
protected List<AsyncRunnableExecutionExceptionHandler> customAsyncRunnableExecutionExceptionHandlers
protected boolean addDefaultExceptionHandler
protected FailedJobCommandFactory failedJobCommandFactory
protected InternalJobParentStateResolver internalJobParentStateResolver
protected String jobExecutionScope
protected boolean handleContentEngineExecutorsAfterEngineCreate
protected VariableTypes variableTypes
protected List<VariableType> customPreVariableTypes
protected List<VariableType> customPostVariableTypes
protected boolean serializableVariableTypeTrackDeserializedObjects
protected boolean asyncExecutorActivate
AsyncExecutor
automatically after the engine has booted up.protected boolean asyncExecutorMessageQueueMode
Set this to true when using the message queue based job executor.
protected int asyncExecutorNumberOfRetries
protected int lockTimeAsyncJobWaitTime
protected int defaultFailedJobWaitTime
protected int asyncFailedJobWaitTime
protected int asyncExecutorCorePoolSize
This property is only applicable when using the threadpool-based async executor.
protected int asyncExecutorMaxPoolSize
This property is only applicable when using the threadpool-based async executor.
protected long asyncExecutorThreadKeepAliveTime
This property is only applicable when using the threadpool-based async executor.
protected int asyncExecutorThreadPoolQueueSize
This property is only applicable when using the threadpool-based async executor.
protected BlockingQueue<Runnable> asyncExecutorThreadPoolQueue
By default null. If null, an ArrayBlockingQueue
will be created of size asyncExecutorThreadPoolQueueSize
.
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.
protected long asyncExecutorSecondsToWaitOnShutdown
This property is only applicable when using the threadpool-based async executor.
protected boolean asyncExecutorAllowCoreThreadTimeout
protected ThreadFactory asyncExecutorThreadFactory
protected int asyncExecutorMaxAsyncJobsDuePerAcquisition
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.
protected int asyncExecutorDefaultTimerJobAcquireWaitTime
(This property is only applicable when using the DefaultAsyncJobExecutor
).
protected int asyncExecutorDefaultAsyncJobAcquireWaitTime
asyncExecutorMaxAsyncJobsDuePerAcquisition
. Default value = 10 seconds.
This property is only applicable when using the threadpool-based async executor.
protected int asyncExecutorDefaultQueueSizeFullWaitTime
protected String asyncExecutorLockOwner
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.
protected String asyncExecutorTenantId
protected int asyncExecutorAsyncJobLockTimeInMillis
protected int asyncExecutorResetExpiredJobsInterval
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.
protected int asyncExecutorResetExpiredJobsMaxTimeout
By default 24 hours, as this should be a very exceptional case.
protected int asyncExecutorResetExpiredJobsPageSize
AsyncExecutor
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.protected ExecuteAsyncRunnableFactory asyncExecutorExecuteAsyncRunnableFactory
Runnable
that is executed by the async executor.
This property is only applicable when using the threadpool-based async executor.
protected boolean isAsyncExecutorAsyncJobAcquisitionEnabled
protected boolean isAsyncExecutorResetExpiredJobsEnabled
protected AsyncExecutor asyncHistoryExecutor
protected boolean isAsyncHistoryEnabled
protected AsyncHistoryListener asyncHistoryListener
protected ContentAsyncHistoryManager contentAsyncHistoryManager
protected ContentCryptoHandler contentCryptoHandler
protected List<RenditionConverter> renditionConverters
protected boolean jsonVariableTypeTrackObjects
This means that, when true, in a JavaDelegate you can write:
JsonNode jsonNode = (JsonNode) execution.getVariable("customer");
customer.put("name", "Kermit");
And the changes to the JsonNode will be reflected in the database. Otherwise, a manual call to setVariable will be needed.public static ContentEngineConfiguration createContentEngineConfigurationFromResourceDefault()
public static ContentEngineConfiguration createContentEngineConfigurationFromResource(String resource)
public static ContentEngineConfiguration createContentEngineConfigurationFromResource(String resource, String beanName)
public static ContentEngineConfiguration createContentEngineConfigurationFromInputStream(InputStream inputStream)
public static ContentEngineConfiguration createContentEngineConfigurationFromInputStream(InputStream inputStream, String beanName)
public static ContentEngineConfiguration createStandaloneContentEngineConfiguration()
public static ContentEngineConfiguration createStandaloneInMemContentEngineConfiguration()
public ContentEngine buildContentEngine()
protected void init()
protected void initServices()
public void initDataManagers()
initDataManagers
in class AbstractEngineConfiguration
public void initEntityManagers()
initEntityManagers
in class AbstractEngineConfiguration
public void initContentStorage()
public void initSchemaManager()
initSchemaManager
in class AbstractEngineConfiguration
public void initSchemaManagementCommand()
protected void initCommonSchemaManager()
protected void initJobSchemaManager()
public void initSessionFactories()
initSessionFactories
in class AbstractEngineConfiguration
public void initDbSqlSessionFactory()
initDbSqlSessionFactory
in class AbstractEngineConfiguration
public DbSqlSessionFactory createDbSqlSessionFactory()
createDbSqlSessionFactory
in class AbstractEngineConfiguration
protected void initDbSqlSessionFactoryEntitySettings()
initDbSqlSessionFactoryEntitySettings
in class AbstractEngineConfiguration
public void initMybatisTypeHandlers(org.apache.ibatis.session.Configuration configuration)
initMybatisTypeHandlers
in class AbstractEngineConfiguration
public void initAsyncHistorySessionFactory()
protected void initDefaultAsyncHistoryListener()
public void initVariableTypes()
public void initCommandExecutors()
initCommandExecutors
in class AbstractEngineConfiguration
public void initCommandInterceptors()
initCommandInterceptors
in class AbstractEngineConfiguration
public String getEngineCfgKey()
getEngineCfgKey
in class AbstractEngineConfiguration
public String getEngineScopeType()
getEngineScopeType
in class AbstractEngineConfiguration
public CommandInterceptor createTransactionInterceptor()
createTransactionInterceptor
in class AbstractEngineConfiguration
public InputStream getMyBatisXmlConfigurationStream()
getMyBatisXmlConfigurationStream
in class AbstractEngineConfiguration
protected void initDeployers()
public Collection<? extends EngineDeployer> getDefaultDeployers()
protected void initDocumentDefinitionCache()
protected void initDocumentResourceConverter()
protected void initDeploymentManager()
public void initContentRenditionManager()
public void initJobHandlers()
public void initFailedJobCommandFactory()
public void initJobServiceConfiguration()
protected void initAsyncTaskExecutor()
public void initAsyncExecutor()
public String getEngineName()
getEngineName
in class AbstractEngineConfiguration
public ContentEngineConfiguration setEngineName(String contentEngineName)
public ContentEngineConfiguration setDatabaseType(String databaseType)
setDatabaseType
in class AbstractEngineConfiguration
public ContentEngineConfiguration setDataSource(DataSource dataSource)
setDataSource
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcDriver(String jdbcDriver)
setJdbcDriver
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcUrl(String jdbcUrl)
setJdbcUrl
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcUsername(String jdbcUsername)
setJdbcUsername
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcPassword(String jdbcPassword)
setJdbcPassword
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcMaxActiveConnections(int jdbcMaxActiveConnections)
setJdbcMaxActiveConnections
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcMaxIdleConnections(int jdbcMaxIdleConnections)
setJdbcMaxIdleConnections
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcMaxCheckoutTime(int jdbcMaxCheckoutTime)
setJdbcMaxCheckoutTime
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcMaxWaitTime(int jdbcMaxWaitTime)
setJdbcMaxWaitTime
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcPingEnabled(boolean jdbcPingEnabled)
setJdbcPingEnabled
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcPingConnectionNotUsedFor(int jdbcPingConnectionNotUsedFor)
setJdbcPingConnectionNotUsedFor
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcDefaultTransactionIsolationLevel(int jdbcDefaultTransactionIsolationLevel)
setJdbcDefaultTransactionIsolationLevel
in class AbstractEngineConfiguration
public ContentEngineConfiguration setJdbcPingQuery(String jdbcPingQuery)
setJdbcPingQuery
in class AbstractEngineConfiguration
public ContentEngineConfiguration setDataSourceJndiName(String dataSourceJndiName)
setDataSourceJndiName
in class AbstractEngineConfiguration
public ContentManagementService getContentManagementService()
getContentManagementService
in interface ContentEngineConfigurationApi
public ContentEngineConfiguration setContentManagementService(ContentManagementService contentManagementService)
public DocumentRepositoryService getDocumentRepositoryService()
getDocumentRepositoryService
in interface CoreContentEngineConfigurationApi
public ContentEngineConfiguration setDocumentRepositoryService(DocumentRepositoryService documentRepositoryService)
public CoreContentService getContentService()
getContentService
in interface CoreContentEngineConfigurationApi
getContentService
in interface ContentEngineConfigurationApi
public ContentEngineConfiguration setContentService(CoreContentService contentService)
public RenditionService getRenditionService()
getRenditionService
in interface CoreContentEngineConfigurationApi
public ContentEngineConfiguration setRenditionService(RenditionService renditionService)
public MetadataService getMetadataService()
getMetadataService
in interface CoreContentEngineConfigurationApi
public ContentEngineConfiguration setMetadataService(MetadataService metadataService)
public ContentEngineConfiguration getContentEngineConfiguration()
public DocumentDeploymentDataManager getDocumentDeploymentDataManager()
public ContentEngineConfiguration setDocumentDeploymentDataManager(DocumentDeploymentDataManager documentDeploymentDataManager)
public DocumentDefinitionDataManager getDocumentDefinitionDataManager()
public ContentEngineConfiguration setDocumentDefinitionDataManager(DocumentDefinitionDataManager documentDefinitionDataManager)
public DocumentResourceDataManager getDocumentResourceDataManager()
public ContentEngineConfiguration setDocumentResourceDataManager(DocumentResourceDataManager documentResourceDataManager)
public ContentItemDataManager getContentItemDataManager()
public ContentEngineConfiguration setContentItemDataManager(ContentItemDataManager contentItemDataManager)
public RenditionItemDataManager getRenditionItemDataManager()
public ContentEngineConfiguration setRenditionItemDataManager(RenditionItemDataManager renditionItemDataManager)
public MetadataInstanceDataManager getMetadataInstanceDataManager()
public ContentEngineConfiguration setMetadataInstanceDataManager(MetadataInstanceDataManager metadataInstanceDataManager)
public DocumentDeploymentEntityManager getDocumentDeploymentEntityManager()
public ContentEngineConfiguration setDocumentDeploymentEntityManager(DocumentDeploymentEntityManager documentDeploymentEntityManager)
public DocumentDefinitionEntityManager getDocumentDefinitionEntityManager()
public ContentEngineConfiguration setDocumentDefinitionEntityManager(DocumentDefinitionEntityManager documentDefinitionEntityManager)
public DocumentResourceEntityManager getDocumentResourceEntityManager()
public ContentEngineConfiguration setDocumentResourceEntityManager(DocumentResourceEntityManager documentResourceEntityManager)
public ContentItemEntityManager getContentItemEntityManager()
public ContentEngineConfiguration setContentItemEntityManager(ContentItemEntityManager contentItemEntityManager)
public RenditionItemEntityManager getRenditionItemEntityManager()
public ContentEngineConfiguration setRenditionItemEntityManager(RenditionItemEntityManager renditionItemEntityManager)
public MetadataInstanceEntityManager getMetadataInstanceEntityManager()
public ContentEngineConfiguration setMetadataInstanceEntityManager(MetadataInstanceEntityManager metadataInstanceEntityManager)
public DatabaseContentObjectEntityManager getDatabaseContentObjectEntityManager()
public ContentEngineConfiguration setDatabaseContentObjectEntityManager(DatabaseContentObjectEntityManager databaseContentObjectEntityManager)
public ContentEngineConfiguration setTableDataManager(TableDataManager tableDataManager)
setTableDataManager
in class AbstractEngineConfiguration
public ContentStorage getContentStorage()
public ContentEngineConfiguration setContentStorage(ContentStorage contentStorage)
public String getContentRootFolder()
public ContentEngineConfiguration setContentRootFolder(String contentRootFolder)
public boolean isCreateContentRootFolder()
public ContentEngineConfiguration setCreateContentRootFolder(boolean createContentRootFolder)
public CoreContentItemContentObjectStorageMetadataProvider getContentItemContentObjectStorageMetadataProvider()
public void setContentItemContentObjectStorageMetadataProvider(CoreContentItemContentObjectStorageMetadataProvider contentItemContentObjectStorageMetadataProvider)
public RenditionItemContentObjectStorageMetadataProvider getRenditionItemContentObjectStorageMetadataProvider()
public void setRenditionItemContentObjectStorageMetadataProvider(RenditionItemContentObjectStorageMetadataProvider renditionItemContentObjectStorageMetadataProvider)
public ContentRenditionManager getContentRenditionManager()
public void setContentRenditionManager(ContentRenditionManager contentRenditionManager)
public ContentCryptoHandler getContentCryptoHandler()
public void setContentCryptoHandler(ContentCryptoHandler contentCryptoHandler)
public List<RenditionConverter> getRenditionConverters()
public void setRenditionConverters(List<RenditionConverter> renditionConverters)
public ContentEngineConfiguration setSqlSessionFactory(org.apache.ibatis.session.SqlSessionFactory sqlSessionFactory)
setSqlSessionFactory
in class AbstractEngineConfiguration
public ContentEngineConfiguration setTransactionFactory(org.apache.ibatis.transaction.TransactionFactory transactionFactory)
setTransactionFactory
in class AbstractEngineConfiguration
public ContentEngineConfiguration setCustomMybatisMappers(Set<Class<?>> customMybatisMappers)
setCustomMybatisMappers
in class AbstractEngineConfiguration
public ContentEngineConfiguration setCustomMybatisXMLMappers(Set<String> customMybatisXMLMappers)
setCustomMybatisXMLMappers
in class AbstractEngineConfiguration
public ContentEngineConfiguration setCustomSessionFactories(List<SessionFactory> customSessionFactories)
setCustomSessionFactories
in class AbstractEngineConfiguration
public ContentEngineConfiguration setUsingRelationalDatabase(boolean usingRelationalDatabase)
setUsingRelationalDatabase
in class AbstractEngineConfiguration
public ContentEngineConfiguration setDatabaseTablePrefix(String databaseTablePrefix)
setDatabaseTablePrefix
in class AbstractEngineConfiguration
public ContentEngineConfiguration setDatabaseCatalog(String databaseCatalog)
setDatabaseCatalog
in class AbstractEngineConfiguration
public ContentEngineConfiguration setDatabaseSchema(String databaseSchema)
setDatabaseSchema
in class AbstractEngineConfiguration
public ContentEngineConfiguration setTablePrefixIsSchema(boolean tablePrefixIsSchema)
setTablePrefixIsSchema
in class AbstractEngineConfiguration
public ContentEngineConfiguration setSessionFactories(Map<Class<?>,SessionFactory> sessionFactories)
setSessionFactories
in class AbstractEngineConfiguration
public ContentEngineConfiguration setDatabaseSchemaUpdate(String databaseSchemaUpdate)
setDatabaseSchemaUpdate
in class AbstractEngineConfiguration
public SchemaManager getJobSchemaManager()
public ContentEngineConfiguration setJobSchemaManager(SchemaManager jobSchemaManager)
public boolean isExecuteServiceSchemaManagers()
public ContentEngineConfiguration setExecuteServiceSchemaManagers(boolean executeServiceSchemaManagers)
public DocumentDefinitionDeployer getDocumentDefinitionDeployer()
public ContentEngineConfiguration setDocumentDefinitionDeployer(DocumentDefinitionDeployer documentDefinitionDeployer)
public DocumentDeploymentManager getDeploymentManager()
public ContentEngineConfiguration setDeploymentManager(DocumentDeploymentManager deploymentManager)
public DocumentResourceConverter getDocumentResourceConverter()
getDocumentResourceConverter
in interface CoreContentEngineConfigurationApi
public ContentEngineConfiguration setDocumentResourceConverter(DocumentResourceConverter documentResourceConverter)
public int getDocumentDefinitionCacheLimit()
public ContentEngineConfiguration setDocumentDefinitionCacheLimit(int documentDefinitionCacheLimit)
public DeploymentCache<DocumentDefinitionCacheEntry> getDocumentDefinitionCache()
public ContentEngineConfiguration setDocumentDefinitionCache(DeploymentCache<DocumentDefinitionCacheEntry> documentDefinitionCache)
public JobServiceConfiguration getJobServiceConfiguration()
public ContentEngineConfiguration setJobServiceConfiguration(JobServiceConfiguration jobServiceConfiguration)
public AsyncExecutor getAsyncExecutor()
public ContentEngineConfiguration setAsyncExecutor(AsyncExecutor asyncExecutor)
public JobManager getJobManager()
public ContentEngineConfiguration setJobManager(JobManager jobManager)
public List<JobHandler> getCustomJobHandlers()
public ContentEngineConfiguration setCustomJobHandlers(List<JobHandler> customJobHandlers)
public Map<String,JobHandler> getJobHandlers()
public ContentEngineConfiguration setJobHandlers(Map<String,JobHandler> jobHandlers)
public InternalJobManager getInternalJobManager()
public ContentEngineConfiguration setInternalJobManager(InternalJobManager internalJobManager)
public List<AsyncRunnableExecutionExceptionHandler> getCustomAsyncRunnableExecutionExceptionHandlers()
public ContentEngineConfiguration setCustomAsyncRunnableExecutionExceptionHandlers(List<AsyncRunnableExecutionExceptionHandler> customAsyncRunnableExecutionExceptionHandlers)
public FailedJobCommandFactory getFailedJobCommandFactory()
public ContentEngineConfiguration setFailedJobCommandFactory(FailedJobCommandFactory failedJobCommandFactory)
public InternalJobParentStateResolver getInternalJobParentStateResolver()
public ContentEngineConfiguration setInternalJobParentStateResolver(InternalJobParentStateResolver internalJobParentStateResolver)
public String getJobExecutionScope()
public ContentEngineConfiguration setJobExecutionScope(String jobExecutionScope)
public boolean isAsyncExecutorActivate()
public ContentEngineConfiguration setAsyncExecutorActivate(boolean asyncExecutorActivate)
public boolean isAsyncExecutorMessageQueueMode()
public ContentEngineConfiguration setAsyncExecutorMessageQueueMode(boolean asyncExecutorMessageQueueMode)
public int getAsyncExecutorNumberOfRetries()
public ContentEngineConfiguration setAsyncExecutorNumberOfRetries(int asyncExecutorNumberOfRetries)
public int getLockTimeAsyncJobWaitTime()
public ContentEngineConfiguration setLockTimeAsyncJobWaitTime(int lockTimeAsyncJobWaitTime)
public int getDefaultFailedJobWaitTime()
public ContentEngineConfiguration setDefaultFailedJobWaitTime(int defaultFailedJobWaitTime)
public int getAsyncFailedJobWaitTime()
public ContentEngineConfiguration setAsyncFailedJobWaitTime(int asyncFailedJobWaitTime)
public int getAsyncExecutorCorePoolSize()
public ContentEngineConfiguration setAsyncExecutorCorePoolSize(int asyncExecutorCorePoolSize)
public int getAsyncExecutorMaxPoolSize()
public ContentEngineConfiguration setAsyncExecutorMaxPoolSize(int asyncExecutorMaxPoolSize)
public long getAsyncExecutorThreadKeepAliveTime()
public ContentEngineConfiguration setAsyncExecutorThreadKeepAliveTime(long asyncExecutorThreadKeepAliveTime)
public int getAsyncExecutorThreadPoolQueueSize()
public ContentEngineConfiguration setAsyncExecutorThreadPoolQueueSize(int asyncExecutorThreadPoolQueueSize)
public boolean isShutdownAsyncTaskExecutor()
public ContentEngineConfiguration setShutdownAsyncTaskExecutor(boolean shutdownAsyncTaskExecutor)
public int getAsyncExecutorDefaultTimerJobAcquireWaitTime()
public ContentEngineConfiguration setAsyncExecutorDefaultTimerJobAcquireWaitTime(int asyncExecutorDefaultTimerJobAcquireWaitTime)
public String getAsyncExecutorTenantId()
public ContentEngineConfiguration setAsyncExecutorTenantId(String asyncExecutorTenantId)
public BlockingQueue<Runnable> getAsyncExecutorThreadPoolQueue()
public ContentEngineConfiguration setAsyncExecutorThreadPoolQueue(BlockingQueue<Runnable> asyncExecutorThreadPoolQueue)
public long getAsyncExecutorSecondsToWaitOnShutdown()
public ContentEngineConfiguration setAsyncExecutorSecondsToWaitOnShutdown(long asyncExecutorSecondsToWaitOnShutdown)
public AsyncTaskExecutor getAsyncTaskExecutor()
public ContentEngineConfiguration setAsyncTaskExecutor(AsyncTaskExecutor asyncTaskExecutor)
public boolean isAsyncExecutorAllowCoreThreadTimeout()
public ContentEngineConfiguration setAsyncExecutorAllowCoreThreadTimeout(boolean asyncExecutorAllowCoreThreadTimeout)
public ThreadFactory getAsyncExecutorThreadFactory()
public ContentEngineConfiguration setAsyncExecutorThreadFactory(ThreadFactory asyncExecutorThreadFactory)
public int getAsyncExecutorMaxAsyncJobsDuePerAcquisition()
public ContentEngineConfiguration setAsyncExecutorMaxAsyncJobsDuePerAcquisition(int asyncExecutorMaxAsyncJobsDuePerAcquisition)
public int getAsyncExecutorDefaultAsyncJobAcquireWaitTime()
public ContentEngineConfiguration setAsyncExecutorDefaultAsyncJobAcquireWaitTime(int asyncExecutorDefaultAsyncJobAcquireWaitTime)
public int getAsyncExecutorDefaultQueueSizeFullWaitTime()
public ContentEngineConfiguration setAsyncExecutorDefaultQueueSizeFullWaitTime(int asyncExecutorDefaultQueueSizeFullWaitTime)
public String getAsyncExecutorLockOwner()
public ContentEngineConfiguration setAsyncExecutorLockOwner(String asyncExecutorLockOwner)
public int getAsyncExecutorAsyncJobLockTimeInMillis()
public ContentEngineConfiguration setAsyncExecutorAsyncJobLockTimeInMillis(int asyncExecutorAsyncJobLockTimeInMillis)
public int getAsyncExecutorResetExpiredJobsInterval()
public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsInterval(int asyncExecutorResetExpiredJobsInterval)
public int getAsyncExecutorResetExpiredJobsMaxTimeout()
public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsMaxTimeout(int asyncExecutorResetExpiredJobsMaxTimeout)
public int getAsyncExecutorResetExpiredJobsPageSize()
public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsPageSize(int asyncExecutorResetExpiredJobsPageSize)
public ExecuteAsyncRunnableFactory getAsyncExecutorExecuteAsyncRunnableFactory()
public ContentEngineConfiguration setAsyncExecutorExecuteAsyncRunnableFactory(ExecuteAsyncRunnableFactory asyncExecutorExecuteAsyncRunnableFactory)
public boolean isAsyncExecutorAsyncJobAcquisitionEnabled()
public ContentEngineConfiguration setAsyncExecutorAsyncJobAcquisitionEnabled(boolean isAsyncExecutorAsyncJobAcquisitionEnabled)
public boolean isAsyncExecutorResetExpiredJobsEnabled()
public ContentEngineConfiguration setAsyncExecutorResetExpiredJobsEnabled(boolean isAsyncExecutorResetExpiredJobsEnabled)
public AsyncExecutor getAsyncHistoryExecutor()
public ContentEngineConfiguration setAsyncHistoryExecutor(AsyncExecutor asyncHistoryExecutor)
public boolean isAsyncHistoryEnabled()
public ContentEngineConfiguration setAsyncHistoryEnabled(boolean isAsyncHistoryEnabled)
public AsyncHistoryListener getAsyncHistoryListener()
public ContentEngineConfiguration setAsyncHistoryListener(AsyncHistoryListener asyncHistoryListener)
public ContentAsyncHistoryManager getContentAsyncHistoryManager()
public ContentEngineConfiguration setContentAsyncHistoryManager(ContentAsyncHistoryManager contentAsyncHistoryManager)
public VariableTypes getVariableTypes()
public ContentEngineConfiguration setVariableTypes(VariableTypes variableTypes)
public List<VariableType> getCustomPreVariableTypes()
public ContentEngineConfiguration setCustomPreVariableTypes(List<VariableType> customPreVariableTypes)
public List<VariableType> getCustomPostVariableTypes()
public ContentEngineConfiguration setCustomPostVariableTypes(List<VariableType> customPostVariableTypes)
public boolean isJsonVariableTypeTrackObjects()
public ContentEngineConfiguration setJsonVariableTypeTrackObjects(boolean jsonVariableTypeTrackObjects)
public ContentEngineConfiguration setObjectMapper(com.fasterxml.jackson.databind.ObjectMapper objectMapper)
setObjectMapper
in class AbstractEngineConfiguration