Skip navigation links
A B C D E F G H I J K L M N O P R S T U W 

A

accept(IHealthEventHandler) - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcCsvHealthEvent
 
accept(ICsvSourceHealthEventHandler) - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcCsvHealthEvent
 
accept(IHealthEventHandler) - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcJdbcHealthEvent
 
accept(IJdbcSourceHealthEventHandler) - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcJdbcHealthEvent
 
accept(IHealthEventHandler) - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcMessagingHealthEvent
 
accept(IMessagingSourceHealthEventHandler) - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcMessagingHealthEvent
 
accept(ICsvSourceHealthEventHandler) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
accept(IHealthEventHandler) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcExceptionHealthEvent
 
accept(IJdbcSourceHealthEventHandler) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcFailureHealthEvent
 
accept(IJdbcSourceHealthEventHandler) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcTaskDoneHealthEvent
 
accept(IMessagingSourceHealthEventHandler) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingFailureHealthEvent
 
accept(IMessagingSourceHealthEventHandler) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingSummaryHealthEvent
 
accept(IMessagingSourceHealthEventHandler) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingTaskDoneHealthEvent
 
accept(IHealthEventHandler) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcNoStatusHealthEvent
 
accept(IHealthEventHandler) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcSummaryHealthEvent
 
accept(IHealthEventHandler) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcUnloadHealthEvent
 
ADatastoreTransactionTask - Class in com.activeviam.tools.dataloadcontroller.core.source
An abstract implementation of a task that executes a Datastore transaction with an unspecified 'content'.
ADatastoreTransactionTask(IDatastore, ConcurrentMap<String, DataLoadController.TopicControllerDelegates>, List<String>, Map<String, Object>) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.ADatastoreTransactionTask
Construct a Datastore transaction task.
addEventToCache(IHealthEvent, String, String) - Static method in class com.activeviam.tools.dataloadcontroller.cache.CacheUtils
 
addTopic(IJdbcScopedFetchTopic) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcScopedFetchSource
Add a new topic to be supported by this source.
addTopic(IJdbcScopedFetchTopic) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
 
addTopic(IMessagingTopic) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingSource
 
ADlcHealthEvent - Class in com.activeviam.tools.dataloadcontroller.event.impl
 
ADlcHealthEvent() - Constructor for class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
AExecutionTask - Class in com.activeviam.tools.dataloadcontroller.core.source
 
AExecutionTask(IDatastore, ConcurrentMap<String, DataLoadController.TopicControllerDelegates>, List<String>, Map<String, Object>) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.AExecutionTask
Construct an execution task.
AJdbcPreparedStatementTask<E> - Class in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Base implementation of a IJdbcStatementTask that executes a prepared statement.
AJdbcPreparedStatementTask(IJdbcScopedFetchTopic, Object[], DataSource, IMessageChannel<String, E>) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
Create a task for executing a prepared statement.
AJdbcPreparedStatementTask.Result - Class in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Default implementation of IJdbcStatementTask.IResult.
apply(String, Map<String, Object>) - Method in interface com.activeviam.tools.dataloadcontroller.controller.IDataLoadController.IScopeToRemoveWhereConditionConverter
Generate a remove-where condition corresponding to a particular topic and scope.
apply(Map<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic.FetchScopeToFileScanParametersConverter
Convert a fetch scope into file scan parameters for IFilesScopedFetchTopic.fetchFiles.
apply(Map<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic.FetchScopeToFileScanParametersConverter
Convert a fetch scope into file scan parameters for IFilesScopedFetchTopic.fetchFiles(Map).s
apply(Map<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic.ScopeToSqlParametersConverter
Convert the given business scope (for a particular statement task execution) into the relevant SQL input parameters (for the JDBC statement topic this tasks relate to).
assignPartition(int, long) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 

B

buildColumnCalculators(AStoreMessageChannelFactory.TopicStore, Map<String, IColumnCalculator<Object[]>>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.TupleMessageChannelFactory
 
bulkLoadCsvMessageChannelFactory() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.csv.ICsvScopedFetchSourceConfig
Factory to create new Channels.
bulkLoadCsvSource(String) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.csv.ICsvScopedFetchSourceConfig
Creates and adds CSV topics to a source.

C

CacheUtils - Class in com.activeviam.tools.dataloadcontroller.cache
 
CacheUtils() - Constructor for class com.activeviam.tools.dataloadcontroller.cache.CacheUtils
 
call() - Method in class com.activeviam.tools.dataloadcontroller.core.source.ADatastoreTransactionTask
 
call() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
 
call() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 
call() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.rabbitmq.RabbitMqMessageConsumer
 
call() - Method in class com.activeviam.tools.dataloadcontroller.core.source.StartListeningControllerTask
 
call() - Method in class com.activeviam.tools.dataloadcontroller.core.source.StopListeningControllerTask
 
cause - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
channel - Variable in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController.TopicControllerDelegates
 
checkStatus(String) - Method in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
 
checkStatus(String) - Method in interface com.activeviam.tools.dataloadcontroller.controller.IDataLoadController
Check the status of a particular data operation previously triggered via this controller.
clazz - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
The class in which the event was created.
client() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.azure.IAzureCsvConnector
Creates a client for accessing the Azure storage account.
client() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.google.IGoogleCsvConnector
 
client() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.s3.IS3CsvConnector
 
close() - Method in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
Shutdown the controller.
close() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.csv.ICsvFilesScopedFetchTopic
 
close() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
Shutdown the source.
close() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer.KafkaJsonDeserializer
 
close() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 
com.activeviam.tools.dataloadcontroller.cache - package com.activeviam.tools.dataloadcontroller.cache
 
com.activeviam.tools.dataloadcontroller.controller - package com.activeviam.tools.dataloadcontroller.controller
 
com.activeviam.tools.dataloadcontroller.core.source - package com.activeviam.tools.dataloadcontroller.core.source
 
com.activeviam.tools.dataloadcontroller.core.source.cloud - package com.activeviam.tools.dataloadcontroller.core.source.cloud
 
com.activeviam.tools.dataloadcontroller.core.source.cloud.azure - package com.activeviam.tools.dataloadcontroller.core.source.cloud.azure
 
com.activeviam.tools.dataloadcontroller.core.source.cloud.google - package com.activeviam.tools.dataloadcontroller.core.source.cloud.google
 
com.activeviam.tools.dataloadcontroller.core.source.cloud.s3 - package com.activeviam.tools.dataloadcontroller.core.source.cloud.s3
 
com.activeviam.tools.dataloadcontroller.core.source.csv - package com.activeviam.tools.dataloadcontroller.core.source.csv
 
com.activeviam.tools.dataloadcontroller.core.source.jdbc - package com.activeviam.tools.dataloadcontroller.core.source.jdbc
 
com.activeviam.tools.dataloadcontroller.core.source.messaging - package com.activeviam.tools.dataloadcontroller.core.source.messaging
 
com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka - package com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka
 
com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer - package com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer
 
com.activeviam.tools.dataloadcontroller.core.source.messaging.rabbitmq - package com.activeviam.tools.dataloadcontroller.core.source.messaging.rabbitmq
 
com.activeviam.tools.dataloadcontroller.core.source.rest - package com.activeviam.tools.dataloadcontroller.core.source.rest
 
com.activeviam.tools.dataloadcontroller.event - package com.activeviam.tools.dataloadcontroller.event
 
com.activeviam.tools.dataloadcontroller.event.constants - package com.activeviam.tools.dataloadcontroller.event.constants
 
com.activeviam.tools.dataloadcontroller.event.formatter - package com.activeviam.tools.dataloadcontroller.event.formatter
 
com.activeviam.tools.dataloadcontroller.event.handler - package com.activeviam.tools.dataloadcontroller.event.handler
 
com.activeviam.tools.dataloadcontroller.event.handler.impl - package com.activeviam.tools.dataloadcontroller.event.handler.impl
 
com.activeviam.tools.dataloadcontroller.event.impl - package com.activeviam.tools.dataloadcontroller.event.impl
 
com.activeviam.tools.dataloadcontroller.exception - package com.activeviam.tools.dataloadcontroller.exception
 
compute(IColumnCalculator.IColumnCalculationContext<Object[]>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.ReadTupleFieldColumnCalculator
 
configure(Map, boolean) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer.KafkaJsonDeserializer
 
controllerDelegatesByTopic - Variable in class com.activeviam.tools.dataloadcontroller.core.source.AExecutionTask
 
createDlcCsvHealthEvent(IHealthEvent, String) - Static method in class com.activeviam.tools.dataloadcontroller.cache.CacheUtils
 
createTranslator(List<IColumnCalculator<Object[]>>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.TupleMessageChannelFactory
 
CsvCloudScopedFetchTopic<E> - Class in com.activeviam.tools.dataloadcontroller.core.source.csv
Default implementation of a ICsvFilesScopedFetchTopic.
CsvCloudScopedFetchTopic(String, ICloudDirectory<E>, ICloudCsvDataProviderFactory<E>, String, ICloudsScopedFetchTopic.IFetchScopeToFileScanParametersConverter, ICSVParserConfiguration, String, Properties) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
Construct a CSV files fetch topic.
CsvCloudScopedFetchTopic.FetchScopeToFileScanParametersConverter - Class in com.activeviam.tools.dataloadcontroller.core.source.csv
Default implementation of IFetchScopeToFileScanParametersConverter.
CsvCloudScopedFetchTopic.FileScanParameters - Class in com.activeviam.tools.dataloadcontroller.core.source.csv
 
CsvFilesScopedFetchTopic - Class in com.activeviam.tools.dataloadcontroller.core.source.csv
Default implementation of a ICsvFilesScopedFetchTopic.
CsvFilesScopedFetchTopic(String, String, PathMatcher, IFilesScopedFetchTopic.IFetchScopeToFileScanParametersConverter, ICSVParserConfiguration) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvFilesScopedFetchTopic
Construct a CSV files fetch topic.
CsvScopedFetchSource<F> - Class in com.activeviam.tools.dataloadcontroller.core.source.csv
A CSV source that implements IFetchingDataSource contract.
CsvScopedFetchSource(Properties) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvScopedFetchSource
Construct a CSV source based on the specified properties.
CustomKafkaAvroDeserializerGenericRecord - Class in com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer
Customize the deserialize method to reuse GenericDatumReader.
CustomKafkaAvroDeserializerGenericRecord() - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer.CustomKafkaAvroDeserializerGenericRecord
 
CustomKafkaAvroDeserializerObjectTuple - Class in com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer
Customize the deserialize method to reuse GenericDatumReader and GenericObject.
CustomKafkaAvroDeserializerObjectTuple() - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer.CustomKafkaAvroDeserializerObjectTuple
 

D

DataLoadController - Class in com.activeviam.tools.dataloadcontroller.controller
Default implementation of a IDataLoadController.
DataLoadController(IDatastore, Properties) - Constructor for class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
Construct a data load controller.
DataLoadController.TopicControllerDelegates - Class in com.activeviam.tools.dataloadcontroller.controller
 
DataLoadControllerRequest - Class in com.activeviam.tools.dataloadcontroller.core.source.rest
A request sent to IDataLoadControllerRestService for executing some data operation.
DataLoadControllerRequest() - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRequest
 
DataLoadControllerRequest(String, List<String>, Map<String, Object>) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRequest
 
DataLoadControllerResponse - Class in com.activeviam.tools.dataloadcontroller.core.source.rest
 
DataLoadControllerResponse() - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
DataLoadControllerResponse(String, long, List<IHealthEvent>) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
DataLoadControllerResponse(String, long, List<IHealthEvent>, String) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
DataLoadControllerRestService - Class in com.activeviam.tools.dataloadcontroller.core.source.rest
Base implementation of IDataLoadControllerRestService.
DataLoadControllerRestService(IDataLoadController) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRestService
Construct a data load controller Rest service.
dataProviderFactory() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.azure.IAzureCsvConnector
Default implementation of a CSV Azure Blob data provider factory.
dataProviderFactory() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.google.IGoogleCsvConnector
Create a Factory to retrieve Blob data from Google storage.
dataProviderFactory() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.ICloudCsvConnector
Create a Factory to retrieve CSV files from Blob cloud storage.
dataProviderFactory() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.s3.IS3CsvConnector
 
datastore - Variable in class com.activeviam.tools.dataloadcontroller.core.source.AExecutionTask
 
DEFAULT_BRANCH - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRestService
 
DEFAULT_CONTROLLER_NAME - Static variable in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
DEFAULT_JDBC_FETCH_SIZE - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
DEFAULT_MAX_TX_DRAIN_SIZE - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 
DEFAULT_MAX_TX_DRAIN_TIME_MS - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 
DEFAULT_NAME - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvScopedFetchSource
DEFAULT_NAME - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
DEFAULT_NAME - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingSource
 
DEFAULT_POLL_TIMEOUT - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 
DEFAULT_PUBLISH_CHUNK_SIZE - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 
DEFAULT_PUBLISH_QUEUE_CAPACITY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 
DEFAULT_PUBLISH_TASK_MAX_CONCURRENCY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
DEFAULT_PUBLISH_TASK_MAX_CONCURRENCY_PER_FETCH_TASK - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
DEFAULT_STATEMENT_TAX_MAX_CONCURRENCY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
deserialize(boolean, String, Boolean, byte[], Schema) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer.CustomKafkaAvroDeserializerGenericRecord
 
deserialize(boolean, String, Boolean, byte[], Schema) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer.CustomKafkaAvroDeserializerObjectTuple
 
deserialize(String, byte[]) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer.KafkaJsonDeserializer
 
deserialize(byte[]) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.rabbitmq.RabbitMqMessageConsumer
 
DLC_CACHE - Static variable in class com.activeviam.tools.dataloadcontroller.cache.DlcCacheManager
 
DlcCacheManager - Class in com.activeviam.tools.dataloadcontroller.cache
 
DlcCsvHealthEvent - Class in com.activeviam.tools.dataloadcontroller.event.impl
 
DlcCsvHealthEvent() - Constructor for class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
DlcCsvHealthEventHandler - Class in com.activeviam.tools.dataloadcontroller.event.handler.impl
Default event handler used by the DLC to handle CSV source events.
DlcCsvHealthEventHandler(String) - Constructor for class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcCsvHealthEventHandler
 
dlcEventType - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
DlcEventTypeConstants - Class in com.activeviam.tools.dataloadcontroller.event.constants
Class for various DlcEventType related constants
DlcEventTypeConstants() - Constructor for class com.activeviam.tools.dataloadcontroller.event.constants.DlcEventTypeConstants
 
DlcException - Exception in com.activeviam.tools.dataloadcontroller.exception
 
DlcException() - Constructor for exception com.activeviam.tools.dataloadcontroller.exception.DlcException
Constructs a new exception with null as its detail message.
DlcException(String) - Constructor for exception com.activeviam.tools.dataloadcontroller.exception.DlcException
Constructs a new exception with the specified detail message.
DlcException(String, Throwable) - Constructor for exception com.activeviam.tools.dataloadcontroller.exception.DlcException
Constructs a new exception with the specified detail message and cause.
DlcException(Throwable) - Constructor for exception com.activeviam.tools.dataloadcontroller.exception.DlcException
Constructs a new exception with the specified cause and a detail message of (cause==null ? null : cause.toString()) (which typically contains the class and detail message of cause).
DlcException(String, Throwable, boolean, boolean) - Constructor for exception com.activeviam.tools.dataloadcontroller.exception.DlcException
Constructs a new exception with the specified detail message, cause, suppression enabled or disabled, and writable stack trace enabled or disabled.
DlcExceptionHealthEvent - Class in com.activeviam.tools.dataloadcontroller.event.impl
A generic exception event
DlcExceptionHealthEvent(Throwable) - Constructor for class com.activeviam.tools.dataloadcontroller.event.impl.DlcExceptionHealthEvent
 
DlcFormatter - Interface in com.activeviam.tools.dataloadcontroller.event.formatter
 
DlcJdbcFailureHealthEvent - Class in com.activeviam.tools.dataloadcontroller.event.impl
A generic failure event to handle JDBC related exceptions and/or failures.
DlcJdbcFailureHealthEvent(Throwable) - Constructor for class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcFailureHealthEvent
 
DlcJdbcHealthEventHandler - Class in com.activeviam.tools.dataloadcontroller.event.handler.impl
 
DlcJdbcHealthEventHandler(String) - Constructor for class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcJdbcHealthEventHandler
 
DlcJdbcTaskDoneHealthEvent - Class in com.activeviam.tools.dataloadcontroller.event.impl
 
DlcJdbcTaskDoneHealthEvent(IJdbcStatementTask.IResult) - Constructor for class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcTaskDoneHealthEvent
 
DlcMessagingFailureHealthEvent - Class in com.activeviam.tools.dataloadcontroller.event.impl
A generic failure event to handle exceptions and/or failures encountered when listening to a MessagingTopic.
DlcMessagingFailureHealthEvent(Throwable, String) - Constructor for class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingFailureHealthEvent
Construct the health event.
DlcMessagingHealthEventHandler - Class in com.activeviam.tools.dataloadcontroller.event.handler.impl
A event handler for the events generated by a MessagingSource.
DlcMessagingHealthEventHandler(String) - Constructor for class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcMessagingHealthEventHandler
 
DlcMessagingHealthEventHandler(String, String) - Constructor for class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcMessagingHealthEventHandler
Construct the event handler.
DlcMessagingSummaryHealthEvent - Class in com.activeviam.tools.dataloadcontroller.event.impl
A summary health event
DlcMessagingSummaryHealthEvent(String, String) - Constructor for class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingSummaryHealthEvent
 
DlcMessagingTaskDoneHealthEvent - Class in com.activeviam.tools.dataloadcontroller.event.impl
A generic messaging health event that can be fired to indicate when a task is completed when listening to a MessagingTopic.
DlcMessagingTaskDoneHealthEvent(String, String) - Constructor for class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingTaskDoneHealthEvent
Construct the health event.
DlcNoStatusHealthEvent - Class in com.activeviam.tools.dataloadcontroller.event.impl
No status health event
DlcNoStatusHealthEvent(String) - Constructor for class com.activeviam.tools.dataloadcontroller.event.impl.DlcNoStatusHealthEvent
 
DlcSummaryHealthEvent - Class in com.activeviam.tools.dataloadcontroller.event.impl
A summary health event
DlcSummaryHealthEvent(String) - Constructor for class com.activeviam.tools.dataloadcontroller.event.impl.DlcSummaryHealthEvent
 
DlcSummaryHealthEventHandler - Class in com.activeviam.tools.dataloadcontroller.event.handler.impl
 
DlcSummaryHealthEventHandler(String) - Constructor for class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcSummaryHealthEventHandler
 
DlcUnloadHealthEvent - Class in com.activeviam.tools.dataloadcontroller.event.impl
An unload health event
DlcUnloadHealthEvent(String) - Constructor for class com.activeviam.tools.dataloadcontroller.event.impl.DlcUnloadHealthEvent
 
doPostCommit() - Method in class com.activeviam.tools.dataloadcontroller.core.source.ADatastoreTransactionTask
Delegate to execute some post-TX-commit operations.
doPostCommit() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.TxSizeController
 
doPostTransactionContent(String, List<IDataLoadSourceHealthEventHandler>) - Static method in class com.activeviam.tools.dataloadcontroller.core.source.TransactionTaskUtil
 
doTransactionContent(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.ADatastoreTransactionTask
Define the content of the transaction.
doTransactionContent(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.LoadDataTxControllerTask
 
doTransactionContent(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.UnloadDataTxControllerTask
 
doTransactionStart(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.ADatastoreTransactionTask
Delegate to execute Datastore transaction start.
doTransactionStart(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.LoadDataTxControllerTask
We override parent implementation so that we start transaction only on stores directly impacted given the list of topics that we are processing.
doTransactionStart(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.UnloadDataTxControllerTask
We override parent implementation so that we start transaction only on stores directly impacted given the list of topics that we are processing.
DOWNLOAD_THREADS - Static variable in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.google.IGoogleCsvConnector
Sets download threads to 1.5x number of logical cores (Rounded Down).
DOWNLOAD_THREADS - Static variable in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.ICloudCsvConnector
Recommended number of downloader threads is 1.5x number of logical cores on server.

E

equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic
 
equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcFailureHealthEvent
 
equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcTaskDoneHealthEvent
 
equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingFailureHealthEvent
 
equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingSummaryHealthEvent
 
equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingTaskDoneHealthEvent
 
equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcNoStatusHealthEvent
 
equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcSummaryHealthEvent
 
equals(Object) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcUnloadHealthEvent
 
EVENT_HANDLER_CACHE - Static variable in class com.activeviam.tools.dataloadcontroller.cache.DlcCacheManager
 
EXCEPTION - Static variable in class com.activeviam.tools.dataloadcontroller.event.constants.DlcEventTypeConstants
 
execute(IDataLoadController.IExecutionRequest) - Method in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
 
execute(IDataLoadController.IExecutionRequest) - Method in interface com.activeviam.tools.dataloadcontroller.controller.IDataLoadController
Synchronously execute a data operation as per specified request.
execute(DataLoadControllerRequest) - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRestService
 
execute(DataLoadControllerRequest) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.rest.IDataLoadControllerRestService
Execute a data operation as per specified request.
executeAsynch(IDataLoadController.IExecutionRequest) - Method in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
 
executeAsynch(IDataLoadController.IExecutionRequest) - Method in interface com.activeviam.tools.dataloadcontroller.controller.IDataLoadController
Asynchronously execute a data operation as per specified request.
extraProperties - Variable in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
extraProperties - Variable in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 

F

FAILED - Static variable in class com.activeviam.tools.dataloadcontroller.event.constants.DlcEventTypeConstants
 
fetch(List<? extends IMessageChannel<?, ?>>, Map<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvScopedFetchSource
 
fetch(Collection<? extends IMessageChannel<I, E>>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IDataSource
 
fetch(List<? extends IMessageChannel<?, ?>>, Map<String, Object>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFetchingDataSource
Synchronously fetch data for the specified channels and scope.
fetch(List<? extends IMessageChannel<?, ?>>, Map<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
 
fetchAsynch(List<? extends IMessageChannel<?, ?>>, Map<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvScopedFetchSource
 
fetchAsynch(List<? extends IMessageChannel<?, ?>>, Map<String, Object>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFetchingDataSource
Asynchronously fetch data for the specified channels and scope.
fetchAsynch(List<? extends IMessageChannel<?, ?>>, Map<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
 
fetchFiles(Map<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
fetchFiles(Map<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
fetchFiles(Map<String, Object>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.ICloudsScopedFetchTopic
Identify the files to process for a particular fetch iteration.
fetchFiles(Map<String, Object>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFilesScopedFetchTopic
Identify the files to process for a particular fetch iteration.
fetchScopeToFileScanParametersConverter - Variable in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
FetchScopeToFileScanParametersConverter(String...) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic.FetchScopeToFileScanParametersConverter
Create a converter of a fetch scope into file scan parameters for IFilesScopedFetchTopic#fetchFiles(Map).
fetchScopeToFileScanParametersConverter - Variable in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
FetchScopeToFileScanParametersConverter(String...) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic.FetchScopeToFileScanParametersConverter
Create a converter of a fetch scope into file scan parameters for IFilesScopedFetchTopic.fetchFiles(Map).
file - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
The name of the file being parsed.
fileLineNumber - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
The line number of the line we failed to parse.
FileScanParameters(String, boolean) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic.FileScanParameters
 
FileScanParameters(String, boolean) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic.FileScanParameters
 
FilesScopedFetchTopic - Class in com.activeviam.tools.dataloadcontroller.core.source
Default implementation of a IFilesScopedFetchTopic.
FilesScopedFetchTopic(String, String, PathMatcher, IFilesScopedFetchTopic.IFetchScopeToFileScanParametersConverter, String, Properties) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
Construct a files scoped fetch topic.
FilesScopedFetchTopic.FetchScopeToFileScanParametersConverter - Class in com.activeviam.tools.dataloadcontroller.core.source
Default implementation of IFetchScopeToFileScanParametersConverter.
FilesScopedFetchTopic.FileScanParameters - Class in com.activeviam.tools.dataloadcontroller.core.source
 
fileTaskPluginKey - Variable in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
fileTaskPluginKey - Variable in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
format(IParsingInfo) - Method in interface com.activeviam.tools.dataloadcontroller.event.formatter.DlcFormatter
 
format(IDlcHealthEvent) - Method in interface com.activeviam.tools.dataloadcontroller.event.formatter.DlcFormatter
 
format(IParsingInfo) - Method in class com.activeviam.tools.dataloadcontroller.event.formatter.JsonFormatter
 
format(IDlcHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.formatter.JsonFormatter
 
format(IParsingInfo) - Method in class com.activeviam.tools.dataloadcontroller.event.formatter.StringFormatter
 
format(IDlcHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.formatter.StringFormatter
 
formatColumnName(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.TupleMessageChannelFactory
 
formatValue(String, Object) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic.ScopeToSqlParametersConverter
Format the scope value denoted by key into the required SQL parameter.

G

getCause() - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcHealthEvent
 
getCause() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
getChannel() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFileTask
 
getChannel() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
 
getChannel() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcStatementTask
 
getClazz() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
getDbFetchedRecordCount() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask.Result
 
getDbFetchedRecordCount() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcStatementTask.IResult
 
getDbFetchElapsedNs() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask.Result
 
getDbFetchElapsedNs() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcStatementTask.IResult
 
getDefaultColumnCalculator(AStoreMessageChannelFactory.TopicStore, String, int) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.TupleMessageChannelFactory
 
getDlcCache() - Static method in class com.activeviam.tools.dataloadcontroller.cache.DlcCacheManager
 
getDlcLoadingStatus() - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
getEventHandlerCache() - Static method in class com.activeviam.tools.dataloadcontroller.cache.DlcCacheManager
 
getEvents() - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
getEventsForTask(String) - Static method in class com.activeviam.tools.dataloadcontroller.core.source.TransactionTaskUtil
Retrieve events for a taskName
getEventsForTask(String, String) - Static method in class com.activeviam.tools.dataloadcontroller.core.source.TransactionTaskUtil
Retrieve events for a taskName
getEventType() - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcHealthEvent
An event type strings defining what this event is about.
getEventType() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
getExceptionOnly() - Method in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
If exceptionOnlyResponse is set to true, the RESTful response only includes exception events.
getExtraProperties() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
getExtraProperties() - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
getExtraProperties() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.ICloudsScopedFetchTopic
 
getExtraProperties() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFilesScopedFetchTopic
 
getExtraProperties() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcScopedFetchTopic
 
getExtraProperties() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic
 
getFetchScopeToFileScanParametersConverter() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
getFetchScopeToFileScanParametersConverter() - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
getFetchScopeToFileScanParametersConverter() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.ICloudsScopedFetchTopic
 
getFetchScopeToFileScanParametersConverter() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFilesScopedFetchTopic
 
getFile() - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcCsvHealthEvent
 
getFile() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
getFileLineNumber() - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcCsvHealthEvent
 
getFileLineNumber() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
getFilePath() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFileTask
 
getFilePath() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFileTask.IResult
 
getFileReadElapsedNs() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFileTask.IResult
 
getFileTaskPluginKey() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
getFileTaskPluginKey() - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
getFileTaskPluginKey() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.ICloudsScopedFetchTopic
 
getFileTaskPluginKey() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFilesScopedFetchTopic
 
getFormatter() - Method in class com.activeviam.tools.dataloadcontroller.core.source.LoadDataTxControllerTask
 
getInstance() - Static method in class com.activeviam.tools.dataloadcontroller.cache.DlcCacheManager
 
getLevel() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
getLevel() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcExceptionHealthEvent
 
getLevel() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcFailureHealthEvent
How important the health event is.
getLevel() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcTaskDoneHealthEvent
How important the health event is.
getLevel() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingFailureHealthEvent
How important the health event is.
getLevel() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingSummaryHealthEvent
 
getLevel() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingTaskDoneHealthEvent
How important the health event is.
getLevel() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcNoStatusHealthEvent
 
getLevel() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcSummaryHealthEvent
 
getLevel() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcUnloadHealthEvent
 
getLine() - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcCsvHealthEvent
 
getLine() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
getLineNumber() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
getMessage() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.TxSizeController.LogMessageOutputStream
 
getMessage() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingSummaryHealthEvent
 
getMessage() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcNoStatusHealthEvent
 
getMessage() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcSummaryHealthEvent
 
getMessage() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcUnloadHealthEvent
 
getMethod() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
getName() - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
getName() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
 
getName() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic
 
getName() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingSource
 
getName() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 
getNumberOfTopicPartitions() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 
getOperation() - Method in interface com.activeviam.tools.dataloadcontroller.controller.IDataLoadController.IExecutionRequest
 
getOperation() - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRequest
 
getParseElapsedNs() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFileTask.IResult
 
getParserConfiguration() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
getParserConfiguration() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvFilesScopedFetchTopic
 
getParsingInfo() - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcCsvHealthEvent
 
getParsingInfo() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
getPathMatcher() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
getPathMatcher() - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
getPathMatcher() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.ICloudsScopedFetchTopic
 
getPathMatcher() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFilesScopedFetchTopic
 
getProviderFactory() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
getPublishedRecordCount() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFileTask.IResult
 
getPublishedRecordCount() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask.Result
 
getPublishedRecordCount() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcStatementTask.IResult
 
getPublishElapsedNs() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFileTask.IResult
 
getPublishElapsedNs() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask.Result
 
getPublishElapsedNs() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcStatementTask.IResult
 
getRecordCount() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFileTask.IResult
 
getRecursive() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic.FileScanParameters
 
getRecursive() - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic.FileScanParameters
 
getRecursive() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.ICloudsScopedFetchTopic.IFileScanParameters
 
getRecursive() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFilesScopedFetchTopic.IFileScanParameters
 
getRelDirPath() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic.FileScanParameters
 
getRelDirPath() - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic.FileScanParameters
 
getRelDirPath() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.ICloudsScopedFetchTopic.IFileScanParameters
 
getRelDirPath() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFilesScopedFetchTopic.IFileScanParameters
 
getResult() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcTaskDoneHealthEvent
 
getResult() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingTaskDoneHealthEvent
 
getResultFields() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcScopedFetchTopic
Optionally, give the names of the result fields for this topic, listed in the order that they are expected to be provided in the results generated by the JDBC source.
getResultFields() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic
 
getRootDirectoryPath() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
getRootDirectoryPath() - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
getRootDirectoryPath() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.ICloudsScopedFetchTopic
 
getRootDirectoryPath() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFilesScopedFetchTopic
 
getScope() - Method in interface com.activeviam.tools.dataloadcontroller.controller.IDataLoadController.IExecutionRequest
 
getScope() - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRequest
 
getScopeToSqlParametersConverter() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcScopedFetchTopic
 
getScopeToSqlParametersConverter() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic
 
getSourceColumnMapping(AStoreMessageChannelFactory.TopicStore) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.TupleMessageChannelFactory
 
getSourceFields() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.messaging.IMessagingTopic
Ordered list of fields in the record from the remote topic or queue
getSourceFields() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 
getSourceTupleFields(String) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.ITupleSource
Declare the fields of the tuples produced by this source for the given topic.
getSourceTupleFields(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
 
getSourceTupleFields(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingSource
 
getSql() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask.Result
 
getSql() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcScopedFetchTopic
 
getSql() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcStatementTask.IResult
 
getSql() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic
 
getSqlInputParameters() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
 
getSqlInputParameters() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask.Result
 
getSqlInputParameters() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcStatementTask
 
getSqlInputParameters() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcStatementTask.IResult
 
getStartTimeMs() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFileTask.IResult
 
getStartTimeMs() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask.Result
 
getStartTimeMs() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcStatementTask.IResult
 
getStatementTaskPluginKey() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcScopedFetchTopic
 
getStatementTaskPluginKey() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic
 
getStopTimeMs() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFileTask.IResult
 
getStopTimeMs() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask.Result
 
getStopTimeMs() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcStatementTask.IResult
 
getStoreToTaskNameMap() - Static method in class com.activeviam.tools.dataloadcontroller.cache.StoreToTaskNameMapper
 
getTags() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
getTags() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
getTags() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcExceptionHealthEvent
 
getTags() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcFailureHealthEvent
A set of strings defining what this event is about.
getTags() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcTaskDoneHealthEvent
A set of strings defining what this event is about.
getTags() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingFailureHealthEvent
A set of strings defining what this event is about.
getTags() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingSummaryHealthEvent
 
getTags() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingTaskDoneHealthEvent
A set of strings defining what this event is about.
getTags() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcNoStatusHealthEvent
 
getTags() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcSummaryHealthEvent
 
getTags() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcUnloadHealthEvent
 
getTaskName() - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
getTaskName() - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcJdbcHealthEventHandler
 
getTaskName() - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcMessagingHealthEventHandler
 
getTaskName() - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcSummaryHealthEventHandler
 
getTaskName() - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcHealthEvent
 
getTaskName() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
getThreadId() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
getThreadName() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
getTimeStamp() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
getTimeTakenMs() - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
getTopic() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
 
getTopic() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcStatementTask
 
getTopic() - Method in interface com.activeviam.tools.dataloadcontroller.event.handler.IMessagingSourceHealthEventHandler
In the case of a Messaging Source, consumers are active even after the "START_LISTEN" task completes.
getTopic() - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcMessagingHealthEventHandler
 
getTopic() - Method in interface com.activeviam.tools.dataloadcontroller.event.IDlcMessagingHealthEvent
Refer to Javadoc on IMessagingSourceHealthEventHandler.getTopic() to see why we need the Messaging Health Event to be aware of the topic
getTopic() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingFailureHealthEvent
 
getTopic() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingSummaryHealthEvent
 
getTopic() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingTaskDoneHealthEvent
 
getTopicEventHandlerDlcCache() - Static method in class com.activeviam.tools.dataloadcontroller.cache.DlcCacheManager
Cache to map a topic to an Event handler.
getTopics() - Method in interface com.activeviam.tools.dataloadcontroller.controller.IDataLoadController.IExecutionRequest
 
getTopics() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
 
getTopics() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingSource
 
getTopics() - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRequest
 
getType() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcPreparedStatementTask
 
getType() - Method in class com.activeviam.tools.dataloadcontroller.core.source.LoadDataTxControllerTask
 
getType() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 
getType() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.rabbitmq.RabbitMqMessageConsumer
 
getType() - Method in class com.activeviam.tools.dataloadcontroller.core.source.StartListeningControllerTask
 
getType() - Method in class com.activeviam.tools.dataloadcontroller.core.source.StopListeningControllerTask
 
getType() - Method in class com.activeviam.tools.dataloadcontroller.core.source.UnloadDataTxControllerTask
 
getType() - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcCsvHealthEventHandler
 
getType() - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcJdbcHealthEventHandler
Return the type identifying of plugin value
getType() - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcMessagingHealthEventHandler
Return the type identifying of plugin value
getType() - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcSummaryHealthEventHandler
 
getUpTime() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 

H

hasException(String) - Static method in class com.activeviam.tools.dataloadcontroller.core.source.TransactionTaskUtil
Return true boolean if there is any exception event
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic
 
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcFailureHealthEvent
 
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcTaskDoneHealthEvent
 
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingFailureHealthEvent
 
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingSummaryHealthEvent
 
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingTaskDoneHealthEvent
 
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcNoStatusHealthEvent
 
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcSummaryHealthEvent
 
hashCode() - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcUnloadHealthEvent
 
HYPHEN - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRestService
 

I

IAzureCsvConnector - Interface in com.activeviam.tools.dataloadcontroller.core.source.cloud.azure
Contract that defines a connector for Azure CSV files.
ICloudCsvConnector<E> - Interface in com.activeviam.tools.dataloadcontroller.core.source.cloud
Cloud connector general implementation for loading CSV data from cloud storage.
ICloudsScopedFetchTopic - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for a topic of a source that can fetch files to load data in ActivePivot.
ICloudsScopedFetchTopic.IFetchScopeToFileScanParametersConverter - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for a converter of a fetch scope into file scan parameters for ICloudsScopedFetchTopic.fetchFiles(Map).
ICloudsScopedFetchTopic.IFileScanParameters - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for file scan parameters for ICloudsScopedFetchTopic.fetchFiles(Map).
ICsvFilesScopedFetchTopic - Interface in com.activeviam.tools.dataloadcontroller.core.source.csv
Contract for a topic of a source that can fetch CSV files to load data in ActivePivot.
ICsvScopedFetchSourceConfig<I> - Interface in com.activeviam.tools.dataloadcontroller.core.source.csv
Configuration of the CSV source that supports scoped fetching.
IDataLoadController - Interface in com.activeviam.tools.dataloadcontroller.controller
Contract for a component that controls data loading/unloading operations in ActivePivot.
IDataLoadController.IExecutionRequest - Interface in com.activeviam.tools.dataloadcontroller.controller
Contract for a request to IDataLoadController to execute some data operation.
IDataLoadController.IExecutionTask - Interface in com.activeviam.tools.dataloadcontroller.controller
Contract for a task executable by IDataLoadController.
IDataLoadController.IScopeToRemoveWhereConditionConverter - Interface in com.activeviam.tools.dataloadcontroller.controller
Contract for a supplier of remove-where condition to apply to a particular target store given a particular business scope (for a particular data removal execution).
IDataLoadControllerRestService - Interface in com.activeviam.tools.dataloadcontroller.core.source.rest
Contract for a Rest (JAX-RS) Web-Service that allows remote clients to trigger some data loading/unloading on this ActivePivot server.
IDataLoadSourceHealthEventHandler - Interface in com.activeviam.tools.dataloadcontroller.event.handler
 
IDataSource<I,E> - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for a source that can fetch or listen to data for a specific scope that is specified at runtime for each fetch or listen operation.
IDlcCsvHealthEvent - Interface in com.activeviam.tools.dataloadcontroller.event
 
IDlcHealthEvent - Interface in com.activeviam.tools.dataloadcontroller.event
 
IDlcJdbcHealthEvent - Interface in com.activeviam.tools.dataloadcontroller.event
 
IDlcMessagingHealthEvent - Interface in com.activeviam.tools.dataloadcontroller.event
Contract for an event that will be generated by MessagingSource like kafka, RabbitMQ, ActiveMQ etc.
IFetchingDataSource<I,E> - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for a source that can fetch data for a specific scope that is specified at runtime for each fetch iteration.
IFilesScopedFetchTopic - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for a topic of a source that can fetch files to load data in ActivePivot.
IFilesScopedFetchTopic.IFetchScopeToFileScanParametersConverter - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for a converter of a fetch scope into file scan parameters for IFilesScopedFetchTopic.fetchFiles(Map).
IFilesScopedFetchTopic.IFileScanParameters - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for file scan parameters for IFilesScopedFetchTopic.fetchFiles(Map).
IFileTask<I,E> - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for a task that a files source may execute to load data in ActivePivot.
IFileTask.IResult - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for a result produced by a IFileTask.
IGoogleCsvConnector - Interface in com.activeviam.tools.dataloadcontroller.core.source.cloud.google
Connector to fetch CSV files from a Google cloud instance.
IJdbcScopedFetchSource - Interface in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Contract for a source that can load data from a Database into ActivePivot, based on SQL statements (defined via source topics) and fetch business scopes, which are defined at fetch time to derive the SQL input parameters required for injection into those statements.
IJdbcScopedFetchTopic - Interface in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Contract for a topic of a source that can fetch a DB to load data in ActivePivot.
IJdbcScopedFetchTopic.IScopeToSqlParametersConverter - Interface in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Contract for a converter of a business scope (for a particular statement task execution) into the relevant SQL input parameters (given the JDBC statement topic that this tasks relates to).
IJdbcSourceHealthEventHandler - Interface in com.activeviam.tools.dataloadcontroller.event.handler
An health event handler dedicated to handling health events declared in the JDBC Source project.
IJdbcStatementTask<I,E> - Interface in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Contract for a task that a JDBC source may execute to process a given Statement SQL statement to retrieve data from a Database and load them in ActivePivot.
IJdbcStatementTask.IResult - Interface in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Contract for a result produced by a JDBC statement task.
IListeningDataSource<I,E> - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for a source that can consume data from a messaging source like Apache Kafka, RabbitMQ, and can stay connected and "listen" for real-time data.
IMessagingConsumer - Interface in com.activeviam.tools.dataloadcontroller.core.source.messaging
Contract for implementing consumers for remote messaging topic or queue.
IMessagingSourceHealthEventHandler - Interface in com.activeviam.tools.dataloadcontroller.event.handler
A health event handler dedicated to handling health events generated by a MessagingSource
IMessagingTopic - Interface in com.activeviam.tools.dataloadcontroller.core.source.messaging
Contract for a topic of the Messaging Source.
incrLoadCsvMessageChannelFactory() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.csv.ICsvScopedFetchSourceConfig
 
incrLoadCsvSource(String) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.csv.ICsvScopedFetchSourceConfig
 
initialState() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
IS3CsvConnector - Interface in com.activeviam.tools.dataloadcontroller.core.source.cloud.s3
Contract for a S3 cloud connector for CSV files.
ISummaryHealthEventHandler - Interface in com.activeviam.tools.dataloadcontroller.event.handler
An health event handler dedicated to handling health events for summary messages.
ITupleSource - Interface in com.activeviam.tools.dataloadcontroller.core.source
Contract for a source that produces Object[] tuples.

J

JdbcPreparedStatementTask - Class in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Standard implementation of a IJdbcStatementTask that executes a prepared statement.
JdbcPreparedStatementTask(IJdbcScopedFetchTopic, Object[], DataSource, IMessageChannel<String, Object[]>) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcPreparedStatementTask
Create a task for for executing a prepared statement.
JdbcScopedFetchSource - Class in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Default implementation of a IJdbcScopedFetchSource.
JdbcScopedFetchSource(DataSource, Properties) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
Construct a JDBC source based on the specified connection factory and source properties.
JdbcStatementTopic - Class in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Base implementation of a IJdbcScopedFetchTopic.
JdbcStatementTopic(String, String, IJdbcScopedFetchTopic.IScopeToSqlParametersConverter, List<String>, String, Properties) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic
Construct a JDBC topic.
JdbcStatementTopic.ScopeToSqlParametersConverter - Class in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Default implementation for IScopeToSqlParametersConverter.
JsonFormatter - Class in com.activeviam.tools.dataloadcontroller.event.formatter
 
JsonFormatter() - Constructor for class com.activeviam.tools.dataloadcontroller.event.formatter.JsonFormatter
 

K

KafkaJsonDeserializer - Class in com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer
Deserialize bytes from kafka to a JsonNode and form an Object[] tuple from the JsonNode.
KafkaJsonDeserializer() - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.deserializer.KafkaJsonDeserializer
 
KafkaMessageConsumer - Class in com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka
A wrapper over KafkaConsumer to process records from a Kafka topic, and submit to a datastore.
KafkaMessageConsumer(Properties, String, String, LinkedBlockingQueue<Object[]>, Map<String, Object>, int) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 

L

level - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
line - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
The content of the line of which the parsing failed.
lineNumber - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
The line number at which the event was created.
listen(IFileListener<Path>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.csv.ICsvFilesScopedFetchTopic
 
listen(IMessageChannel<I, E>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IDataSource
 
LOAD_SUMMARY - Static variable in class com.activeviam.tools.dataloadcontroller.event.constants.DlcEventTypeConstants
 
LoadDataTxControllerTask - Class in com.activeviam.tools.dataloadcontroller.core.source
A IDataLoadController.IExecutionTask that loads data related to one or multiple topics and a particular business scope, within the boundaries of a single Datastore transaction.
LoadDataTxControllerTask(IDatastore, ConcurrentMap<String, DataLoadController.TopicControllerDelegates>, List<String>, Map<String, Object>) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.LoadDataTxControllerTask
Create a DS transaction task to fetch data for the specified topics and scope.
logErrorMsgAndFireFailureEvent(Throwable, String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 
logErrorMsgAndFireFailureEvent(Throwable, String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 
logger - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.LoadDataTxControllerTask
 
LogMessageOutputStream() - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.messaging.TxSizeController.LogMessageOutputStream
 

M

message - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingSummaryHealthEvent
 
message - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcNoStatusHealthEvent
 
message - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcSummaryHealthEvent
 
message - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcUnloadHealthEvent
 
MessagingSource - Class in com.activeviam.tools.dataloadcontroller.core.source.messaging
MessagingSource to poll topics in a remote messaging system, for eg.
MessagingSource(String) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingSource
 
MessagingTopic - Class in com.activeviam.tools.dataloadcontroller.core.source.messaging
Topic that listens for records from a messaging system, for eg.
MessagingTopic(String, String, List<String>, Properties, int, IDatastore, String[], String) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 
method - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
The method in which the event was created.
MISC_INFO - Static variable in class com.activeviam.tools.dataloadcontroller.event.constants.DlcEventTypeConstants
 

N

name - Variable in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
name - Variable in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
newFileTask(ICloudEntityPath, IMessageChannel<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
newFileTask(Path, IMessageChannel<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
newFileTask(ICloudEntityPath, IMessageChannel<String, Object>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.ICloudsScopedFetchTopic
Create a task for processing a file that belongs to this topic.
newFileTask(Path, IMessageChannel<String, Object>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IFilesScopedFetchTopic
Create a task for processing a file that belongs to this topic.
newStatementTask(Map<String, Object>, DataSource, IMessageChannel<?, ?>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.jdbc.IJdbcScopedFetchTopic
Create a task for processing the statement defined by this topic.
newStatementTask(Map<String, Object>, DataSource, IMessageChannel<?, ?>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic
 
NO_STATUS - Static variable in class com.activeviam.tools.dataloadcontroller.event.constants.DlcEventTypeConstants
 
numConsumers - Variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 

O

onCsvFileParsingDone(CsvFileParsingDone) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcCsvHealthEventHandler
 
onCsvFileParsingFailure(CsvFileParsingFailure) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcCsvHealthEventHandler
 
onCsvFileParsingProgress(CsvFileParsingProgress) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcCsvHealthEventHandler
 
onCsvLineParsingFailure(CsvLineParsingFailure) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcCsvHealthEventHandler
 
onException(DlcExceptionHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcSummaryHealthEventHandler
 
onException(DlcExceptionHealthEvent) - Method in interface com.activeviam.tools.dataloadcontroller.event.handler.ISummaryHealthEventHandler
 
onFetchedResultSet(ResultSet, ResultSetMetaData) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
Specialization method called by the fetching thread any time a new result has been retrieved from DB, which gives the opportunity for custom code to define what must be posted to publication queue after that.
onFetchedResultSet(ResultSet, ResultSetMetaData) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcPreparedStatementTask
 
onJdbcFailure(DlcJdbcFailureHealthEvent) - Method in interface com.activeviam.tools.dataloadcontroller.event.handler.IJdbcSourceHealthEventHandler
 
onJdbcFailure(DlcJdbcFailureHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcJdbcHealthEventHandler
 
onJdbcTaskDone(DlcJdbcTaskDoneHealthEvent) - Method in interface com.activeviam.tools.dataloadcontroller.event.handler.IJdbcSourceHealthEventHandler
 
onJdbcTaskDone(DlcJdbcTaskDoneHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcJdbcHealthEventHandler
 
onMessagingFailure(DlcMessagingFailureHealthEvent) - Method in interface com.activeviam.tools.dataloadcontroller.event.handler.IMessagingSourceHealthEventHandler
 
onMessagingFailure(DlcMessagingFailureHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcMessagingHealthEventHandler
 
onMessagingSummary(DlcMessagingSummaryHealthEvent) - Method in interface com.activeviam.tools.dataloadcontroller.event.handler.IMessagingSourceHealthEventHandler
 
onMessagingSummary(DlcMessagingSummaryHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcMessagingHealthEventHandler
 
onMessagingTaskDone(DlcMessagingTaskDoneHealthEvent) - Method in interface com.activeviam.tools.dataloadcontroller.event.handler.IMessagingSourceHealthEventHandler
 
onMessagingTaskDone(DlcMessagingTaskDoneHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcMessagingHealthEventHandler
 
onNoMoreFetchResult() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
Specialization method called by the fetching thread once it has no more result to retrieve from DB, which gives the opportunity for custom code to properly "finalize" whatever complex record building logic was at play.
onNoStatus(DlcNoStatusHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcSummaryHealthEventHandler
 
onNoStatus(DlcNoStatusHealthEvent) - Method in interface com.activeviam.tools.dataloadcontroller.event.handler.ISummaryHealthEventHandler
 
onSummary(DlcSummaryHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcSummaryHealthEventHandler
 
onSummary(DlcSummaryHealthEvent) - Method in interface com.activeviam.tools.dataloadcontroller.event.handler.ISummaryHealthEventHandler
 
onUnknownEvent(IHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcCsvHealthEventHandler
 
onUnknownEvent(IHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcJdbcHealthEventHandler
The default method to implement, that will receive all events by default.
onUnknownEvent(IHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcMessagingHealthEventHandler
The default method to implement, that will receive all events by default.
onUnknownEvent(IHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcSummaryHealthEventHandler
 
onUnload(DlcUnloadHealthEvent) - Method in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcSummaryHealthEventHandler
 
onUnload(DlcUnloadHealthEvent) - Method in interface com.activeviam.tools.dataloadcontroller.event.handler.ISummaryHealthEventHandler
 

P

PARSING_EXCEPTION - Static variable in class com.activeviam.tools.dataloadcontroller.event.constants.DlcEventTypeConstants
 
parsingInfo - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
Various information about the parsing.
pathMatcher - Variable in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
PLUGIN_KEY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcPreparedStatementTask
 
PLUGIN_KEY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.LoadDataTxControllerTask
 
PLUGIN_KEY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 
PLUGIN_KEY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.rabbitmq.RabbitMqMessageConsumer
 
PLUGIN_KEY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.StartListeningControllerTask
 
PLUGIN_KEY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.StopListeningControllerTask
 
PLUGIN_KEY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.UnloadDataTxControllerTask
 
PLUGIN_KEY - Static variable in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcCsvHealthEventHandler
 
PLUGIN_KEY - Static variable in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcJdbcHealthEventHandler
 
PLUGIN_KEY - Static variable in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcMessagingHealthEventHandler
 
PLUGIN_KEY - Static variable in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcSummaryHealthEventHandler
 
poll() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.csv.ICsvFilesScopedFetchTopic
 
processObjectArrayRecord(Object[], Object[]) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
Combine the key and value Object[] to a single Object[] representing a tuple that can be sent to datastore.
PROP__BROKER_URI - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.rabbitmq.RabbitMqMessageConsumer
 
PROP__CONTROLLER_NAME - Static variable in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
Optional property, to set a custom name for this controller.
PROP__EXCEPTION_ONLY_RESPONSE - Static variable in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
Optional property, to set the exception even type in response only.
PROP__JDBC_FETCH_SIZE - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
Optional property, to set JDBC driver fetch size.
PROP__MAX_TX_DRAIN_SIZE - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
To set capacity of the publish queue.
PROP__MAX_TX_DRAIN_TIME_MS - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
To set max wait time before committing transaction
PROP__PUBLISH_CHUNK_SIZE - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
Optional property, to set size of publish message chunks.
PROP__PUBLISH_CHUNK_SIZE - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
Optional property, to set size of publish message chunks.
PROP__PUBLISH_QUEUE_CAPACITY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
Optional property, to set capacity of the publish queue.
PROP__PUBLISH_QUEUE_CAPACITY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
Optional property, to set the size of publish queue that accumulates records from remote topic before publishing them to datastore (default = 100M)
PROP__PUBLISH_TASK_MAX_CONCURRENCY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
Optional property, to set max concurrency of publish tasks per fetch task.
PROP__PUBLISH_TASK_MAX_CONCURRENCY_PER_FETCH_TASK - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
Optional property, to set max concurrency of publish tasks per fetch task.
PROP__SOURCE_NAME - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvScopedFetchSource
Optional property, to set a custom name for this source.
PROP__SOURCE_NAME - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
Optional property, to set a custom name for this source.
PROP__STATEMENT_TASK_MAX_CONCURRENCY - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcScopedFetchSource
Optional property, to set max concurrency of statement tasks.
PROP_COBDATE_INDEX - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 
PROP_COBDATE_INDEX - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.rabbitmq.RabbitMqMessageConsumer
 
PROP_POLL_TIMEOUT - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 
props - Variable in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 
providerFactory - Variable in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
PublishTask(List<E>, IMessageChannel<String, E>, String, TxSizeController.PublishInfoAccumulator) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.messaging.TxSizeController.PublishTask
 

R

RabbitMqMessageConsumer - Class in com.activeviam.tools.dataloadcontroller.core.source.messaging.rabbitmq
Consume messages from a RabbitMQ queue.
RabbitMqMessageConsumer(Properties, String, String, BlockingQueue<Object[]>, Map<String, Object>, int) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.messaging.rabbitmq.RabbitMqMessageConsumer
 
ReadTupleFieldColumnCalculator - Class in com.activeviam.tools.dataloadcontroller.core.source.jdbc
Column calculator that extracts values for a particular column in the given (source) Object[] tuple, based on the column index that has been configured at construction time.
ReadTupleFieldColumnCalculator(String, int) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.jdbc.ReadTupleFieldColumnCalculator
Create a new column calculator.
regex - Variable in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
registerChannel(IMessageChannel<?, ?>, Collection<String>, IDataLoadController.IScopeToRemoveWhereConditionConverter) - Method in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
 
registerChannel(IMessageChannel<?, ?>, Collection<String>, IDataLoadController.IScopeToRemoveWhereConditionConverter) - Method in interface com.activeviam.tools.dataloadcontroller.controller.IDataLoadController
Register a store message channel with this controller.
registerDlcEventHandlers(List<IHealthEventHandler>) - Method in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
 
registerDlcEventHandlers(List<IHealthEventHandler>) - Method in interface com.activeviam.tools.dataloadcontroller.controller.IDataLoadController
Register custom event handlers to monitor source related events.
registerSource(IDataSource<?, ?>) - Method in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
 
registerSource(IDataSource<?, ?>) - Method in interface com.activeviam.tools.dataloadcontroller.controller.IDataLoadController
Register a source with this controller.
registerTopicAlias(String, List<String>) - Method in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
 
registerTopicAlias(String, List<String>) - Method in interface com.activeviam.tools.dataloadcontroller.controller.IDataLoadController
Register an alias to conveniently references multiple topics.
removeWhereConditionSupplier - Variable in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController.TopicControllerDelegates
 
reset() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.csv.ICsvFilesScopedFetchTopic
 
resolvePath(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
Result(String, Object[], long, long, long, long, long, long) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask.Result
 
result - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcTaskDoneHealthEvent
 
result - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingTaskDoneHealthEvent
 
rootDirectory() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.azure.IAzureCsvConnector
Create a wrapper on a cloud directory.
rootDirectory() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.google.IGoogleCsvConnector
 
rootDirectory() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.ICloudCsvConnector
Create a wrapper on a cloud directory.
rootDirectory() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.cloud.s3.IS3CsvConnector
 
rootDirectoryPath - Variable in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
Watched directory
rootDirectoryPath - Variable in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
run() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.TxSizeController.PublishTask
 
run() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.TxSizeController
 

S

scope - Variable in class com.activeviam.tools.dataloadcontroller.core.source.AExecutionTask
 
SCOPE_KEY__COB_DATE - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRestService
Business parameters scopes defined here.
SCOPE_KEY__CONFIGURATION - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRestService
 
SCOPE_KEY__RECURSIVE - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic.FetchScopeToFileScanParametersConverter
 
SCOPE_KEY__RECURSIVE - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic.FetchScopeToFileScanParametersConverter
 
SCOPE_KEY__REL_DIR_PATH - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic.FetchScopeToFileScanParametersConverter
 
SCOPE_KEY__REL_DIR_PATH - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic.FetchScopeToFileScanParametersConverter
 
SCOPE_KEY__TIME_STAMP - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRestService
 
SCOPE_KEY_BRANCH - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRestService
 
ScopeToSqlParametersConverter(String...) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic.ScopeToSqlParametersConverter
Create a converter of a business scope (for statement task execution) into the relevant SQL input parameters for a given JDBC statement topic.
setCause(Throwable) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
setClazz(String) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
setDlcLoadingStatus(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
setEvents(List<IHealthEvent>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
setEventType(String) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
setExceptionOnlyResponse(boolean) - Method in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController
If exceptionOnlyResponse is set to true, the RESTful response only includes exception events.
setFile(String) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
setFileLineNumber(long) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
setLevel(Level) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
setLine(String) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
setLineNumber(int) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
setMethod(String) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
setParsingInfo(IParsingInfo) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
setSourceColumn(String, String, Map<String, Integer>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.TupleMessageChannelFactory
 
setStoreToTaskNameMap(Map<String, String>) - Static method in class com.activeviam.tools.dataloadcontroller.cache.StoreToTaskNameMapper
 
setTags(Set<String>) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
 
setTaskName(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
setTaskName(String) - Method in interface com.activeviam.tools.dataloadcontroller.event.handler.IDataLoadSourceHealthEventHandler
 
setTaskName(String) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
setThreadId(long) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
setThreadName(String) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
setTimeStamp(long) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
setTimeTakenMs(long) - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
setUpTime(long) - Method in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
shutdown() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.messaging.IMessagingConsumer
Logic to shutdown/stop the consumer thread.
shutdown() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.kafka.KafkaMessageConsumer
 
shutdown() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.rabbitmq.RabbitMqMessageConsumer
 
signalPublishers() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.TxSizeController
 
source - Variable in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController.TopicControllerDelegates
 
sourceFieldIdx - Variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.ReadTupleFieldColumnCalculator
 
startConsumers(IMessageChannel<?, ?>, Map<String, Object>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.messaging.IMessagingTopic
Instantiates the concrete consumer impl and starts the consumer asynchronously.
startConsumers(IMessageChannel<?, ?>, Map<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 
startListening(List<? extends IMessageChannel<?, ?>>, Map<String, Object>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IListeningDataSource
Asynchronously listen and consume data from a MessagingSource like Apache Kafka, RabbitMQ.
startListening(List<? extends IMessageChannel<?, ?>>, Map<String, Object>) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingSource
Start consumers to listen to the remote messaging topic.
StartListeningControllerTask - Class in com.activeviam.tools.dataloadcontroller.core.source
A IDataLoadController.IExecutionTask that starts consumers on the MessagingTopic/s specified.
StartListeningControllerTask(IDatastore, ConcurrentMap<String, DataLoadController.TopicControllerDelegates>, List<String>, Map<String, Object>) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.StartListeningControllerTask
Create a task to listen for data for the specified messaging topics.
status(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRestService
 
status(String) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.rest.IDataLoadControllerRestService
Check the status of a particular processing previously triggered via this service.
stopConsumers() - Method in interface com.activeviam.tools.dataloadcontroller.core.source.messaging.IMessagingTopic
Stops the consumers.
stopConsumers() - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingTopic
 
stopListening(String) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IListeningDataSource
Asynchronously stop the consumers for the specified topics.
stopListening(String) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.MessagingSource
Stop all consumers for given topic
StopListeningControllerTask - Class in com.activeviam.tools.dataloadcontroller.core.source
A IDataLoadController.IExecutionTask that stops the consumers/listeners for given MessagingTopic.
StopListeningControllerTask(IDatastore, ConcurrentMap<String, DataLoadController.TopicControllerDelegates>, List<String>, Map<String, Object>) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.StopListeningControllerTask
Create a task to stop listening for data for the specified MessagingTopic/s.
storeToTaskNameMap - Static variable in class com.activeviam.tools.dataloadcontroller.cache.StoreToTaskNameMapper
 
StoreToTaskNameMapper - Class in com.activeviam.tools.dataloadcontroller.cache
 
StoreToTaskNameMapper() - Constructor for class com.activeviam.tools.dataloadcontroller.cache.StoreToTaskNameMapper
 
StringFormatter - Class in com.activeviam.tools.dataloadcontroller.event.formatter
 
StringFormatter() - Constructor for class com.activeviam.tools.dataloadcontroller.event.formatter.StringFormatter
 
SUCCESS - Static variable in class com.activeviam.tools.dataloadcontroller.event.constants.DlcEventTypeConstants
 
SUMMARY - Static variable in class com.activeviam.tools.dataloadcontroller.event.constants.DlcEventTypeConstants
 

T

TAGS - Static variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
The tags of this event.
TAGS - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcCsvHealthEvent
The tags of this event.
TAGS - Static variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcExceptionHealthEvent
 
TAGS - Static variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcFailureHealthEvent
The tags of this event.
TAGS - Static variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcJdbcTaskDoneHealthEvent
The tags of this event.
TAGS - Static variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingFailureHealthEvent
The tags of this event.
TAGS - Static variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingSummaryHealthEvent
 
TAGS - Static variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingTaskDoneHealthEvent
The tags of this event.
TAGS - Static variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcNoStatusHealthEvent
 
TAGS - Static variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcSummaryHealthEvent
 
TAGS - Static variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcUnloadHealthEvent
 
targetStores - Variable in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController.TopicControllerDelegates
 
TASK_LOG_TOKEN - Static variable in class com.activeviam.tools.dataloadcontroller.core.source.ADatastoreTransactionTask
 
taskName - Variable in class com.activeviam.tools.dataloadcontroller.core.source.AExecutionTask
 
taskName - Variable in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.AJdbcPreparedStatementTask
 
taskName - Variable in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcCsvHealthEventHandler
 
taskName - Variable in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcJdbcHealthEventHandler
 
taskName - Variable in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcMessagingHealthEventHandler
 
taskName - Variable in class com.activeviam.tools.dataloadcontroller.event.handler.impl.DlcSummaryHealthEventHandler
 
taskName - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 
threadId - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
The name of the thread that created the event.
threadName - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
The id of the thread that created the event.
timeStamp - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
The Unix timestamp, in ms, at the creation of the event.
topic - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.DlcMessagingSummaryHealthEvent
 
TOPIC_EVENT_HANDLER_LIST_CACHE - Static variable in class com.activeviam.tools.dataloadcontroller.cache.DlcCacheManager
 
TopicControllerDelegates(IDataSource<?, ?>, IMessageChannel<?, ?>, Collection<String>, IDataLoadController.IScopeToRemoveWhereConditionConverter) - Constructor for class com.activeviam.tools.dataloadcontroller.controller.DataLoadController.TopicControllerDelegates
 
topics - Variable in class com.activeviam.tools.dataloadcontroller.core.source.AExecutionTask
 
toString() - Method in class com.activeviam.tools.dataloadcontroller.controller.DataLoadController.TopicControllerDelegates
 
toString() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic.FetchScopeToFileScanParametersConverter
 
toString() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvCloudScopedFetchTopic
 
toString() - Method in class com.activeviam.tools.dataloadcontroller.core.source.csv.CsvFilesScopedFetchTopic
 
toString() - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic.FetchScopeToFileScanParametersConverter
 
toString() - Method in class com.activeviam.tools.dataloadcontroller.core.source.FilesScopedFetchTopic
 
toString(IMessageChannel<?, ?>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IDataSource
 
toString(List<? extends IMessageChannel<?, ?>>) - Method in interface com.activeviam.tools.dataloadcontroller.core.source.IDataSource
 
toString() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic.ScopeToSqlParametersConverter
 
toString() - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.JdbcStatementTopic
 
toString() - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerRequest
 
toString() - Method in class com.activeviam.tools.dataloadcontroller.core.source.rest.DataLoadControllerResponse
 
TransactionTaskUtil - Class in com.activeviam.tools.dataloadcontroller.core.source
Utility class for Tx Controller Task
TransactionTaskUtil() - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.TransactionTaskUtil
 
translate(Object[]) - Method in class com.activeviam.tools.dataloadcontroller.core.source.jdbc.TupleToTupleTranslator
 
TupleMessageChannelFactory - Class in com.activeviam.tools.dataloadcontroller.core.source.jdbc
A factory for low-translation-overhead message channels that connect a source producing Object[] tuples to a store in ActivePivot Datastore.
TupleMessageChannelFactory(ITupleSource, IDatastore) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.jdbc.TupleMessageChannelFactory
Create a new tuple message channel factory.
TupleToTupleTranslator - Class in com.activeviam.tools.dataloadcontroller.core.source.jdbc
A translator that produces a 'target' Object[] tuple based on a 'source' Object[] tuple.
TupleToTupleTranslator(List<IColumnCalculator<Object[]>>) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.jdbc.TupleToTupleTranslator
Create a new tuple-to-tuple translator.
TxSizeController - Class in com.activeviam.tools.dataloadcontroller.core.source.messaging
Drain the AP topic's internal publishQueue, and submit records to datastore.
TxSizeController(BlockingQueue<Object[]>, int, int, int, int, String, IMessageChannel<?, ?>, IDatastore, String[], int) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.messaging.TxSizeController
 
TxSizeController.LogMessageOutputStream - Class in com.activeviam.tools.dataloadcontroller.core.source.messaging
 
TxSizeController.PublishTask<E> - Class in com.activeviam.tools.dataloadcontroller.core.source.messaging
 

U

UNLOAD - Static variable in class com.activeviam.tools.dataloadcontroller.event.constants.DlcEventTypeConstants
 
UnloadDataTxControllerTask - Class in com.activeviam.tools.dataloadcontroller.core.source
A IDataLoadController.IExecutionTask that unloads data related to one or multiple topics and a particular business scope, within the boundaries of a single Datastore transaction.
UnloadDataTxControllerTask(IDatastore, ConcurrentMap<String, DataLoadController.TopicControllerDelegates>, List<String>, Map<String, Object>) - Constructor for class com.activeviam.tools.dataloadcontroller.core.source.UnloadDataTxControllerTask
Create a DS transaction task to delete data for the specified topics and scope.
upTime - Variable in class com.activeviam.tools.dataloadcontroller.event.impl.ADlcHealthEvent
 

W

waitUntilAllEventsProcessed(String) - Static method in class com.activeviam.tools.dataloadcontroller.core.source.TransactionTaskUtil
 
write(int) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.TxSizeController.LogMessageOutputStream
 
write(byte[]) - Method in class com.activeviam.tools.dataloadcontroller.core.source.messaging.TxSizeController.LogMessageOutputStream
 
A B C D E F G H I J K L M N O P R S T U W 
Skip navigation links

Copyright © 2020. All rights reserved.