Package | Description |
---|---|
com.attivio.platform.store | |
com.attivio.platform.transformer.ingest.util | |
com.attivio.sdk | |
com.attivio.sdk.api | |
com.attivio.sdk.autocomplete | |
com.attivio.sdk.client |
Interfaces for client side AIE development.
|
com.attivio.sdk.client.audit | |
com.attivio.sdk.client.streaming |
Interfaces that allow developers to request all results, facets, or document id's back from a query.
|
com.attivio.sdk.client.trigger |
Copyright 2016 Attivio Inc., All rights reserved.
|
com.attivio.sdk.commandline | |
com.attivio.sdk.esb | |
com.attivio.sdk.ingest | |
com.attivio.sdk.search | |
com.attivio.sdk.security | |
com.attivio.sdk.server.component |
Interfaces necessary to write components for the AIE system.
|
com.attivio.sdk.server.component.ingest |
Interfaces for all ingest related transformers and associated dependencies of those transformers.
|
com.attivio.sdk.server.component.lifecycle |
Annotations used to indicate that a component wishes to be notified of certain AIE lifecyle events.
|
com.attivio.sdk.server.component.query |
Interfaces for all query and response related transformers and associated dependencies of those transformers.
|
com.attivio.sdk.server.component.reduce | |
com.attivio.sdk.server.export | |
com.attivio.sdk.server.global |
Interfaces for data structures and control mechanisms that AIE provides to help components coordinate and store data globally across a cluster of AIE Nodes.
|
com.attivio.sdk.server.tokenization |
Interfaces class that handle breaking free text / Strings into
TokenList s. |
com.attivio.sdk.service | |
com.attivio.sdk.test | |
com.attivio.service | |
com.attivio.util | |
com.sample.module |
Modifier and Type | Method and Description |
---|---|
void |
MockConnectorHistory.clearHistory(String connectorName)
Removes all history associated with the connector.
|
void |
MockConnectorHistory.connectorCompleted(String connectorName,
long finalDocCount)
The connector has completed -- all documents have been fully processed.
|
void |
MockConnectorHistory.connectorCompleting(String connectorName)
The connector is completing -- all documents have been sent but have not finished being processed.
|
void |
MockConnectorHistory.connectorPaused(String connectorName)
A node has paused the connector.
|
void |
MockConnectorHistory.connectorQueued(String connectorName,
UUID clientId,
String workflow,
List<String> extraRunInfo,
boolean external)
The connector has been submitted for execution on an AIE node.
|
void |
MockConnectorHistory.connectorReset(String connectorName)
Indicates that the incremental state of the connector has been reset.
|
void |
MockConnectorHistory.connectorResumed(String connectorName)
A node has resumed a paused connector.
|
void |
MockConnectorHistory.connectorStarted(String connectorName,
long timestamp)
A node has started executing the connector.
|
void |
MockConnectorHistory.updateExtraRunInfo(String connectorName,
List<String> extraRunInfo)
Updates the extraRunInfo for
connectorName . |
void |
MockConnectorHistory.updateSentCount(String connectorName,
long docCount)
Updates the number of documents sent by
connectorName . |
Modifier and Type | Method and Description |
---|---|
static <T> boolean |
TransformerUtils.mapFieldValues(IngestDocument doc,
FieldValueCreatingTransformer<T> trans)
Applies a FieldValueCreatingTransformer to the given IngestDocument.
|
static <T> boolean |
TransformerUtils.processDocument(IngestDocument doc,
FieldValueCreatingTransformer<T> transformer)
A processDocument utility method for FieldValueCreatingTransformer, because that class doesn't have one.
|
Modifier and Type | Method and Description |
---|---|
AttivioException |
AttivioIOException.getAttivioException()
Convert this exception into an
AttivioException . |
AttivioException |
AttivioRuntimeException.getAttivioException()
Convert this exception into an
AttivioException . |
AttivioException |
AttivioThrowable.toRemoteException()
Convert this exception to be a remote exception.
|
AttivioException |
AttivioIOException.toRemoteException()
Convert this exception to be a remote exception.
|
AttivioException |
AttivioRuntimeException.toRemoteException()
Convert this exception to be a remote exception.
|
AttivioException |
AttivioException.toRemoteException()
Convert this exception to be a remote exception.
|
Modifier and Type | Method and Description |
---|---|
void |
ContentStoreProvider.add(String namespace,
String id,
InputStream in)
Content will be copied from the InputStream and stored within the
namespace under the id . |
boolean |
ContentStoreProvider.contains(String namespace,
String id) |
void |
ContentStoreProvider.delete(String namespace,
String id)
Deletes
id from the namespace . |
void |
ContentStoreProvider.deleteAll(String namespace)
Deletes all content from the store within the namespace
|
String |
ContentStoreProvider.externalize(String storeName,
String id)
Returns an externally accessible URI for the content suitable for HTTP GET.
|
InputStream |
ContentStoreProvider.get(String namespace,
String id)
Returns an InputStream to access the content.
|
long |
ContentStoreProvider.getDiskUtilization() |
long |
ContentStoreProvider.getLastModified(String namespace,
String id) |
List<String> |
ContentStoreProvider.getNamespaces() |
long |
ContentStoreProvider.getSize(String namespace,
String id) |
long |
ContentStoreProvider.getTotalRecords(String namespace) |
Modifier and Type | Method and Description |
---|---|
List<AutoCompleteSuggestion> |
AutoCompleteProvider.getSuggestions(QueryRequest req)
Get a list of query auto complete suggestions for the specified term.
|
void |
SharedResourceAutoCompleteProvider.resourceModified(URI uri)
Hook method called when the shared resource is modified
|
Modifier and Type | Method and Description |
---|---|
void |
EventStoreApi.acknowledgeEvent(long eventId,
String user,
String reason) |
long |
EventStoreApi.addEvent(SystemEvent event) |
void |
MockSignalTrackingService.addSignal(Signal signal) |
void |
SignalTrackingApi.addSignal(Signal signal)
Add a signal
|
DictionaryInfo |
DictionaryClient.approveDictionary(DictionaryInfo info)
Approve pending changes to dictionary identified by
info . |
void |
DocumentOutputClient.bulkUpdate(BulkUpdate message)
Send
message to AIE. |
void |
IngestionHistoryApi.childCreated(String namespace,
String key,
String childKey)
Marks the
childKey as one created by the record associated with key . |
void |
IngestionHistoryApi.clear(String namespace)
Removes all historical information associated with the
namespace . |
void |
ConnectorHistoryApi.clearHistory(String connectorName)
Removes all history associated with the connector.
|
DictionaryInfo |
DictionaryClient.cloneDictionary(DictionaryInfo source,
DictionaryInfo dest)
Clone dictionary
source to dest . |
void |
IngestClient.commit(String... zones)
Sends internal queue of documents and commits all documents sent to AIE.
|
void |
ConnectorHistoryApi.connectorCompleted(String connectorName,
long finalDocCount)
The connector has completed -- all documents have been fully processed.
|
void |
ConnectorHistoryApi.connectorCompleting(String connectorName)
The connector is completing -- all documents have been sent but have not finished being processed.
|
void |
ConnectorHistoryApi.connectorPaused(String connectorName)
A node has paused the connector.
|
void |
ConnectorHistoryApi.connectorQueued(String connectorName,
UUID clientId,
String workflow,
List<String> extraRunInfo,
boolean external)
The connector has been submitted for execution on an AIE node.
|
void |
ConnectorHistoryApi.connectorReset(String connectorName)
Indicates that the incremental state of the connector has been reset.
|
void |
ConnectorHistoryApi.connectorResumed(String connectorName)
A node has resumed a paused connector.
|
void |
ConnectorHistoryApi.connectorStarted(String connectorName,
long timestamp)
A node has started executing the connector.
|
boolean |
ContentStoreClient.contains(String id)
Deprecated.
True if the content store has a stream for this id.
|
long |
EventStoreApi.countEvents() |
DictionaryInfo |
DictionaryClient.createDictionary(DictionaryInfo info)
Create dictionary
info . |
DictionaryInfo |
DictionaryClient.createDictionaryEntries(DictionaryInfo info,
String contentStoreId)
Add all entries from
contentStorId in csv format to dictionary identified by info . |
DictionaryEntry |
DictionaryClient.createDictionaryEntry(DictionaryEntry entry)
Create a dictionary entry.
|
List<IngestDocument> |
ConnectorControlApi.debugConnector(String connectorName,
int numDocs)
A method to help with debugging connectors.
|
void |
DocumentOutputClient.delete(Collection<String> ids)
See
DocumentOutputClient.delete(String...) for documentation. |
void |
DocumentOutputClient.delete(String... ids)
Delete a series of documents from AIE by document id.
|
void |
ContentStoreClient.delete(String id)
Deprecated.
Delete a record by id from the content store.
|
void |
DocumentStoreApi.delete(String namespace,
String docId)
Deletes the document from the specified collection
|
void |
ContentStoreClient.deleteAll()
Deprecated.
Delete all content in the content store.
|
void |
DocumentOutputClient.deleteByQuery(String queryWorkflow,
Query query)
Delete all documents that match the
Query . |
DictionaryInfo |
DictionaryClient.deleteDictionary(DictionaryInfo info)
Delete dictionary
info . |
DictionaryEntry |
DictionaryClient.deleteDictionaryEntry(DictionaryEntry entry)
Delete a dictionary entry.
|
void |
DictionaryClient.deleteDictionaryFromContentStore(String contentStoreId)
Deprecated.
|
void |
IngestClient.deletePrincipal(AttivioPrincipalKey key)
Delete an AttivioPrincipal from AIE.
|
void |
SignalTrackingApi.deleteSignals(String signalType)
Delete all signals for
signalType . |
void |
DocumentOutputClient.endMessageGroup()
Ends the current message group (if any).
|
String |
DictionaryClient.exportDictionary(DictionaryInfo info)
Export published form of dictionary.
|
void |
IngestClient.feed(AttivioPrincipal principal)
Feeds an AttivioPrincipal to AIE.
|
void |
DocumentOutputClient.feed(IngestDocument... docs)
Send
docs to AIE. |
void |
IngestClient.feed(IngestDocument doc,
AttivioAcl acl)
Feeds the document with its ACL to AIE.
|
void |
DocumentOutputClient.feed(Iterable<IngestDocument> docs)
Send
docs to AIE. |
Iterable<IngestDocument> |
DocumentStoreApi.filteredRetrieve(String namespace,
Map<String,String> filters)
Finds and returns the documents matching the provided equality filters.
|
Iterable<String> |
IngestionHistoryApi.getChildren(String namespace,
String key)
Returns an Iterable of the children that were marked as created via the
IngestionHistoryApi.childCreated(String, String, String) method. |
Schema |
SearchClient.getDefaultSchema()
Gets the schema named 'default' which is the most commonly one used throughout the system.
|
AdminQueryResult<DictionaryInfo> |
DictionaryClient.getDictionaries(AdminQuery query,
int offset,
int rows)
Get all matching dictionaries.
|
DictionaryInfo |
DictionaryClient.getDictionary(RevisionStatus view,
DictionaryType type,
String name,
String group)
Get a dictionary info based on the (type, name, group).
|
AdminQueryResult<DictionaryEntry> |
DictionaryClient.getDictionaryEntries(AdminQuery query,
int offset,
int rows)
Get dictionary entries.
|
DictionaryEntry |
DictionaryClient.getDictionaryEntry(RevisionStatus view,
String entryId)
Get a dictionary entry based on its entryId.
|
SearchDocument |
SearchClient.getDocumentById(String documentId)
Gets a document by a specific document Id
|
SystemEvent |
EventStoreApi.getEvent(long eventId) |
EventQuery |
EventStoreApi.getEvents(EventQuery eventQuery)
Executes the event query.
|
ConnectorExecutionRecord |
ConnectorControlApi.getExecutionInfo(String connectorName)
Gets execution information for the connector.
|
Iterable<ConnectorExecutionRecord> |
ConnectorHistoryApi.getHistory(String connectorName) |
ConnectorExecutionRecord |
ConnectorHistoryApi.getLatestHistory(String connectorName) |
Date |
IngestionHistoryApi.getPreviousStartTime(String namespace)
Returns the start time for the last session for this
namespace . |
List<String> |
MockAutoCompleteApi.getProviderNames() |
List<String> |
AutoCompleteApi.getProviderNames()
Get a list of all the
autocomplete provider names registered in Attivio |
AdminQueryResult<DictionaryEntry> |
DictionaryClient.getPublishedEntities(String name,
String group,
String query,
int offset,
int rows)
Get a list of published entries for an entity dictionary.
|
Schema |
SearchClient.getSchema(String schemaName)
Get a named schema in the system or null if it does not exist.
|
List<String> |
SignalTrackingApi.getSignalTypes()
Get all available signal types.
|
byte[] |
IngestionHistoryApi.getSignature(String namespace,
String key)
Returns the last signature associated with the key or
null if no signature is present. |
Date |
IngestionHistoryApi.getStartTime(String namespace)
Returns the start time of the current session for this
namespace . |
List<AutoCompleteSuggestion> |
MockAutoCompleteApi.getSuggestions(String providerName,
QueryRequest req) |
List<AutoCompleteSuggestion> |
AutoCompleteApi.getSuggestions(String providerName,
QueryRequest req)
Get all suggestions from a certain
autocomplete provider given its name and
a query request |
long |
ContentStoreClient.getTotalRecords()
Deprecated.
Get the total number of records in the content store.
|
Iterable<String> |
IngestionHistoryApi.getUnvisited(String namespace)
Returns an
Iterable of the keys that have not been visited in the current session. |
Iterable<String> |
IngestionHistoryApi.getUnvisited(String namespace,
Date since)
Returns an
Iterable of the keys that have not been visited since the time since . |
void |
DictionaryClient.importDictionary(String contentStoreId) |
void |
SignalTrackingApi.importSignals(Iterable<Signal> signals)
Import signals to be tracked
|
boolean |
IngestClient.isCompleted()
True is all messages sent have been fully processed by AIE.
|
void |
IngestClient.optimize()
Sends internal queue of documents and optimizes the AIE index and associated data structures.
|
void |
ConnectorControlApi.pause(String connectorName)
Pauses the named connector
|
DictionaryInfo |
DictionaryClient.publishDictionary(DictionaryInfo info)
Publish approved changes to dictionary identified by
info . |
ContentPointer |
IngestClient.put(String id,
byte[] bytes)
Put the contents of a byte array into the content store.
|
ContentPointer |
IngestClient.put(String id,
File f)
Put the contents of a File into the content store.
|
ContentPointer |
IngestClient.put(String id,
InputStream input)
Put a resource into the Content Store.
|
ContentPointer |
IngestClient.put(String id,
InputStreamBuilder input)
Stores binary data in the ContentStore.
|
void |
IngestClient.refresh()
Sends internal queue of documents and commits all partial update documents sent to AIE.
|
DictionaryInfo |
DictionaryClient.refreshDictionary(DictionaryInfo info)
Refresh dictionary identified by
info . |
DictionaryInfo |
DictionaryClient.registerDictionary(DictionaryInfo info,
String contentStoreId)
Create dictionary defined by
info and import all dictionary entries at contentStoreId in csv format. |
void |
IngestionHistoryApi.removeDocumentByKey(String namespace,
String key)
Removes a document using the key
|
void |
DictionaryClient.replaceDictionary(String contentStoreId)
Replace dictionary with import.
|
DictionaryInfo |
DictionaryClient.replaceDictionaryEntries(DictionaryInfo info,
String contentStoreId)
Add all entries from
contentStorId in csv format to dictionary identified by info . |
void |
ConnectorControlApi.reset(String connectorName)
Resets the incremental state of the named connector
|
void |
MockAutoCompleteApi.resourceModified(String uri) |
void |
AutoCompleteApi.resourceModified(String uri)
Notifies all
autocomplete providers that share resources
that their resource has been modified. |
void |
ConnectorControlApi.resume(String connectorName)
Resumes the named connector if paused
|
ContentPointer |
ContentStoreClient.retrieve(String id)
Deprecated.
Retrieve a ContentPointer in the ContentStore.
|
IngestDocument |
DocumentStoreApi.retrieve(String namespace,
String docId) |
DictionaryInfo |
DictionaryClient.revertDictionary(DictionaryInfo info,
boolean recursive)
Revert pending changes to dictionary.
|
DictionaryInfo |
DictionaryClient.revertDictionaryApproval(DictionaryInfo info,
boolean recursive)
Revert approved changes to dictionary.
|
DictionaryEntry |
DictionaryClient.revertDictionaryEntry(DictionaryEntry entry)
Revert pending changes to dictionary entry.
|
DictionaryEntry |
DictionaryClient.revertDictionaryEntryApproval(DictionaryEntry entry)
Revert approved changes to dictionary entry.
|
QueryResponse |
SearchClient.search(QueryRequest query)
Sends the query to the Attivio search and returns the result.
|
StreamingQueryResponse |
SearchClient.search(StreamingQueryRequest req)
Sends the streaming query request to the Attivio search and returns the result.
|
QueryResponse |
SearchClient.search(String query)
Searches using a query string only.
|
void |
IngestClient.sendIndexMessage(IndexMessage message)
Sends an arbitrary IndexMessage into the engine.
|
void |
IngestClient.sendQueuedDocuments()
Send the documents in the queue to the engine
|
UUID |
ConnectorControlApi.start(String connectorName)
Starts the named connector
|
void |
DocumentOutputClient.startMessageGroup()
Starts a group of messages that will be processed together.
|
Date |
IngestionHistoryApi.startSession(String namespace)
Starts a new session for the namespace.
|
void |
ConnectorControlApi.stop(String connectorName)
Stops the connector
|
void |
ConnectorControlApi.stop(String connectorName,
long shutdownWaitTimeout)
Stops the connector
|
void |
DocumentStoreApi.store(String namespace,
IngestDocument doc,
List<String> filterFields,
boolean storeContentPointers)
Stores the document in
namespace , creating indexes which allow equality filtering on the list of fields provided. |
ContentPointer |
ContentStoreClient.store(String id,
InputStreamBuilder input)
Deprecated.
Store a ContentPointer in the ContentStore.
|
IngestDocument |
DocumentStoreApi.storeAndUpdate(String namespace,
IngestDocument doc,
List<String> filterFields,
boolean storeContentPointers)
Stores the document in
namespace , creating indexes which allow equality filtering on the list of fields provided. |
void |
DictionaryClient.storeDictionaryInContentStore(String contentStoreId,
byte[] bytes)
Deprecated.
|
DictionaryInfo |
DictionaryClient.updateDictionary(DictionaryInfo info)
Update dictionary
info . |
DictionaryEntry |
DictionaryClient.updateDictionaryEntry(DictionaryEntry entry)
Update a dictionary entry.
|
void |
ConnectorHistoryApi.updateExtraRunInfo(String connectorName,
List<String> extraRunInfo)
Updates the extraRunInfo for
connectorName . |
void |
ConnectorHistoryApi.updateSentCount(String connectorName,
long docCount)
Updates the number of documents sent by
connectorName . |
void |
IngestionHistoryApi.visit(String namespace,
String key,
byte[] signature)
Records the
key as having been visited updates its associated signature. |
boolean |
IngestClient.waitForCompletion()
Wait for all MessageResults to be processed.
|
boolean |
IngestClient.waitForCompletion(long timeout)
Wait the specified number of milliseconds for all MessageResults to be processed.
|
Modifier and Type | Method and Description |
---|---|
long |
AuditWriterApi.audit(AuditDetail audit)
Writes the audit information to the store.
|
long |
AuditWriterApi.audit(List<AuditDetail> audit)
Writes a batch of audit information to the store.
|
void |
AuditWriterApi.clientHeartbeat(UUID clientId)
Updates the audit information to show that the client is still active so that the client will continue to be returned by
AuditReaderApi.getActiveClients() . |
void |
AuditWriterApi.clientName(UUID clientId,
String name)
Sets a name to be associated with the client.
|
Iterable<UUID> |
AuditReaderApi.getActiveClients()
Returns the clientIds for all active clients.
|
CloseableIterable<AuditDetail> |
AuditReaderApi.getAll(UUID clientId,
long startSeq,
long count) |
Iterable<AuditDetail> |
AuditReaderApi.getAuditDetails(String docId,
Date start,
Date end)
Returns an
Iterable of AuditDetail s associated with the document. |
Iterable<AuditDetail> |
AuditReaderApi.getAuditDetails(String docId,
UUID clientId)
Returns an
Iterable of AuditDetail s associated with the document. |
Iterable<AuditDetail> |
AuditReaderApi.getByCorrelationId(UUID clientId,
UUID correlationId)
Get all audit details for a document via its
correlationId . |
Iterable<String> |
AuditReaderApi.getCreatedDocuments(Date start,
Date end)
Returns a list of IDs for all documents which were received by the system or created within the system during the specified
date range.
|
Iterable<String> |
AuditReaderApi.getCreatedDocuments(UUID clientId)
Returns a list of IDs for all documents which were received by the system or created within the system by the specified
clientId.
|
Iterable<String> |
AuditReaderApi.getDocuments(EnumSet<ProcessingResultCode> codeSet,
Date start,
Date end)
Returns a list of IDs for all documents for which a
resultCode in codeSet was received at some point during
content processing. |
Iterable<String> |
AuditReaderApi.getDocuments(EnumSet<ProcessingResultCode> codeSet,
UUID clientId)
Returns a list of IDs for all documents for which a
resultCode in codeSet was received at some point during
content processing. |
Iterable<UUID> |
AuditReaderApi.getInactiveClients()
Returns the clientIds for all inactive clients.
|
Iterable<AuditDetail> |
AuditReaderApi.getLostDetails(long startSeq,
long endSeq)
Returns all audit detail events that have been flagged as LOST and have a sequence id >=
startSeq and <
endSeq . |
Iterable<String> |
AuditReaderApi.getProcessedDocuments(Date start,
Date end)
Returns a list of IDs for all documents which have completed processing during the specified date range.
|
Iterable<String> |
AuditReaderApi.getProcessedDocuments(UUID clientId)
Returns a list of IDs for all documents which have completed processing which were sent by the specified client.
|
Iterable<String> |
AuditReaderApi.getSearchableDocuments(String indexName,
Date start,
Date end)
Returns an
Iterable of IDs for all documents which became searchable during the specified date range. |
Iterable<String> |
AuditReaderApi.getSearchableDocuments(String indexName,
UUID clientId)
Returns an
Iterable of IDs for all documents that are searchable and were fed by the specified client. |
AuditClientSummary |
AuditReaderApi.getSummary(UUID clientId) |
void |
AuditWriterApi.makeInactive(UUID clientId)
Marks the clientId as inactive.
|
void |
AuditWriterApi.purge(Date start,
Date end)
Purges all audit data within the time range.
|
void |
AuditWriterApi.purge(UUID clientId)
Purges all audit data associated with the client ID.
|
int |
AuditWriterApi.purgeInactiveClients(long lastInactiveTimeToKeep)
Purges the audit data for all clients that are inactive and went inactive before
lastInactiveTimeToKeep |
AuditClientSummary |
AuditReaderApi.waitForCompletion(UUID clientId)
Waits until all documents and messages created by this client have completed processing.
|
AuditClientSummary |
AuditReaderApi.waitForCompletion(UUID clientId,
long timeout)
Waits until all documents and messages created by this client have completed processing.
|
Date |
AuditReaderApi.whenSearchable(String indexName,
UUID clientId)
Returns the earliest date an index commit was received after all documents for the client were indexed.
|
Date |
AuditReaderApi.whenSearchable(String indexName,
UUID clientId,
String docId)
Returns the earliest date an index commit was received after the document was indexed.
|
Modifier and Type | Method and Description |
---|---|
QueryResponse |
StreamingQueryResponse.getQueryResponse()
Get the QueryResponse for the query.
|
Modifier and Type | Method and Description |
---|---|
void |
TriggerApi.compileDictionary(String dictionaryName)
Compile the trigger dictionary identified by
dictionaryName into binary format. |
void |
TriggerApi.copyDictionary(String dictionaryName,
String newName)
Copy the trigger dictionary identified by
dictionaryName to a new dictionary with newName . |
void |
TriggerApi.createDictionary(TriggerDictionaryInfo info)
Create a new
trigger dictionary. |
void |
TriggerApi.createTrigger(String dictionaryName,
TriggerDefinition trigger)
Add
trigger to the dictionary identified by dictionaryName . |
void |
TriggerApi.deleteDictionary(String dictionaryName)
Delete a
trigger dictionary identified by dictionaryName . |
void |
TriggerApi.deleteTrigger(String dictionaryName,
String triggerName)
Delete trigger named
triggerName for the dictionary identified by dictionaryName . |
void |
TriggerApi.exportDictionary(String dictionaryName,
OutputStream output)
Export trigger dictionary by
name to output . |
Iterable<TriggerDictionaryInfo> |
TriggerApi.getDictionaries(String prefix,
int offset,
int rows)
Get all dictionaries.
|
TriggerDictionaryInfo |
TriggerApi.getDictionary(String dictionaryName)
Get a
TriggerDictionaryInfo by dictionaryName . |
Map<Locale,Long> |
TriggerApi.getLocales(String dictionaryName,
String prefix)
Get a map of locales for dictionary specified by
dictionaryName . |
TriggerDefinition |
TriggerApi.getTrigger(String dictionaryName,
String triggerName)
|
Iterable<TriggerDefinition> |
TriggerApi.getTriggers(String dictionaryName,
Locale locale,
String prefix,
int offset,
int rows)
Get triggers for dictionary identified by
dictionaryName . |
void |
TriggerApi.importDictionary(byte[] input,
String newName,
boolean replace)
Deprecated.
|
void |
TriggerApi.importDictionary(InputStream input,
String newName,
boolean replace)
Import a trigger dictionary from
input . |
IngestDocument |
TriggerApi.process(String dictionaryName,
IngestDocument document,
boolean published)
Process
document according to dictionaryName . |
void |
TriggerApi.publishDictionary(String dictionaryName)
Publish the most recently compiled binary dictionary identified by
dictionaryName . |
void |
TriggerApi.updateDictionary(TriggerDictionaryInfo info)
Update the metadata for a
trigger dictionary. |
void |
TriggerApi.updateTrigger(String dictionaryName,
TriggerDefinition trigger)
Update
trigger for the dictionary identified by dictionaryName . |
Modifier and Type | Method and Description |
---|---|
int |
AttivioRunnable.run()
Perform logic and return one of
AttivioRunnable.RETURN_CODE_OK , AttivioRunnable.RETURN_CODE_ERROR . |
Modifier and Type | Method and Description |
---|---|
void |
ProcessingResult.fail(PlatformMessage pm,
AttivioException ex) |
Modifier and Type | Method and Description |
---|---|
InputStream |
ByteArrayContentPointer.getStream()
Get as an InputStream for reading.
|
InputStream |
ContentPointer.getStream()
Get as an InputStream for reading.
|
Modifier and Type | Method and Description |
---|---|
static QueryRequest |
QueryRequest.create(CgiRequest cgi)
Converts CGI HTTP POST/GET request to a
QueryRequest . |
void |
QueryRequest.setProperties(Map<String,String[]> parameters) |
Modifier and Type | Method and Description |
---|---|
void |
SecurityFeeder.deletePrincipal(AttivioPrincipalKey key)
Deletes a principal from the index.
|
void |
SecurityFeeder.feed(AttivioPrincipal principal)
Ingests an AttivioPrincipal.
|
void |
SecurityFeeder.feed(IngestDocument doc,
AttivioAcl acl)
Sends
doc to the document receiver with the given ACL. |
Modifier and Type | Method and Description |
---|---|
PlatformMessage |
CgiRequestProcessor.handleCgiRequest(CgiRequest cgi)
Called by the Attivio Engine to convert a
CgiRequest into a PlatformMessage to be handled by the Attivio Engine. |
void |
IndexMessageHandler.handleIndexMessage(IndexMessage message)
Called by the Attivio Engine to allow implementing components to handle
IndexMessage s. |
PlatformMessage |
MessageHandlingWorkflowStage.processMessage(PlatformMessage msg)
Called whenever a message is received for the component.
|
Modifier and Type | Method and Description |
---|---|
IngestFieldValue |
FieldValueCreatingTransformer.createMappedValue(String inputFieldName,
IngestFieldValue inputFieldValue)
Process a single
IngestFieldValue and return a new value to be placed into the document for this input->output
mapping. |
boolean |
FieldValueModifyingTransformer.modifyFieldValue(String fieldName,
IngestFieldValue fv)
Process a single field value and modify it in place.
|
void |
MultiOutputDocumentTransformer.process(IngestDocument doc,
DocumentOutputClient out)
Generates documents and messages from a single input document.
|
boolean |
DocumentModifyingTransformer.processDocument(IngestDocument doc)
Processes a single
IngestDocument . |
Modifier and Type | Method and Description |
---|---|
void |
AfterAllLocalInstancesStarted.afterAllLocalInstancesStarted()
Called after all instances of this component in the system have been started
|
void |
AfterLocalNodeStartup.afterLocalNodeStartup()
Called after the local AIE node has been started.
|
void |
Startable.startComponent()
Called on startup of the system before any components receive messages.
|
void |
Stoppable.stopComponent()
Called indicate message processing is being stopped for the component.
|
Modifier and Type | Method and Description |
---|---|
List<QueryFeedback> |
QueryTransformer.processQuery(QueryRequest query)
Processes a query by modifying it in-place.
|
void |
ResponseTransformer.processResponseDocuments(QueryResponse info,
SearchDocumentList documents)
Process the documents for a response.
|
void |
ResponseTransformer.processResponseInfo(QueryResponse info)
Process a
QueryResponse which contains information about the query request and the metadata about how long it took to
compute the results. |
Modifier and Type | Method and Description |
---|---|
IngestDocument |
ReducingTransformer.reduce(String keyValue,
Iterator<IngestDocument> documents)
Reduces a set of IngestDocument(s) based on key
|
Modifier and Type | Method and Description |
---|---|
void |
DiagnosticExportProvider.export(ZipOutputStream out) |
Modifier and Type | Method and Description |
---|---|
boolean |
GlobalSet.add(String val)
Deprecated.
Adds a
String value to this GlobalSet |
void |
GlobalMembership.add(String name)
Deprecated.
Add a member to this membership.
|
Closeable |
GlobalDataStructureFactory.addGlobalMapListener(String name,
GlobalMapListener listener)
Deprecated.
|
boolean |
GlobalVariable.compareAndSet(String expectedValue,
String newValue)
Deprecated.
Same semantics as
AtomicReference.compareAndSet(Object, Object) . |
boolean |
GlobalSet.contains(String val)
Deprecated.
Whether or not this
GlobalSet contains a given String |
GlobalLock |
GlobalDataStructureFactory.createGlobalLock(String name,
BreakableLockListener lockListener)
Deprecated.
Creates a global
Lock with the given name if it does not yet exist. |
GlobalMap |
GlobalDataStructureFactory.createGlobalMap(String name)
Deprecated.
Creates a persistent
global map with the given name if it does not yet exist. |
GlobalMembership |
GlobalDataStructureFactory.createGlobalMembership(String name)
Deprecated.
Creates a
global membership with the given name if it does not yet exist. |
GlobalSet |
GlobalDataStructureFactory.createGlobalSet(String name,
MembershipListener listener)
Deprecated.
Creates a
global set with the given name if it does not yet exist. |
GlobalVariable |
GlobalDataStructureFactory.createGlobalVariable(String name)
Deprecated.
Creates a
global variable with the given name if it does not yet exist. |
String |
GlobalVariable.getCurrentValue()
Deprecated.
Returns the current value of the variable or null if not set.
|
void |
GlobalMembership.listen(MembershipListener listener)
Deprecated.
Listen for changes to this membership via a user provided
MembershipListener |
void |
GlobalVariable.listen(VariableListener listener)
Deprecated.
Registers a
VariableListener that will be called when the value of this GlobalVariable is changed. |
List<String> |
GlobalMembership.listMembers()
Deprecated.
List all active members of this membership.
|
void |
VersionedMasterElection.newLocalVersion()
Deprecated.
Notification indicating that local version has been updated.
|
void |
GlobalMap.put(String key,
String value)
Deprecated.
Update a
key to value . |
void |
VersionedMasterElection.registerListener(VariableListener listener)
Deprecated.
Register a listener to receive notifications about changes to master version.
|
void |
VersionedMasterElection.registerMaster(MasterCandidate engine)
Deprecated.
Checks the global variable value against the local value and acquires the lock if the values match.
|
boolean |
GlobalSet.remove(String val)
Deprecated.
Removes a
String value from this GlobalSet |
void |
GlobalMembership.remove(String name)
Deprecated.
Remove a member from this membership.
|
void |
VersionedMasterElection.rollback(String version)
Deprecated.
Rollback the global version to
version |
void |
GlobalVariable.set(String value)
Deprecated.
Add or updates the value to the new value specified.
|
void |
VersionedMasterElection.setGlobalVersion(String version)
Deprecated.
Updates the global value for the election to be based on.
|
Modifier and Type | Method and Description |
---|---|
Tokenizer |
Tokenizer.getIngestTokenizer(SchemaField field,
Locale locale)
Get the underlying tokenizer to use for tokenizing fields in the ingest workflow.
|
Tokenizer |
Tokenizer.getQueryTokenizer(SchemaField field,
Locale locale)
Get the underlaying tokenizer to use for tokenizing fields in the query workflow.
|
Phrase |
Tokenizer.tokenize(SchemaField field,
Locale locale,
SearchTerm term)
Tokenizes
term into a Phrase for query processing. |
TokenList |
Tokenizer.tokenize(SchemaField field,
Locale locale,
String value)
Tokenizes
value into a TokenList. |
Phrase |
Tokenizer.tokenize(SchemaField field,
Locale locale,
TermRange range)
Tokenizes
range into a Phrase for query processing. |
void |
Tokenizer.tokenize(SchemaField field,
Locale locale,
TokenList tokens)
Tokenizes all tokens in
tokens . |
Phrase |
Tokenizer.tokenize(SchemaField field,
Locale locale,
WildcardTerm term)
Tokenizes a wildcard
term into a Phrase for query processing. |
Modifier and Type | Method and Description |
---|---|
void |
MockContentStoreProvider.add(String namespace,
String id,
InputStream in)
Content will be copied from the InputStream and stored within the
namespace under the id . |
long |
MockIngestAuditApi.audit(AuditDetail detail) |
long |
MockIngestAuditApi.audit(List<AuditDetail> details) |
void |
MockIngestAuditApi.clientHeartbeat(UUID clientId)
Updates the audit information to show that the client is still active so that the client will continue to be returned by
AuditReaderApi.getActiveClients() . |
void |
MockIngestAuditApi.clientName(UUID clientId,
String name)
Sets a name to be associated with the client.
|
boolean |
MockContentStoreProvider.contains(String namespace,
String id) |
void |
MockContentStoreClient.delete(String id)
Delete a record by id from the content store.
|
void |
MockContentStoreProvider.delete(String namespace,
String id)
Deletes
id from the namespace . |
void |
MockDocumentStore.delete(String collection,
String docId)
Deletes the document from the specified collection
|
void |
MockContentStoreClient.deleteAll()
Delete all content in the content store.
|
void |
MockContentStoreProvider.deleteAll(String namespace)
Deletes all content from the store within the namespace
|
String |
MockContentStoreProvider.externalize(String storeName,
String id)
Returns an externally accessible URI for the content suitable for HTTP GET.
|
void |
MockIngestApi.feed(PlatformMessage msg) |
Iterable<IngestDocument> |
MockDocumentStore.filteredRetrieve(String collection,
Map<String,String> filterVals)
Finds and returns the documents matching the provided equality filters.
|
InputStream |
MockContentStoreProvider.get(String namespace,
String id)
Returns an InputStream to access the content.
|
Iterable<UUID> |
MockIngestAuditApi.getActiveClients()
Returns the clientIds for all active clients.
|
CloseableIterable<AuditDetail> |
MockIngestAuditApi.getAll(UUID clientId,
long startSeq,
long count) |
Iterable<AuditDetail> |
MockIngestAuditApi.getAuditDetails(String docId,
Date start,
Date end)
Returns an
Iterable of AuditDetail s associated with the document. |
Iterable<AuditDetail> |
MockIngestAuditApi.getAuditDetails(String docId,
UUID clientId)
Returns an
Iterable of AuditDetail s associated with the document. |
Iterable<AuditDetail> |
MockIngestAuditApi.getByCorrelationId(UUID clientId,
UUID correlationId)
Get all audit details for a document via its
correlationId . |
Iterable<String> |
MockIngestAuditApi.getCreatedDocuments(Date start,
Date end)
Returns a list of IDs for all documents which were received by the system or created within the system during the specified
date range.
|
Iterable<String> |
MockIngestAuditApi.getCreatedDocuments(UUID clientId)
Returns a list of IDs for all documents which were received by the system or created within the system by the specified
clientId.
|
long |
MockContentStoreProvider.getDiskUtilization() |
Iterable<String> |
MockIngestAuditApi.getDocuments(EnumSet<ProcessingResultCode> codeSet,
Date start,
Date end)
Returns a list of IDs for all documents for which a
resultCode in codeSet was received at some point during
content processing. |
Iterable<String> |
MockIngestAuditApi.getDocuments(EnumSet<ProcessingResultCode> codeSet,
UUID clientId)
Returns a list of IDs for all documents for which a
resultCode in codeSet was received at some point during
content processing. |
Iterable<UUID> |
MockIngestAuditApi.getInactiveClients()
Returns the clientIds for all inactive clients.
|
long |
MockIngestAuditApi.getLastLossDetectionSequence(UUID clientId) |
long |
MockContentStoreProvider.getLastModified(String namespace,
String id) |
Iterable<AuditDetail> |
MockIngestAuditApi.getLostDetails(long startSeq,
long endSeq) |
List<String> |
MockContentStoreProvider.getNamespaces() |
Iterable<String> |
MockIngestAuditApi.getProcessedDocuments(Date start,
Date end)
Returns a list of IDs for all documents which have completed processing during the specified date range.
|
Iterable<String> |
MockIngestAuditApi.getProcessedDocuments(UUID clientId)
Returns a list of IDs for all documents which have completed processing which were sent by the specified client.
|
Iterable<String> |
MockIngestAuditApi.getSearchableDocuments(String indexName,
Date start,
Date end)
Returns an
Iterable of IDs for all documents which became searchable during the specified date range. |
Iterable<String> |
MockIngestAuditApi.getSearchableDocuments(String indexName,
UUID clientId)
Returns an
Iterable of IDs for all documents that are searchable and were fed by the specified client. |
<T> T |
MockServiceFactory.getService(Class<T> clazz) |
<T> T |
ServiceFactory.getService(Class<T> clazz)
|
<T> T |
MockServiceFactory.getService(Class<T> clazz,
long timeout) |
<T> T |
ServiceFactory.getService(Class<T> clazz,
long timeout)
|
<T> T |
MockServiceFactory.getService(Class<T> clazz,
Map<String,String> attributes,
long timeout)
Returns an implementation of the desired service API.
|
<T> T |
ServiceFactory.getService(Class<T> clazz,
Map<String,String> attributes,
long timeout)
Returns an implementation of the desired service API.
|
<T> T |
MockServiceFactory.getService(Class<T> clazz,
String nodeName) |
<T> T |
ServiceFactory.getService(Class<T> clazz,
String nodeName)
|
<T> T |
MockServiceFactory.getService(Class<T> clazz,
String nodeName,
long timeout) |
<T> T |
ServiceFactory.getService(Class<T> clazz,
String nodeName,
long timeout)
Deprecated.
|
long |
MockContentStoreProvider.getSize(String namespace,
String id) |
AuditClientSummary |
MockIngestAuditApi.getSummary(UUID clientId) |
long |
MockContentStoreProvider.getTotalRecords(String namespace) |
void |
MockIngestAuditApi.makeInactive(UUID clientId)
Marks the clientId as inactive.
|
void |
MockIngestAuditApi.purge(Date start,
Date end) |
void |
MockIngestAuditApi.purge(UUID clientId) |
int |
MockIngestAuditApi.purgeInactiveClients(long lastInactiveTimeToKeep)
Purges the audit data for all clients that are inactive and went inactive before
lastInactiveTimeToKeep |
ContentPointer |
MockContentStoreClient.retrieve(String id)
Retrieve a ContentPointer in the ContentStore.
|
IngestDocument |
MockDocumentStore.retrieve(String collection,
String docId) |
void |
MockIngestAuditApi.setLastLossDetectionSequence(UUID clientId,
long seq) |
void |
MockDocumentStore.store(String namespace,
IngestDocument doc,
List<String> filterFields,
boolean storeContentPointers)
Stores the document in
namespace , creating indexes which allow equality filtering on the list of fields provided. |
ContentPointer |
MockContentStoreClient.store(String id,
InputStreamBuilder input)
Store a ContentPointer in the ContentStore.
|
IngestDocument |
MockDocumentStore.storeAndUpdate(String namespace,
IngestDocument doc,
List<String> filterFields,
boolean storeContentPointers)
Stores the document in
namespace , creating indexes which allow equality filtering on the list of fields provided. |
void |
MockIngestAuditApi.truncateAll() |
void |
MockIngestAuditApi.updateSummary(AuditClientSummary summary) |
AuditClientSummary |
MockIngestAuditApi.waitForCompletion(UUID clientId)
Waits until all documents and messages created by this client have completed processing.
|
AuditClientSummary |
MockIngestAuditApi.waitForCompletion(UUID clientId,
long timeout)
Waits until all documents and messages created by this client have completed processing.
|
Date |
MockIngestAuditApi.whenSearchable(String indexName,
UUID clientId)
Returns the earliest date an index commit was received after all documents for the client were indexed.
|
Date |
MockIngestAuditApi.whenSearchable(String indexName,
UUID clientId,
String docId)
Returns the earliest date an index commit was received after the document was indexed.
|
Constructor and Description |
---|
MockIngestApi() |
Modifier and Type | Method and Description |
---|---|
void |
MockIngestClient.delete(Collection<String> ids) |
void |
MockIngestClient.delete(String... ids) |
void |
MockIngestClient.deleteByQuery(String queryWorkflows,
Query query) |
void |
MockIngestClient.deletePrincipal(AttivioPrincipalKey key) |
void |
MockIngestClient.endMessageGroup() |
void |
MockIngestClient.feed(AttivioPrincipal principal) |
void |
MockIngestClient.feed(IngestDocument... docs) |
void |
MockIngestClient.feed(IngestDocument doc,
AttivioAcl acl) |
void |
MockIngestClient.feed(Iterable<IngestDocument> docs) |
void |
MockIngestClient.startMessageGroup() |
Modifier and Type | Method and Description |
---|---|
void |
MockUnclusteredEventStore.acknowledgeEvent(long eventId,
String user,
String reason) |
long |
MockUnclusteredEventStore.addEvent(SystemEvent event) |
void |
MockUnclusteredIngestionHistory.childCreated(String namespace,
String key,
String childKey) |
void |
MockUnclusteredIngestionHistory.clear(String namespace) |
long |
MockUnclusteredEventStore.countEvents() |
protected List<String> |
MockUnclusteredIngestionHistory.getAllChildData(String namespace) |
protected List<String> |
MockUnclusteredIngestionHistory.getAllDocumentData(String namespace) |
Iterable<String> |
MockUnclusteredIngestionHistory.getChildren(String namespace,
String key) |
EventQuery |
MockUnclusteredEventStore.getEvents(EventQuery query) |
Date |
MockUnclusteredIngestionHistory.getPreviousStartTime(String namespace) |
byte[] |
MockUnclusteredIngestionHistory.getSignature(String namespace,
String key) |
Date |
MockUnclusteredIngestionHistory.getStartTime(String namespace) |
Iterable<String> |
MockUnclusteredIngestionHistory.getUnvisited(String namespace) |
Iterable<String> |
MockUnclusteredIngestionHistory.getUnvisited(String namespace,
Date since) |
void |
MockUnclusteredIngestionHistory.removeDocumentByKey(String namespace,
String key) |
Date |
MockUnclusteredIngestionHistory.startSession(String namespace) |
protected void |
MockUnclusteredIngestionHistory.updateDocumentWithDate(String namespace,
String key,
byte[] signature,
Date useDate) |
protected void |
MockUnclusteredIngestionHistory.updateDocumentWithDate(String namespace,
String key,
Date useDate) |
void |
MockUnclusteredIngestionHistory.visit(String namespace,
String key,
byte[] signature) |
Modifier and Type | Method and Description |
---|---|
void |
StatusListener.warn(AttivioException ae)
Log an AttivioException at a warning level.
|
Modifier and Type | Method and Description |
---|---|
IngestFieldValue |
SampleFieldValueCreatingTransformer.createMappedValue(String inputFieldName,
IngestFieldValue fv) |
boolean |
SampleDocumentModifyingTransformer.processDocument(IngestDocument doc) |
List<QueryFeedback> |
SampleQueryRewriteTransformer.processQuery(QueryRequest queryRequest) |
List<QueryFeedback> |
SampleQueryTransformer.processQuery(QueryRequest query) |
void |
SampleResponseTransformer.processResponseDocuments(QueryResponse info,
SearchDocumentList documents) |
void |
SampleResponseTransformer.processResponseInfo(QueryResponse info) |
int |
SampleAttivioRunnable.run() |
Copyright © 2018 Attivio, Inc. All Rights Reserved.
PATENT NOTICE: Attivio, Inc. Software Related Patents. With respect to the Attivio software product(s) being used, the following patents apply: Querying Joined Data Within A Search Engine Index: United States Patent No.(s): 8,073,840. Ordered Processing of Groups of Messages: U.S. Patent No.(s) 8,495,656. Signal processing approach to sentiment analysis for entities in documents: U.S. Patent No.(s) 8,725,494. Other U.S. and International Patents Pending.