Uses of Class
com.attivio.sdk.AttivioException
-
Packages that use AttivioException Package Description com.attivio.client Contains the Client Attivio API for adding content, submitting queries, and sending general purpose messages to an Attivio server.com.attivio.client.exposedapi com.attivio.client.streaming Contains client code for streaming search results.com.attivio.connector com.attivio.platform.service com.attivio.platform.store com.attivio.platform.store.audit com.attivio.platform.transformer.ingest.util com.attivio.platform.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 2019 Attivio Inc., All rights reserved.com.attivio.sdk.commandline com.attivio.sdk.connector com.attivio.sdk.esb com.attivio.sdk.ingest com.attivio.sdk.scanner com.attivio.sdk.scanner.concurrency com.attivio.sdk.schema Models data from fields and describes how each field should be handled by the Attivio engine.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 intoTokenList
s.com.attivio.sdk.service com.attivio.sdk.test com.attivio.sdk.transport com.attivio.service com.attivio.transport com.attivio.util Contains utility classes and methods used across the Attivio code base.com.attivio.util.serialization Contains classes related to serialization/desearialization of objects to/from XML. -
-
Uses of AttivioException in com.attivio.client
Methods in com.attivio.client with parameters of type AttivioException Modifier and Type Method Description void
IngestMessageListener. handleSendFailure(PlatformMessage message, AttivioException ae)
protected PlatformMessage
AbstractReceiverClient. handleServerReset(PlatformMessage msg, AttivioException ae)
Called when the client has detected a server reset.Methods in com.attivio.client that throw AttivioException Modifier and Type Method Description protected void
ContentFeeder. batchDocument(IngestDocument doc)
Adddoc
to the current batch, flushing batch if any limit exceeded.void
ContentFeeder. bulkUpdate(BulkUpdate message)
Sendmessage
to AIE.void
ContentFeeder. clientHeartbeat()
Send a client heartbeat to keep the client alive (only if active).void
ContentFeeder. commit(java.lang.String... zones)
Sends internal queue of documents and commits all documents sent to AIE.boolean
LazyContentStoreClient. contains(java.lang.String id)
True if the content store has a stream for this id.void
ContentFeeder. delete(java.lang.String... ids)
Delete a series of documents from AIE by document id.void
ContentFeeder. delete(java.util.Collection<java.lang.String> ids)
SeeDocumentOutputClient.delete(String...)
for documentation.void
LazyContentStoreClient. delete(java.lang.String id)
Delete a record by id from the content store.void
LazyContentStoreClient. deleteAll()
Delete all content in the content store.void
ContentFeeder. deleteByQuery(java.lang.String workflow, Query query)
Delete all documents that match theQuery
.void
ContentFeeder. deleteByQuery(java.lang.String workflow, java.lang.String queryString, java.lang.String queryLanguage)
void
ContentFeeder. deletePrincipal(AttivioPrincipalKey key)
Deletes a principal from the index.void
MessageForwardingClient. disconnect()
Deprecated.no longer necessaryvoid
AbstractReceiverClient.ClientMessageSender. dispatch(PlatformMessage msg, java.lang.String uri)
protected void
ContentFeeder. dispatchDocumentsInQueue()
Perform an internal batching of docs and feeds any queued documentsvoid
ContentFeeder. endMessageGroup()
Ends the current message group (if any).void
ContentFeeder. feed(IngestDocument... docs)
Senddocs
to AIE.void
ContentFeeder. feed(IngestDocument doc, AttivioAcl acl)
Sendsdoc
to the document receiver with the given ACL.void
ContentFeeder. feed(AttivioPrincipal principal)
Ingests an AttivioPrincipal.void
ContentFeeder. feed(java.lang.Iterable<IngestDocument> docs)
Senddocs
to AIE.protected AuditReaderApi
ContentFeeder. getAuditReader()
protected ContentStoreProvider
ContentFeeder. getContentStore()
Schema
AbstractSearchClient. getDefaultSchema()
SearchDocument
AbstractSearchClient. getDocumentById(java.lang.String documentId)
Gets a document by a specific document IdSchema
AbstractSearchClient. getSchema(java.lang.String schemaName)
long
LazyContentStoreClient. getTotalRecords()
Get the total number of records in the content store.void
IngestMessageListener. handleSend(PlatformMessage message)
protected PlatformMessage
AbstractReceiverClient. handleServerReset(PlatformMessage msg, AttivioException ae)
Called when the client has detected a server reset.boolean
ContentFeeder. isCompleted()
True is all messages sent have been fully processed by AIE.protected void
ContentFeeder. makeInactive()
void
ContentFeeder. optimize()
Sends internal queue of documents and optimizes the AIE index and associated data structures.ContentPointer
ContentFeeder. put(java.lang.String id, byte[] bytes)
Put the contents of a byte array into the content store.ContentPointer
ContentFeeder. put(java.lang.String id, InputStreamBuilder builder)
Stores binary data in the ContentStore.ContentPointer
ContentFeeder. put(java.lang.String id, java.io.File f)
Put the contents of a File into the content store.ContentPointer
ContentFeeder. put(java.lang.String id, java.io.InputStream input)
Put a resource into the Content Store.void
ContentFeeder. refresh()
Sends internal queue of documents and commits all partial update documents sent to AIE.ContentPointer
LazyContentStoreClient. retrieve(java.lang.String id)
Retrieve a ContentPointer in the ContentStore.QueryResponse
AbstractSearchClient. search(QueryRequest query)
Sends the query to the Attivio search and returns the result.StreamingQueryResponse
AbstractSearchClient. search(StreamingQueryRequest req)
Sends the streaming query request to the Attivio search and returns the result.QueryResponse
AbstractSearchClient. search(java.lang.String query)
Searches using a query string only.PlatformMessage
AbstractReceiverClient.ClientMessageSender. send(PlatformMessage msg, java.lang.String uri, boolean allowNullResponse)
protected void
AbstractReceiverClient. sendAsyncMessage(PlatformMessage msg)
Sends an asynchronous message to Attivio via the configured nodeAbstractReceiverClient.getReceiverUri()
.void
MessageForwardingClient. sendAsyncMessage(java.lang.String componentName, PlatformMessage msg)
Sends a message to a component name asynchronously.void
ContentFeeder. sendIndexMessage(IndexMessage msg)
protected PlatformMessage
AbstractReceiverClient. sendMessage(PlatformMessage msg)
Sends a synchronous message to Attivio via the configured nodeAbstractReceiverClient.getReceiverUri()
.protected PlatformMessage
AbstractReceiverClient. sendMessage(PlatformMessage msg, boolean allowNullResponse)
Sends a synchronous message to Attivio via the configured nodeAbstractReceiverClient.getReceiverUri()
.PlatformMessage
MessageForwardingClient. sendMessage(java.lang.String componentName, PlatformMessage msg)
Sends a message to a component name synchronously.protected void
ContentFeeder. sendMessageInternal(PlatformMessage message)
Internal method to send amessage
to theIngestApi
.void
ContentFeeder. sendQueuedDocuments()
Send the documents in the queue to the enginevoid
HasSecurityCredentials. setConnectionCredentials(java.lang.String username, java.lang.String password)
void
ContentFeeder. startMessageGroup()
Starts a group of messages that will be processed together.ContentPointer
LazyContentStoreClient. store(java.lang.String id, InputStreamBuilder input)
Store a ContentPointer in the ContentStore.boolean
ContentFeeder. waitForCompletion()
Wait for all documents and messages to be fully processed.boolean
ContentFeeder. waitForCompletion(boolean changeClientId)
Wait the specified number of milliseconds for all MessageResults to be processed.boolean
ContentFeeder. waitForCompletion(long timeout)
Wait the specified number of milliseconds for all MessageResults to be processed.boolean
ContentFeeder. waitForCompletion(long timeout, boolean changeClientId)
Wait the specified number of milliseconds for all MessageResults to be processed.Constructors in com.attivio.client that throw AttivioException Constructor Description MessageForwardingClient(java.lang.String receiverUri)
Creates an AttivioMessageClient client which communicates with a message receiver at the specified URI. -
Uses of AttivioException in com.attivio.client.exposedapi
Methods in com.attivio.client.exposedapi that throw AttivioException Modifier and Type Method Description static org.apache.curator.x.discovery.ServiceInstance<AieServiceInfo>
JMXUtils. expose(javax.management.ObjectName oname, java.lang.Class<?> apiClass, java.lang.Object api, java.lang.String user, java.lang.String password, int rmiPort)
Exposes the object via JMX and registers it as a service via theServiceFactory
. -
Uses of AttivioException in com.attivio.client.streaming
Methods in com.attivio.client.streaming that throw AttivioException Modifier and Type Method Description static StreamedResponseClient
StreamedResponseClient. connect(StreamRequestInfo request, StreamResponse response)
static StreamedResponseClient
StreamedResponseClient. createStreamedResponseClient(java.lang.String clientWorkflow, java.lang.String queryEndpoint, QueryRequest request, StreamRequestInfo streamConfig)
Create a new streamed response client.java.lang.String
StreamingRecordIteratorAbstract. getFieldname()
Get the field name of the field moved to by the last nextField call.QueryResponse
StreamedResponseClient. getQueryResponse()
Get the QueryResponse for the query.protected abstract void
StreamingRecordIteratorAbstract. implFirstValue()
Fetch the first valueprotected boolean
StreamingRecordIteratorAbstract. implSimpleNextFieldOfRecord()
Get the next field of the record.void
StreamedResponseClient. initStream()
java.lang.Object
StreamingRecordIteratorAbstract. nextValue()
Get the next value of the current field. -
Uses of AttivioException in com.attivio.connector
Methods in com.attivio.connector that throw AttivioException Modifier and Type Method Description void
ConcurrentScannerMessagePublisher. bulkUpdate(BulkUpdate bulkUpdateMessage)
DataSourceAPIErrorDescriptors
DataSourceAPIErrorDescriptorsCreator. createErrorDescriptors(DataSourceAPIErrorDescriptorsAware scanner)
void
ConcurrentScannerMessagePublisher. delete(java.lang.String... docIds)
void
ConcurrentScannerMessagePublisher. delete(java.lang.String queryWorkflow, Query query)
void
ConcurrentScannerMessagePublisher. deletePrincipal(AttivioPrincipalKey key)
void
ConcurrentScannerMessagePublisher. feed(IngestDocument... doc)
void
ConcurrentScannerMessagePublisher. feed(IngestDocument doc, AttivioAcl acl)
void
ConcurrentScannerMessagePublisher. feed(AttivioPrincipal principal)
void
ConcurrentDocumentFetcherImpl. put(IngestDocument doc, java.lang.String fieldName, java.lang.String id, java.io.InputStream is)
void
ConcurrentScannerMessagePublisher. put(IngestDocument doc, java.lang.String fieldName, java.lang.String id, java.io.InputStream is)
boolean
ConcurrentScannerMessagePublisher. waitForCompletion(long time)
-
Uses of AttivioException in com.attivio.platform.service
Methods in com.attivio.platform.service that throw AttivioException Modifier and Type Method Description void
LocalSearchClientImpl. setConnectionCredentials(java.lang.String username, java.lang.String password)
void
RemoteSearchClient. setConnectionCredentials(java.lang.String username, java.lang.String password)
-
Uses of AttivioException in com.attivio.platform.store
Methods in com.attivio.platform.store that throw AttivioException Modifier and Type Method Description void
MockConnectorHistory. clearHistory(java.lang.String connectorName)
Removes all history associated with the connector.void
MockConnectorHistory. connectorCompleted(java.lang.String connectorName, long finalDocCount)
The connector has completed -- all documents have been fully processed.void
MockConnectorHistory. connectorCompleting(java.lang.String connectorName)
The connector is completing -- all documents have been sent but have not finished being processed.void
MockConnectorHistory. connectorPaused(java.lang.String connectorName)
A node has paused the connector.void
MockConnectorHistory. connectorQueued(java.lang.String connectorName, java.util.UUID clientId, java.lang.String workflow, java.util.List<java.lang.String> extraRunInfo, boolean external)
The connector has been submitted for execution on an AIE node.void
MockConnectorHistory. connectorReset(java.lang.String connectorName)
Indicates that the incremental state of the connector has been reset.void
MockConnectorHistory. connectorResumed(java.lang.String connectorName)
A node has resumed a paused connector.void
MockConnectorHistory. connectorStarted(java.lang.String connectorName, long timestamp)
A node has started executing the connector.void
MockConnectorHistory. setClientId(java.lang.String connectorName, java.util.UUID clientId)
Associates the provided client id with the current run of the connector.void
MockConnectorHistory. updateExtraRunInfo(java.lang.String connectorName, java.util.List<java.lang.String> extraRunInfo)
Updates the extraRunInfo forconnectorName
.void
MockConnectorHistory. updateSentCount(java.lang.String connectorName, long docCount)
Updates the number of documents sent byconnectorName
. -
Uses of AttivioException in com.attivio.platform.store.audit
Methods in com.attivio.platform.store.audit that throw AttivioException Modifier and Type Method Description long
AieSystemAuditApi. getLastLossDetectionSequence(java.util.UUID clientId)
void
AieSystemAuditApi. setLastLossDetectionSequence(java.util.UUID clientId, long seq)
Updates the last sequence number considered for loss detection forclientId
.void
AieSystemAuditApi. truncateAll()
Truncates all data tables containing audit information.void
AieSystemAuditApi. updateSummary(AuditClientSummary summary)
Updates the summary record to the provided value. -
Uses of AttivioException in com.attivio.platform.transformer.ingest.util
Methods in com.attivio.platform.transformer.ingest.util that throw AttivioException Modifier and Type Method 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. -
Uses of AttivioException in com.attivio.platform.util
Methods in com.attivio.platform.util that throw AttivioException Modifier and Type Method Description static <T> java.lang.Class<? extends T>
ReflectionUtils. forName(java.lang.String className, java.lang.Class<T> type)
Lookup a class givenclassName
andtype
.static boolean
ReflectionUtils. isSubclass(java.lang.String className, java.lang.Class<?> type)
static <T> T
ReflectionUtils. newInstance(java.lang.Class<? extends T> type)
Intantiate a new instance oftype
.static java.lang.Object
ReflectionUtils. newInstance(java.lang.String className)
Instantiate a class by name. -
Uses of AttivioException in com.attivio.sdk
Subclasses of AttivioException in com.attivio.sdk Modifier and Type Class Description class
TransportException
Exception to indicate an error occurred while moving messages between components.Methods in com.attivio.sdk that return AttivioException Modifier and Type Method Description AttivioException
AttivioIOException. getAttivioException()
Convert this exception into anAttivioException
.AttivioException
AttivioRuntimeException. getAttivioException()
Convert this exception into anAttivioException
.AttivioException
AttivioException. 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
AttivioThrowable. toRemoteException()
Convert this exception to be a remote exception. -
Uses of AttivioException in com.attivio.sdk.api
Methods in com.attivio.sdk.api that throw AttivioException Modifier and Type Method Description void
ContentStoreProvider. add(java.lang.String namespace, java.lang.String id, java.io.InputStream in)
Content will be copied from the InputStream and stored within thenamespace
under theid
.boolean
ContentStoreProvider. contains(java.lang.String namespace, java.lang.String id)
void
ContentStoreProvider. delete(java.lang.String namespace, java.lang.String id)
Deletesid
from thenamespace
.void
ContentStoreProvider. deleteAll(java.lang.String namespace)
Deletes all content from the store within the namespacejava.lang.String
ContentStoreProvider. externalize(java.lang.String storeName, java.lang.String id)
Returns an externally accessible URI for the content suitable for HTTP GET.java.io.InputStream
ContentStoreProvider. get(java.lang.String namespace, java.lang.String id)
Returns an InputStream to access the content.long
ContentStoreProvider. getDiskUtilization()
long
ContentStoreProvider. getLastModified(java.lang.String namespace, java.lang.String id)
java.util.List<java.lang.String>
ContentStoreProvider. getNamespaces()
long
ContentStoreProvider. getSize(java.lang.String namespace, java.lang.String id)
java.io.InputStream
ContentStoreContentPointer. getStream()
Get as an InputStream for reading.long
ContentStoreProvider. getTotalRecords(java.lang.String namespace)
-
Uses of AttivioException in com.attivio.sdk.autocomplete
Methods in com.attivio.sdk.autocomplete that throw AttivioException Modifier and Type Method Description java.util.List<AutoCompleteSuggestion>
AutoCompleteProvider. getSuggestions(QueryRequest req)
Get a list of query auto complete suggestions for the specified term.void
SharedResourceAutoCompleteProvider. resourceModified(java.net.URI uri)
Hook method called when the shared resource is modified -
Uses of AttivioException in com.attivio.sdk.client
Methods in com.attivio.sdk.client that throw AttivioException Modifier and Type Method Description void
EventStoreApi. acknowledgeEvent(long eventId, java.lang.String user, java.lang.String reason)
long
EventStoreApi. addEvent(SystemEvent event)
void
MockSignalTrackingService. addSignal(Signal signal)
void
SignalTrackingApi. addSignal(Signal signal)
Add a signalDictionaryInfo
DictionaryClient. approveDictionary(DictionaryInfo info)
Approve pending changes to dictionary identified byinfo
.void
DocumentOutputClient. bulkUpdate(BulkUpdate message)
Sendmessage
to AIE.void
IngestionHistoryApi. childCreated(java.lang.String namespace, java.lang.String key, java.lang.String childKey)
Marks thechildKey
as one created by the record associated withkey
.void
IngestionHistoryApi. clear(java.lang.String namespace)
Removes all historical information associated with thenamespace
.void
ConnectorHistoryApi. clearHistory(java.lang.String connectorName)
Removes all history associated with the connector.DictionaryInfo
DictionaryClient. cloneDictionary(DictionaryInfo source, DictionaryInfo dest)
Clone dictionarysource
todest
.void
IndexCommitter. commit(java.lang.String... zones)
void
IngestClient. commit(java.lang.String... zones)
Sends internal queue of documents and commits all documents sent to AIE.void
ConnectorHistoryApi. connectorCompleted(java.lang.String connectorName, long finalDocCount)
The connector has completed -- all documents have been fully processed.void
ConnectorHistoryApi. connectorCompleting(java.lang.String connectorName)
The connector is completing -- all documents have been sent but have not finished being processed.void
ConnectorHistoryApi. connectorPaused(java.lang.String connectorName)
A node has paused the connector.void
ConnectorHistoryApi. connectorQueued(java.lang.String connectorName, java.util.UUID clientId, java.lang.String workflow, java.util.List<java.lang.String> extraRunInfo, boolean external)
The connector has been submitted for execution on an AIE node.void
ConnectorHistoryApi. connectorReset(java.lang.String connectorName)
Indicates that the incremental state of the connector has been reset.void
ConnectorHistoryApi. connectorResumed(java.lang.String connectorName)
A node has resumed a paused connector.void
ConnectorHistoryApi. connectorStarted(java.lang.String connectorName, long timestamp)
A node has started executing the connector.boolean
ContentStoreClient. contains(java.lang.String id)
Deprecated.True if the content store has a stream for this id.long
EventStoreApi. countEvents()
DictionaryInfo
DictionaryClient. createDictionary(DictionaryInfo info)
Create dictionaryinfo
.DictionaryInfo
DictionaryClient. createDictionaryEntries(DictionaryInfo info, java.lang.String contentStoreId)
Add all entries fromcontentStorId
in csv format to dictionary identified byinfo
.DictionaryEntry
DictionaryClient. createDictionaryEntry(DictionaryEntry entry)
Create a dictionary entry.java.util.List<IngestDocument>
ConnectorControlApi. debugConnector(java.lang.String connectorName, int numDocs)
A method to help with debugging connectors.void
ContentStoreClient. delete(java.lang.String id)
Deprecated.Delete a record by id from the content store.void
DocumentOutputClient. delete(java.lang.String... ids)
Delete a series of documents from AIE by document id.void
DocumentOutputClient. delete(java.util.Collection<java.lang.String> ids)
SeeDocumentOutputClient.delete(String...)
for documentation.void
DocumentStoreApi. delete(java.lang.String namespace, java.lang.String docId)
Deletes the document from the specified collectionvoid
ContentStoreClient. deleteAll()
Deprecated.Delete all content in the content store.void
DocumentOutputClient. deleteByQuery(java.lang.String queryWorkflow, Query query)
Delete all documents that match theQuery
.DictionaryInfo
DictionaryClient. deleteDictionary(DictionaryInfo info)
Delete dictionaryinfo
.DictionaryEntry
DictionaryClient. deleteDictionaryEntry(DictionaryEntry entry)
Delete a dictionary entry.void
DictionaryClient. deleteDictionaryFromContentStore(java.lang.String contentStoreId)
Deprecated.void
IngestClient. deletePrincipal(AttivioPrincipalKey key)
Delete an AttivioPrincipal from AIE.void
SignalTrackingApi. deleteSignals(java.lang.String signalType)
Delete all signals forsignalType
.void
DocumentOutputClient. endMessageGroup()
Ends the current message group (if any).java.lang.String
DictionaryClient. exportDictionary(DictionaryInfo info)
Export published form of dictionary.long
ExternalizableStore. exportStore(java.io.OutputStream output, java.lang.Long ifModifiedSince)
Export the model for the store to a jar file written tooutput
.void
DocumentOutputClient. feed(IngestDocument... docs)
Senddocs
to AIE.void
DocumentOutputClient. feed(java.lang.Iterable<IngestDocument> docs)
Senddocs
to AIE.void
IngestClient. feed(IngestDocument doc, AttivioAcl acl)
Feeds the document with its ACL to AIE.void
IngestClient. feed(AttivioPrincipal principal)
Feeds an AttivioPrincipal to AIE.java.lang.Iterable<IngestDocument>
DocumentStoreApi. filteredRetrieve(java.lang.String namespace, java.util.Map<java.lang.String,java.lang.String> filters)
Finds and returns the documents matching the provided equality filters.java.lang.Iterable<java.lang.String>
IngestionHistoryApi. getChildren(java.lang.String namespace, java.lang.String key)
Returns an Iterable of the children that were marked as created via theIngestionHistoryApi.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, java.lang.String name, java.lang.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, java.lang.String entryId)
Get a dictionary entry based on its entryId.SearchDocument
SearchClient. getDocumentById(java.lang.String documentId)
Gets a document by a specific document IdSystemEvent
EventStoreApi. getEvent(long eventId)
EventQuery
EventStoreApi. getEvents(EventQuery eventQuery)
Executes the event query.ConnectorExecutionRecord
ConnectorControlApi. getExecutionInfo(java.lang.String connectorName)
Gets execution information for the connector.java.lang.Iterable<ConnectorExecutionRecord>
ConnectorHistoryApi. getHistory(java.lang.String connectorName)
ConnectorExecutionRecord
ConnectorHistoryApi. getLatestHistory(java.lang.String connectorName)
java.util.Date
IngestionHistoryApi. getPreviousStartTime(java.lang.String namespace)
Returns the start time for the last session for thisnamespace
.java.util.List<java.lang.String>
AutoCompleteApi. getProviderNames()
Get a list of all theautocomplete provider
names registered in Attiviojava.util.List<java.lang.String>
MockAutoCompleteApi. getProviderNames()
AdminQueryResult<DictionaryEntry>
DictionaryClient. getPublishedEntities(DictionaryType type, java.lang.String name, java.lang.String group, java.lang.String query, int offset, int rows)
Get a list of published entries for an entity dictionary.AdminQueryResult<DictionaryEntry>
DictionaryClient. getPublishedEntities(java.lang.String name, java.lang.String group, java.lang.String query, int offset, int rows)
Get a list of published entries for an entity dictionary.Schema
SearchClient. getSchema(java.lang.String schemaName)
Get a named schema in the system or null if it does not exist.java.util.List<java.lang.String>
SignalTrackingApi. getSignalTypes()
Get all available signal types.byte[]
IngestionHistoryApi. getSignature(java.lang.String namespace, java.lang.String key)
Returns the last signature associated with the key ornull
if no signature is present.java.util.List<byte[]>
IngestionHistoryApiBatchSupport. getSignatureBatch(java.lang.String namespace, java.util.List<java.lang.String> keys)
Similar to @link com.attivio.sdk.client.InvestionHistoryApi#getSignature() but takes an ordered list of keys (for efficiency)java.util.Date
IngestionHistoryApi. getStartTime(java.lang.String namespace)
Returns the start time of the current session for thisnamespace
.long
ExternalizableStore. getStoreRevision()
Get the current revision number for this store.java.util.List<AutoCompleteSuggestion>
AutoCompleteApi. getSuggestions(java.lang.String providerName, QueryRequest req)
Get all suggestions from a certainautocomplete provider
given its name and a query requestjava.util.List<AutoCompleteSuggestion>
MockAutoCompleteApi. getSuggestions(java.lang.String providerName, QueryRequest req)
long
ContentStoreClient. getTotalRecords()
Deprecated.Get the total number of records in the content store.java.lang.Iterable<java.lang.String>
IngestionHistoryApi. getUnvisited(java.lang.String namespace)
Returns anIterable
of the keys that have not been visited in the current session.java.lang.Iterable<java.lang.String>
IngestionHistoryApi. getUnvisited(java.lang.String namespace, java.util.Date since)
Returns anIterable
of the keys that have not been visited since the timesince
.void
DictionaryClient. importDictionary(java.lang.String contentStoreId)
void
SignalTrackingApi. importSignals(java.lang.Iterable<Signal> signals)
Import signals to be trackedvoid
ExternalizableStore. importStore(java.io.InputStream input, java.lang.Long ifUnmodifiedSince, ExternalizableStore.ImportOption... options)
Import the model for the store from a jar file read frominput
.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(java.lang.String connectorName)
Pauses the named connectorIngestDocument
DocumentProcessorApi. process(IngestDocument doc, java.lang.String workflow)
Process a given document by running it through a given workflow.DictionaryInfo
DictionaryClient. publishDictionary(DictionaryInfo info)
Publish approved changes to dictionary identified byinfo
.ContentPointer
IngestClient. put(java.lang.String id, byte[] bytes)
Put the contents of a byte array into the content store.ContentPointer
IngestClient. put(java.lang.String id, InputStreamBuilder input)
Stores binary data in the ContentStore.ContentPointer
IngestClient. put(java.lang.String id, java.io.File f)
Put the contents of a File into the content store.ContentPointer
IngestClient. put(java.lang.String id, java.io.InputStream input)
Put a resource into the Content Store.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 byinfo
.DictionaryInfo
DictionaryClient. registerDictionary(DictionaryInfo info, java.lang.String contentStoreId)
Create dictionary defined byinfo
and import all dictionary entries atcontentStoreId
in csv format.void
IngestionHistoryApi. removeDocumentByKey(java.lang.String namespace, java.lang.String key)
Removes a document using the keyvoid
DictionaryClient. replaceDictionary(java.lang.String contentStoreId)
Replace dictionary with import.DictionaryInfo
DictionaryClient. replaceDictionaryEntries(DictionaryInfo info, java.lang.String contentStoreId)
Add all entries fromcontentStorId
in csv format to dictionary identified byinfo
.void
ConnectorControlApi. reset(java.lang.String connectorName)
Resets the incremental state of the named connectorvoid
AutoCompleteApi. resourceModified(java.lang.String uri)
Notifies allautocomplete providers
that share resources that their resource has been modified.void
MockAutoCompleteApi. resourceModified(java.lang.String uri)
void
ConnectorControlApi. resume(java.lang.String connectorName)
Resumes the named connector if pausedContentPointer
ContentStoreClient. retrieve(java.lang.String id)
Deprecated.Retrieve a ContentPointer in the ContentStore.IngestDocument
DocumentStoreApi. retrieve(java.lang.String namespace, java.lang.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(java.lang.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 enginevoid
ConnectorHistoryApi. setClientId(java.lang.String connectorName, java.util.UUID clientId)
Associates the provided client id with the current run of the connector.java.util.UUID
ConnectorControlApi. start(java.lang.String connectorName)
Starts the named connectorvoid
DocumentOutputClient. startMessageGroup()
Starts a group of messages that will be processed together.java.util.Date
IngestionHistoryApi. startSession(java.lang.String namespace)
Starts a new session for the namespace.void
ConnectorControlApi. stop(java.lang.String connectorName)
Stops the connectorvoid
ConnectorControlApi. stop(java.lang.String connectorName, long shutdownWaitTimeout)
Stops the connectorContentPointer
ContentStoreClient. store(java.lang.String id, InputStreamBuilder input)
Deprecated.Store a ContentPointer in the ContentStore.void
DocumentStoreApi. store(java.lang.String namespace, IngestDocument doc, java.util.List<java.lang.String> filterFields, boolean storeContentPointers)
Stores the document innamespace
, creating indexes which allow equality filtering on the list of fields provided.IngestDocument
DocumentStoreApi. storeAndUpdate(java.lang.String namespace, IngestDocument doc, java.util.List<java.lang.String> filterFields, boolean storeContentPointers)
Stores the document innamespace
, creating indexes which allow equality filtering on the list of fields provided.void
DictionaryClient. storeDictionaryInContentStore(java.lang.String contentStoreId, byte[] bytes)
Deprecated.DictionaryInfo
DictionaryClient. updateDictionary(DictionaryInfo info)
Update dictionaryinfo
.DictionaryEntry
DictionaryClient. updateDictionaryEntry(DictionaryEntry entry)
Update a dictionary entry.void
ConnectorHistoryApi. updateExtraRunInfo(java.lang.String connectorName, java.util.List<java.lang.String> extraRunInfo)
Updates the extraRunInfo forconnectorName
.void
ConnectorHistoryApi. updateSentCount(java.lang.String connectorName, long docCount)
Updates the number of documents sent byconnectorName
.void
IngestionHistoryApi. visit(java.lang.String namespace, java.lang.String key, byte[] signature)
Records thekey
as having been visited updates its associated signature.void
IngestionHistoryApiBatchSupport. visitBatch(java.lang.String namespace, java.util.Collection<IngestionHistoryApiBatchSupport.VisitBatch> batch)
Similar to @link com.attivio.sdk.client.InvestionHistoryApi#visit() but takes a batch (for efficiency)boolean
IngestClient. waitForCompletion()
Wait for all documents and messages to be fully processed.boolean
IngestClient. waitForCompletion(boolean changeClientId)
Wait the specified number of milliseconds for all MessageResults to be processed.boolean
IngestClient. waitForCompletion(long timeout)
Wait the specified number of milliseconds for all MessageResults to be processed.boolean
IngestClient. waitForCompletion(long timeout, boolean changeClientId)
Wait the specified number of milliseconds for all MessageResults to be processed. -
Uses of AttivioException in com.attivio.sdk.client.audit
Methods in com.attivio.sdk.client.audit that throw AttivioException Modifier and Type Method Description long
AuditWriterApi. audit(AuditDetail audit)
Writes the audit information to the store.long
AuditWriterApi. audit(java.util.List<AuditDetail> audit)
Writes a batch of audit information to the store.void
AuditWriterApi. clientHeartbeat(java.util.UUID clientId)
Updates the audit information to show that the client is still active so that the client will continue to be returned byAuditReaderApi.getActiveClients()
.void
AuditWriterApi. clientName(java.util.UUID clientId, java.lang.String name)
Sets a name to be associated with the client.java.lang.Iterable<java.util.UUID>
AuditReaderApi. getActiveClients()
Returns the clientIds for all active clients.CloseableIterable<AuditDetail>
AuditReaderApi. getAll(java.util.UUID clientId, long startSeq, long count)
java.lang.Iterable<java.util.UUID>
AuditReaderApi. getAllClients()
Returns the clientIds for all clients sorted by clientId for ease of comparison.java.lang.Iterable<AuditDetail>
AuditReaderApi. getAuditDetails(java.lang.String docId, java.util.Date start, java.util.Date end)
Returns anIterable
ofAuditDetail
s associated with the document.java.lang.Iterable<AuditDetail>
AuditReaderApi. getAuditDetails(java.lang.String docId, java.util.UUID clientId)
Returns anIterable
ofAuditDetail
s associated with the document.java.lang.Iterable<AuditDetail>
AuditReaderApi. getByCorrelationId(java.util.UUID clientId, java.util.UUID correlationId)
Get all audit details for a document via itscorrelationId
.java.lang.Iterable<java.lang.String>
AuditReaderApi. getCreatedDocuments(java.util.Date start, java.util.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.java.lang.Iterable<java.lang.String>
AuditReaderApi. getCreatedDocuments(java.util.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.java.lang.Iterable<java.lang.String>
AuditReaderApi. getDocuments(java.util.EnumSet<ProcessingResultCode> codeSet, java.util.Date start, java.util.Date end)
Returns a list of IDs for all documents for which aresultCode
incodeSet
was received at some point during content processing.java.lang.Iterable<java.lang.String>
AuditReaderApi. getDocuments(java.util.EnumSet<ProcessingResultCode> codeSet, java.util.UUID clientId)
Returns a list of IDs for all documents for which aresultCode
incodeSet
was received at some point during content processing.java.lang.Iterable<java.util.UUID>
AuditReaderApi. getInactiveClients()
Returns the clientIds for all inactive clients.java.lang.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
.java.lang.Iterable<java.lang.String>
AuditReaderApi. getProcessedDocuments(java.util.Date start, java.util.Date end)
Returns a list of IDs for all documents which have completed processing during the specified date range.java.lang.Iterable<java.lang.String>
AuditReaderApi. getProcessedDocuments(java.util.UUID clientId)
Returns a list of IDs for all documents which have completed processing which were sent by the specified client.java.lang.Iterable<java.lang.String>
AuditReaderApi. getSearchableDocuments(java.lang.String indexName, java.util.Date start, java.util.Date end)
Returns anIterable
of IDs for all documents which became searchable during the specified date range.java.lang.Iterable<java.lang.String>
AuditReaderApi. getSearchableDocuments(java.lang.String indexName, java.util.UUID clientId)
Returns anIterable
of IDs for all documents that are searchable and were fed by the specified client.AuditClientSummary
AuditReaderApi. getSummary(java.util.UUID clientId)
void
AuditWriterApi. makeInactive(java.util.UUID clientId)
Marks the clientId as inactive.void
AuditWriterApi. purge(java.util.Date start, java.util.Date end)
Purges all audit data within the time range.void
AuditWriterApi. purge(java.util.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 beforelastInactiveTimeToKeep
AuditClientSummary
AuditReaderApi. waitForCompletion(java.util.UUID clientId)
Waits until all documents and messages created by this client have completed processing.AuditClientSummary
AuditReaderApi. waitForCompletion(java.util.UUID clientId, long timeout)
Waits until all documents and messages created by this client have completed processing.java.util.Date
AuditReaderApi. whenSearchable(java.lang.String indexName, java.util.UUID clientId)
Returns the earliest date an index commit was received after all documents for the client were indexed.java.util.Date
AuditReaderApi. whenSearchable(java.lang.String indexName, java.util.UUID clientId, java.lang.String docId)
Returns the earliest date an index commit was received after the document was indexed. -
Uses of AttivioException in com.attivio.sdk.client.streaming
Methods in com.attivio.sdk.client.streaming that throw AttivioException Modifier and Type Method Description QueryResponse
StreamingQueryResponse. getQueryResponse()
Get the QueryResponse for the query. -
Uses of AttivioException in com.attivio.sdk.client.trigger
Methods in com.attivio.sdk.client.trigger that throw AttivioException Modifier and Type Method Description void
TriggerApi. compileDictionary(TriggerDictionaryName dictionaryName)
Compile the trigger dictionary identified bydictionaryName
into binary format.default void
TriggerApi. compileDictionary(java.lang.String dictionaryName)
Deprecated.useTriggerApi.compileDictionary(TriggerDictionaryName)
instead.void
TriggerApi. copyDictionary(TriggerDictionaryName dictionaryName, TriggerDictionaryName newName)
Copy the trigger dictionary identified bydictionaryName
to a new dictionary withnewName
.default void
TriggerApi. copyDictionary(java.lang.String dictionaryName, java.lang.String newName)
Deprecated.void
TriggerApi. createDictionary(TriggerDictionaryInfo info)
Create a newtrigger
dictionary.void
TriggerApi. createTrigger(TriggerDictionaryName dictionaryName, TriggerDefinition trigger)
Addtrigger
to the dictionary identified bydictionaryName
.default void
TriggerApi. createTrigger(java.lang.String dictionaryName, TriggerDefinition trigger)
Deprecated.void
TriggerApi. deleteDictionary(TriggerDictionaryName dictionaryName)
Delete atrigger
dictionary identified bydictionaryName
.default void
TriggerApi. deleteDictionary(java.lang.String dictionaryName)
Deprecated.useTriggerApi.deleteDictionary(TriggerDictionaryName)
instead.void
TriggerApi. deleteTrigger(TriggerDictionaryName dictionaryName, java.lang.String triggerName)
Delete trigger namedtriggerName
for the dictionary identified bydictionaryName
.default void
TriggerApi. deleteTrigger(java.lang.String dictionaryName, java.lang.String triggerName)
Deprecated.void
TriggerApi. exportDictionary(TriggerDictionaryName dictionaryName, java.io.OutputStream output)
Export trigger dictionary byname
tooutput
.default void
TriggerApi. exportDictionary(java.lang.String dictionaryName, java.io.OutputStream output)
Deprecated.java.lang.Iterable<TriggerDictionaryInfo>
TriggerApi. getDictionaries(TriggerDictionaryName prefix, int offset, int rows)
Get all dictionaries.default java.lang.Iterable<TriggerDictionaryInfo>
TriggerApi. getDictionaries(java.lang.String prefix, int offset, int rows)
Deprecated.TriggerDictionaryInfo
TriggerApi. getDictionary(TriggerDictionaryName dictionaryName)
Get aTriggerDictionaryInfo
bydictionaryName
.default TriggerDictionaryInfo
TriggerApi. getDictionary(java.lang.String dictionaryName)
Deprecated.useTriggerApi.getDictionary(TriggerDictionaryName)
instead.default java.util.List<java.lang.String>
TriggerApi. getDictionaryNames()
Get the names of all dictionaries in the default namespace.java.util.Map<java.util.Locale,java.lang.Long>
TriggerApi. getLocales(TriggerDictionaryName dictionaryName, java.lang.String prefix)
Get a map of locales for dictionary specified bydictionaryName
.default java.util.Map<java.util.Locale,java.lang.Long>
TriggerApi. getLocales(java.lang.String dictionaryName, java.lang.String prefix)
Deprecated.useTriggerApi.getLocales(TriggerDictionaryName, String)
instead.default long
TriggerApi. getStoreRevision()
Get the store revision for the default namespace.long
TriggerApi. getStoreRevision(java.lang.String namespace)
Get the store revision for the specifiednamespace
.TriggerDefinition
TriggerApi. getTrigger(TriggerDictionaryName dictionaryName, java.lang.String triggerName)
default TriggerDefinition
TriggerApi. getTrigger(java.lang.String dictionaryName, java.lang.String triggerName)
Deprecated.use#getTrigger(String, String, String)
instead.java.lang.Iterable<TriggerDefinition>
TriggerApi. getTriggers(TriggerDictionaryName dictionaryName, java.util.Locale locale, java.lang.String prefix, int offset, int rows)
Get triggers for dictionary identified bydictionaryName
.default java.lang.Iterable<TriggerDefinition>
TriggerApi. getTriggers(java.lang.String dictionaryName, java.util.Locale locale, java.lang.String prefix, int offset, int rows)
Deprecated.default void
TriggerApi. importDictionary(byte[] input, TriggerDictionaryName newName, boolean replace)
Deprecated.default void
TriggerApi. importDictionary(byte[] input, java.lang.String newName, boolean replace)
Deprecated.void
TriggerApi. importDictionary(java.io.InputStream input, TriggerDictionaryName newName, boolean replace)
Import a trigger dictionary frominput
.default void
TriggerApi. importDictionary(java.io.InputStream input, java.lang.String newName, boolean replace)
Deprecated.IngestDocument
TriggerApi. process(TriggerDictionaryName dictionaryName, IngestDocument document, boolean published)
Processdocument
according todictionaryName
.default IngestDocument
TriggerApi. process(java.lang.String dictionaryName, IngestDocument document, boolean published)
Deprecated.void
TriggerApi. publishDictionary(TriggerDictionaryName dictionaryName)
Publish the most recently compiled binary dictionary identified bydictionaryName
.default void
TriggerApi. publishDictionary(java.lang.String dictionaryName)
Deprecated.useTriggerApi.publishDictionary(TriggerDictionaryName)
instead.void
TriggerApi. updateDictionary(TriggerDictionaryInfo info)
Update the metadata for atrigger
dictionary.void
TriggerApi. updateTrigger(TriggerDictionaryName dictionaryName, TriggerDefinition trigger)
Updatetrigger
for the dictionary identified bydictionaryName
.default void
TriggerApi. updateTrigger(java.lang.String dictionaryName, TriggerDefinition trigger)
Deprecated.use#updateTrigger(String, String, TriggerDefinition)
instead. -
Uses of AttivioException in com.attivio.sdk.commandline
Methods in com.attivio.sdk.commandline that throw AttivioException Modifier and Type Method Description int
AttivioRunnable. run()
Perform logic and return one ofAttivioRunnable.RETURN_CODE_OK
,AttivioRunnable.RETURN_CODE_ERROR
. -
Uses of AttivioException in com.attivio.sdk.connector
Methods in com.attivio.sdk.connector that throw AttivioException Modifier and Type Method Description void
DocumentPublisher. bulkUpdate(BulkUpdate bulkUpdateMessage)
Issue a bulk update.void
MockPublisher. bulkUpdate(BulkUpdate message)
void
DocumentPublisher. delete(java.lang.String... docIds)
Delete a list of documents.void
DocumentPublisher. delete(java.lang.String queryWorkflow, Query query)
Delete all documents that match a query.void
MockPublisher. delete(java.lang.String... docId)
void
MockPublisher. delete(java.lang.String queryWorkflow, Query query)
void
MockPublisher. deletePrincipal(AttivioPrincipalKey key)
void
DocumentPublisher. feed(IngestDocument... doc)
Feed one of more documents to Attivio.void
MockPublisher. feed(IngestDocument... docs)
void
MockPublisher. feed(IngestDocument doc, AttivioAcl acl)
void
MockPublisher. feed(AttivioPrincipal principal)
java.util.List<PlatformMessage>
MockPublisher. getSentMessages()
void
DocumentPublisher. put(IngestDocument doc, java.lang.String fieldName, java.lang.String id, java.io.InputStream is)
Store the content stream in the content store an put aContentPointer
in the indicated document field.void
MockPublisher. put(IngestDocument doc, java.lang.String fieldName, java.lang.String id, java.io.InputStream is)
boolean
DocumentPublisher. waitForCompletion(long time)
Wait the specified number of milliseconds for all the documents to be processed. -
Uses of AttivioException in com.attivio.sdk.esb
Methods in com.attivio.sdk.esb that return AttivioException Modifier and Type Method Description AttivioException
ExceptionResponse. getCause()
Get the cause.AttivioException
ExceptionResponse. getCause(java.lang.String message, java.lang.Object... args)
Get the cause.Methods in com.attivio.sdk.esb with parameters of type AttivioException Modifier and Type Method Description void
ProcessingResult. fail(PlatformMessage pm, AttivioException ex)
-
Uses of AttivioException in com.attivio.sdk.ingest
Methods in com.attivio.sdk.ingest that throw AttivioException Modifier and Type Method Description java.io.InputStream
ByteArrayContentPointer. getStream()
Get as an InputStream for reading.java.io.InputStream
ContentPointer. getStream()
Get as an InputStream for reading. -
Uses of AttivioException in com.attivio.sdk.scanner
Methods in com.attivio.sdk.scanner that throw AttivioException Modifier and Type Method Description java.util.List<PlatformMessage>
TestScannerRunner. getSentMessages()
java.util.List<PlatformMessage>
TestScannerRunnerImpl. getSentMessages()
void
IncrementalDataSourceScanner. reset(java.lang.String connectorName)
Resets any state being maintained by this scanner.void
DataSourceScanner. start(java.lang.String connectorName, DocumentPublisher publisher)
void
TestScannerRunner. start()
Runs the scanner.void
TestScannerRunnerImpl. start()
default void
DataSourceScanner. validateConfiguration()
This method could be implemented to verify the scanner configuration before it is started. -
Uses of AttivioException in com.attivio.sdk.scanner.concurrency
Methods in com.attivio.sdk.scanner.concurrency that throw AttivioException Modifier and Type Method Description DocumentAndAcl
DocumentFetchRequest. getDocument()
Called by the framework to get the generated document.void
ContentStoreAccess. put(IngestDocument doc, java.lang.String fieldName, java.lang.String id, java.io.InputStream is)
Store the content stream in the content store and put aContentPointer
in the indicated document field. -
Uses of AttivioException in com.attivio.sdk.schema
Methods in com.attivio.sdk.schema that throw AttivioException Modifier and Type Method Description default Schema
SchemaApi. addSchema(Schema schema)
Add/updateschema
java.util.List<java.lang.String>
SchemaApi. getSchemaNames()
Get the names of all available schemas.default void
SchemaApi. removeSchema(java.lang.String schemaName)
Remove a schema from the system. -
Uses of AttivioException in com.attivio.sdk.search
Methods in com.attivio.sdk.search that throw AttivioException Modifier and Type Method Description void
SearchProfileApi. compileSearchProfile(java.lang.String name)
Compile all outstanding changes to the search profile to support testing/publish.static QueryRequest
QueryRequest. create(CgiRequest cgi)
Converts CGI HTTP POST/GET request to aQueryRequest
.void
SearchProfileApi. createQueryFrame(java.lang.String searchProfile, QueryFrame frame)
Create a query frame.void
SearchProfileApi. createSearchProfile(SearchProfile profile)
Create a search profile.default void
SearchProfileApi. createSearchProfile(java.lang.String name)
Create a search profile.void
SearchProfileApi. deleteQueryFrame(java.lang.String searchProfile, java.lang.String name)
Delete a query frame.void
SearchProfileApi. deleteSearchProfile(java.lang.String name)
Delete a search profile identified byname
.void
SearchProfileApi. exportSearchProfile(java.lang.String name, java.io.OutputStream output)
Export a search profile.QueryFrame
SearchProfileApi. getQueryFrame(java.lang.String searchProfile, java.lang.String name)
Get a query frame.java.util.List<QueryFrame>
SearchProfileApi. getQueryFrames(java.lang.String searchProfile)
Get a list of all query frames forsearchProfile
SearchProfile
SearchProfileApi. getSearchProfile(java.lang.String name)
Get search profile by name.default java.util.List<java.lang.String>
SearchProfileApi. getSearchProfileNames()
Return a list of the names of all search profiles.java.util.List<SearchProfile>
SearchProfileApi. getSearchProfiles()
Return a list of available search profiles.default void
SearchProfileApi. importSearchProfile(java.io.InputStream input)
Import search profile frominput
.QueryFrameResult
SearchProfileApi. process(QueryRequest request, java.lang.String query, java.lang.String workflow)
Get the matching query frame for a request.void
SearchProfileApi. publishSearchProfile(java.lang.String name)
Make the most recently compiled search profile live.void
QueryRequest. setProperties(java.util.Map<java.lang.String,java.lang.String[]> parameters)
void
SearchProfileApi. updateQueryFrame(java.lang.String searchProfile, QueryFrame frame)
Update query frame.void
SearchProfileApi. updateSearchProfile(SearchProfile profile)
Update a search profile. -
Uses of AttivioException in com.attivio.sdk.security
Methods in com.attivio.sdk.security that throw AttivioException Modifier and Type Method Description void
SecurityFeeder. deletePrincipal(AttivioPrincipalKey key)
Deletes a principal from the index.void
SecurityFeeder. feed(IngestDocument doc, AttivioAcl acl)
Sendsdoc
to the document receiver with the given ACL.void
SecurityFeeder. feed(AttivioPrincipal principal)
Ingests an AttivioPrincipal. -
Uses of AttivioException in com.attivio.sdk.server.component
Methods in com.attivio.sdk.server.component that throw AttivioException Modifier and Type Method Description PlatformMessage
CgiRequestProcessor. handleCgiRequest(CgiRequest cgi)
Called by the Attivio Engine to convert aCgiRequest
into aPlatformMessage
to be handled by the Attivio Engine.void
IndexMessageHandler. handleIndexMessage(IndexMessage message)
Called by the Attivio Engine to allow implementing components to handleIndexMessage
s.PlatformMessage
MessageHandlingWorkflowStage. processMessage(PlatformMessage msg)
Called whenever a message is received for the component. -
Uses of AttivioException in com.attivio.sdk.server.component.ingest
Methods in com.attivio.sdk.server.component.ingest that throw AttivioException Modifier and Type Method Description IngestFieldValue
FieldValueCreatingTransformer. createMappedValue(java.lang.String inputFieldName, IngestFieldValue inputFieldValue)
Process a singleIngestFieldValue
and return a new value to be placed into the document for this input->output mapping.boolean
FieldValueModifyingTransformer. modifyFieldValue(java.lang.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 singleIngestDocument
. -
Uses of AttivioException in com.attivio.sdk.server.component.lifecycle
Methods in com.attivio.sdk.server.component.lifecycle that throw AttivioException Modifier and Type Method Description void
AfterAllLocalInstancesStarted. afterAllLocalInstancesStarted()
Called after all instances of this component in the system have been startedvoid
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. -
Uses of AttivioException in com.attivio.sdk.server.component.query
Methods in com.attivio.sdk.server.component.query that throw AttivioException Modifier and Type Method Description java.util.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 aQueryResponse
which contains information about the query request and the metadata about how long it took to compute the results. -
Uses of AttivioException in com.attivio.sdk.server.component.reduce
Methods in com.attivio.sdk.server.component.reduce that throw AttivioException Modifier and Type Method Description IngestDocument
ReducingTransformer. reduce(java.lang.String keyValue, java.util.Iterator<IngestDocument> documents)
Reduces a set of IngestDocument(s) based on key -
Uses of AttivioException in com.attivio.sdk.server.export
Methods in com.attivio.sdk.server.export that throw AttivioException Modifier and Type Method Description void
DiagnosticExportProvider. export(java.util.zip.ZipOutputStream out)
-
Uses of AttivioException in com.attivio.sdk.server.global
Methods in com.attivio.sdk.server.global that throw AttivioException Modifier and Type Method Description void
GlobalMembership. add(java.lang.String name)
Deprecated.Add a member to this membership.boolean
GlobalSet. add(java.lang.String val)
Deprecated.Adds aString
value to thisGlobalSet
java.io.Closeable
GlobalDataStructureFactory. addGlobalMapListener(java.lang.String name, GlobalMapListener listener)
Deprecated.boolean
GlobalVariable. compareAndSet(java.lang.String expectedValue, java.lang.String newValue)
Deprecated.Same semantics asAtomicReference.compareAndSet(Object, Object)
.boolean
GlobalSet. contains(java.lang.String val)
Deprecated.Whether or not thisGlobalSet
contains a givenString
GlobalLock
GlobalDataStructureFactory. createGlobalLock(java.lang.String name, BreakableLockListener lockListener)
Deprecated.Creates a globalLock
with the givenname
if it does not yet exist.GlobalMap
GlobalDataStructureFactory. createGlobalMap(java.lang.String name)
Deprecated.Creates a persistentglobal map
with the givenname
if it does not yet exist.GlobalMembership
GlobalDataStructureFactory. createGlobalMembership(java.lang.String name)
Deprecated.Creates aglobal membership
with the givenname
if it does not yet exist.GlobalSet
GlobalDataStructureFactory. createGlobalSet(java.lang.String name, MembershipListener listener)
Deprecated.Creates aglobal set
with the givenname
if it does not yet exist.GlobalVariable
GlobalDataStructureFactory. createGlobalVariable(java.lang.String name)
Deprecated.Creates aglobal variable
with the givenname
if it does not yet exist.java.lang.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 providedMembershipListener
void
GlobalVariable. listen(VariableListener listener)
Deprecated.Registers aVariableListener
that will be called when the value of this GlobalVariable is changed.java.util.List<java.lang.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(java.lang.String key, java.lang.String value)
Deprecated.Update akey
tovalue
.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.void
GlobalMembership. remove(java.lang.String name)
Deprecated.Remove a member from this membership.boolean
GlobalSet. remove(java.lang.String val)
Deprecated.Removes aString
value from thisGlobalSet
void
VersionedMasterElection. rollback(java.lang.String version)
Deprecated.Rollback the global version toversion
void
GlobalVariable. set(java.lang.String value)
Deprecated.Add or updates the value to the new value specified.void
VersionedMasterElection. setGlobalVersion(java.lang.String version)
Deprecated.Updates the global value for the election to be based on. -
Uses of AttivioException in com.attivio.sdk.server.tokenization
Methods in com.attivio.sdk.server.tokenization that throw AttivioException Modifier and Type Method Description default Tokenizer
Tokenizer. getIngestTokenizer(SchemaField field, java.util.Locale locale)
Get the underlying tokenizer to use for tokenizing fields in the ingest workflow.default Tokenizer
Tokenizer. getQueryTokenizer(SchemaField field, java.util.Locale locale)
Get the underlaying tokenizer to use for tokenizing fields in the query workflow.Phrase
Tokenizer. tokenize(SchemaField field, java.util.Locale locale, SearchTerm term)
Tokenizesterm
into a Phrase for query processing.Phrase
Tokenizer. tokenize(SchemaField field, java.util.Locale locale, TermRange range)
Tokenizesrange
into a Phrase for query processing.Phrase
Tokenizer. tokenize(SchemaField field, java.util.Locale locale, WildcardTerm term)
Tokenizes a wildcardterm
into a Phrase for query processing.void
Tokenizer. tokenize(SchemaField field, java.util.Locale locale, TokenList tokens)
Tokenizes all tokens intokens
.default TokenList
Tokenizer. tokenize(SchemaField field, java.util.Locale locale, java.lang.String value)
Tokenizesvalue
into a TokenList. -
Uses of AttivioException in com.attivio.sdk.service
Methods in com.attivio.sdk.service that throw AttivioException Modifier and Type Method Description void
MockContentStoreProvider. add(java.lang.String namespace, java.lang.String id, java.io.InputStream in)
Content will be copied from the InputStream and stored within thenamespace
under theid
.long
MockIngestAuditApi. audit(AuditDetail detail)
long
MockIngestAuditApi. audit(java.util.List<AuditDetail> details)
void
MockIngestAuditApi. clientHeartbeat(java.util.UUID clientId)
Updates the audit information to show that the client is still active so that the client will continue to be returned byAuditReaderApi.getActiveClients()
.void
MockIngestAuditApi. clientName(java.util.UUID clientId, java.lang.String name)
Sets a name to be associated with the client.boolean
MockContentStoreProvider. contains(java.lang.String namespace, java.lang.String id)
void
MockContentStoreClient. delete(java.lang.String id)
Delete a record by id from the content store.void
MockContentStoreProvider. delete(java.lang.String namespace, java.lang.String id)
Deletesid
from thenamespace
.void
MockDocumentStore. delete(java.lang.String collection, java.lang.String docId)
Deletes the document from the specified collectionvoid
MockContentStoreClient. deleteAll()
Delete all content in the content store.void
MockContentStoreProvider. deleteAll(java.lang.String namespace)
Deletes all content from the store within the namespacelong
MockTransportDefinitionStore. exportStore(java.io.OutputStream output, java.lang.Long ifModifiedSince)
Export the model for the store to a jar file written tooutput
.java.lang.String
MockContentStoreProvider. externalize(java.lang.String storeName, java.lang.String id)
Returns an externally accessible URI for the content suitable for HTTP GET.void
MockIngestApi. feed(PlatformMessage msg)
java.lang.Iterable<IngestDocument>
MockDocumentStore. filteredRetrieve(java.lang.String collection, java.util.Map<java.lang.String,java.lang.String> filterVals)
Finds and returns the documents matching the provided equality filters.java.io.InputStream
MockContentStoreProvider. get(java.lang.String namespace, java.lang.String id)
Returns an InputStream to access the content.java.lang.Iterable<java.util.UUID>
MockIngestAuditApi. getActiveClients()
Returns the clientIds for all active clients.CloseableIterable<AuditDetail>
MockIngestAuditApi. getAll(java.util.UUID clientId, long startSeq, long count)
java.lang.Iterable<java.util.UUID>
MockIngestAuditApi. getAllClients()
Returns the clientIds for all clients sorted by clientId for ease of comparison.java.lang.Iterable<AuditDetail>
MockIngestAuditApi. getAuditDetails(java.lang.String docId, java.util.Date start, java.util.Date end)
Returns anIterable
ofAuditDetail
s associated with the document.java.lang.Iterable<AuditDetail>
MockIngestAuditApi. getAuditDetails(java.lang.String docId, java.util.UUID clientId)
Returns anIterable
ofAuditDetail
s associated with the document.java.lang.Iterable<AuditDetail>
MockIngestAuditApi. getByCorrelationId(java.util.UUID clientId, java.util.UUID correlationId)
Get all audit details for a document via itscorrelationId
.java.lang.Iterable<java.lang.String>
MockIngestAuditApi. getCreatedDocuments(java.util.Date start, java.util.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.java.lang.Iterable<java.lang.String>
MockIngestAuditApi. getCreatedDocuments(java.util.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()
java.lang.Iterable<java.lang.String>
MockIngestAuditApi. getDocuments(java.util.EnumSet<ProcessingResultCode> codeSet, java.util.Date start, java.util.Date end)
Returns a list of IDs for all documents for which aresultCode
incodeSet
was received at some point during content processing.java.lang.Iterable<java.lang.String>
MockIngestAuditApi. getDocuments(java.util.EnumSet<ProcessingResultCode> codeSet, java.util.UUID clientId)
Returns a list of IDs for all documents for which aresultCode
incodeSet
was received at some point during content processing.java.lang.Iterable<java.util.UUID>
MockIngestAuditApi. getInactiveClients()
Returns the clientIds for all inactive clients.long
MockIngestAuditApi. getLastLossDetectionSequence(java.util.UUID clientId)
long
MockContentStoreProvider. getLastModified(java.lang.String namespace, java.lang.String id)
java.lang.Iterable<AuditDetail>
MockIngestAuditApi. getLostDetails(long startSeq, long endSeq)
java.util.List<java.lang.String>
MockContentStoreProvider. getNamespaces()
java.lang.Iterable<java.lang.String>
MockIngestAuditApi. getProcessedDocuments(java.util.Date start, java.util.Date end)
Returns a list of IDs for all documents which have completed processing during the specified date range.java.lang.Iterable<java.lang.String>
MockIngestAuditApi. getProcessedDocuments(java.util.UUID clientId)
Returns a list of IDs for all documents which have completed processing which were sent by the specified client.java.lang.Iterable<java.lang.String>
MockIngestAuditApi. getSearchableDocuments(java.lang.String indexName, java.util.Date start, java.util.Date end)
Returns anIterable
of IDs for all documents which became searchable during the specified date range.java.lang.Iterable<java.lang.String>
MockIngestAuditApi. getSearchableDocuments(java.lang.String indexName, java.util.UUID clientId)
Returns anIterable
of IDs for all documents that are searchable and were fed by the specified client.<T> T
MockServiceFactory. getService(java.lang.Class<T> clazz)
<T> T
MockServiceFactory. getService(java.lang.Class<T> clazz, long timeout)
<T> T
MockServiceFactory. getService(java.lang.Class<T> clazz, java.lang.String nodeName)
<T> T
MockServiceFactory. getService(java.lang.Class<T> clazz, java.lang.String nodeName, long timeout)
<T> T
MockServiceFactory. getService(java.lang.Class<T> clazz, java.util.Map<java.lang.String,java.lang.String> attributes, long timeout)
Returns an implementation of the desired service API.<T> T
ServiceFactory. getService(java.lang.Class<T> clazz)
<T> T
ServiceFactory. getService(java.lang.Class<T> clazz, long timeout)
<T> T
ServiceFactory. getService(java.lang.Class<T> clazz, java.lang.String nodeName)
<T> T
ServiceFactory. getService(java.lang.Class<T> clazz, java.lang.String nodeName, long timeout)
Deprecated.<T> T
ServiceFactory. getService(java.lang.Class<T> clazz, java.util.Map<java.lang.String,java.lang.String> attributes, long timeout)
Returns an implementation of the desired service API.long
MockContentStoreProvider. getSize(java.lang.String namespace, java.lang.String id)
long
MockTransportDefinitionStore. getStoreRevision()
Get the current revision number for this store.AuditClientSummary
MockIngestAuditApi. getSummary(java.util.UUID clientId)
long
MockContentStoreProvider. getTotalRecords(java.lang.String namespace)
void
MockTransportDefinitionStore. importStore(java.io.InputStream input, java.lang.Long ifUnmodifiedSince, ExternalizableStore.ImportOption... options)
Import the model for the store from a jar file read frominput
.void
MockIngestAuditApi. makeInactive(java.util.UUID clientId)
Marks the clientId as inactive.IngestDocument
MockDocumentProcessorApi. process(IngestDocument doc, java.lang.String workflowName)
void
MockIngestAuditApi. purge(java.util.Date start, java.util.Date end)
void
MockIngestAuditApi. purge(java.util.UUID clientId)
int
MockIngestAuditApi. purgeInactiveClients(long lastInactiveTimeToKeep)
Purges the audit data for all clients that are inactive and went inactive beforelastInactiveTimeToKeep
ContentPointer
MockContentStoreClient. retrieve(java.lang.String id)
Retrieve a ContentPointer in the ContentStore.IngestDocument
MockDocumentStore. retrieve(java.lang.String collection, java.lang.String docId)
void
MockIngestAuditApi. setLastLossDetectionSequence(java.util.UUID clientId, long seq)
Updates the last sequence number considered for loss detection forclientId
.ContentPointer
MockContentStoreClient. store(java.lang.String id, InputStreamBuilder input)
Store a ContentPointer in the ContentStore.void
MockDocumentStore. store(java.lang.String namespace, IngestDocument doc, java.util.List<java.lang.String> filterFields, boolean storeContentPointers)
Stores the document innamespace
, creating indexes which allow equality filtering on the list of fields provided.IngestDocument
MockDocumentStore. storeAndUpdate(java.lang.String namespace, IngestDocument doc, java.util.List<java.lang.String> filterFields, boolean storeContentPointers)
Stores the document innamespace
, creating indexes which allow equality filtering on the list of fields provided.void
MockIngestAuditApi. truncateAll()
Truncates all data tables containing audit information.void
MockIngestAuditApi. updateSummary(AuditClientSummary summary)
Updates the summary record to the provided value.AuditClientSummary
MockIngestAuditApi. waitForCompletion(java.util.UUID clientId)
Waits until all documents and messages created by this client have completed processing.AuditClientSummary
MockIngestAuditApi. waitForCompletion(java.util.UUID clientId, long timeout)
Waits until all documents and messages created by this client have completed processing.java.util.Date
MockIngestAuditApi. whenSearchable(java.lang.String indexName, java.util.UUID clientId)
Returns the earliest date an index commit was received after all documents for the client were indexed.java.util.Date
MockIngestAuditApi. whenSearchable(java.lang.String indexName, java.util.UUID clientId, java.lang.String docId)
Returns the earliest date an index commit was received after the document was indexed.Constructors in com.attivio.sdk.service that throw AttivioException Constructor Description MockIngestApi()
-
Uses of AttivioException in com.attivio.sdk.test
Methods in com.attivio.sdk.test that throw AttivioException Modifier and Type Method Description static SchemaApi
SdkTestUtils. createMockSchemaApi(Schema schema)
Create a mockSchemaApi
and addschema
to it.void
MockIngestClient. delete(java.lang.String... ids)
void
MockIngestClient. delete(java.util.Collection<java.lang.String> ids)
void
MockIngestClient. deleteByQuery(java.lang.String queryWorkflows, Query query)
void
MockIngestClient. deletePrincipal(AttivioPrincipalKey key)
void
MockIngestClient. endMessageGroup()
void
MockIngestClient. feed(IngestDocument... docs)
void
MockIngestClient. feed(IngestDocument doc, AttivioAcl acl)
void
MockIngestClient. feed(AttivioPrincipal principal)
void
MockIngestClient. feed(java.lang.Iterable<IngestDocument> docs)
java.io.InputStream
FileContentPointer. getStream()
void
MockIngestClient. startMessageGroup()
-
Uses of AttivioException in com.attivio.sdk.transport
Methods in com.attivio.sdk.transport that throw AttivioException Modifier and Type Method Description void
TransportDefinitionStore. addTransportDefinition(TransportDefinition tdef)
Add a transport definition.void
TransportDefinitionStore. removeTransportDefinition(java.lang.String className)
Remove the TransportDefinition associated withclassName
. -
Uses of AttivioException in com.attivio.service
Methods in com.attivio.service that throw AttivioException Modifier and Type Method Description void
MockUnclusteredEventStore. acknowledgeEvent(long eventId, java.lang.String user, java.lang.String reason)
long
MockUnclusteredEventStore. addEvent(SystemEvent event)
static <T> void
ServiceFactory. addServiceListener(java.lang.Class<T> clazz, ServiceListener listener)
Adds a listener that is called whenever the service availability changes.void
MockUnclusteredIngestionHistory. childCreated(java.lang.String namespace, java.lang.String key, java.lang.String childKey)
void
MockUnclusteredNoopIngestionHistory. childCreated(java.lang.String namespace, java.lang.String key, java.lang.String childKey)
void
MockUnclusteredIngestionHistory. clear(java.lang.String namespace)
void
MockUnclusteredNoopIngestionHistory. clear(java.lang.String namespace)
long
MockUnclusteredEventStore. countEvents()
void
IngestApi. feed(PlatformMessage msg)
protected java.util.List<java.lang.String>
MockUnclusteredIngestionHistory. getAllChildData(java.lang.String namespace)
protected java.util.List<java.lang.String>
MockUnclusteredIngestionHistory. getAllDocumentData(java.lang.String namespace)
java.lang.Iterable<java.lang.String>
MockUnclusteredIngestionHistory. getChildren(java.lang.String namespace, java.lang.String key)
java.lang.Iterable<java.lang.String>
MockUnclusteredNoopIngestionHistory. getChildren(java.lang.String namespace, java.lang.String key)
EventQuery
MockUnclusteredEventStore. getEvents(EventQuery query)
java.util.Date
MockUnclusteredIngestionHistory. getPreviousStartTime(java.lang.String namespace)
java.util.Date
MockUnclusteredNoopIngestionHistory. getPreviousStartTime(java.lang.String namespace)
static <T> T
ServiceFactory. getService(java.lang.Class<T> clazz)
static <T> T
ServiceFactory. getService(java.lang.Class<T> clazz, long timeout)
static <T> T
ServiceFactory. getService(java.lang.Class<T> clazz, long timeout, boolean logErrorOnTimeout)
static <T> T
ServiceFactory. getService(java.lang.Class<T> clazz, java.lang.String nodeName)
static <T> T
ServiceFactory. getService(java.lang.Class<T> clazz, java.lang.String nodeName, long timeout)
static <T> T
ServiceFactory. getService(java.lang.Class<T> clazz, java.util.Map<java.lang.String,java.lang.String> attributes)
static <T> T
ServiceFactory. getService(java.lang.Class<T> clazz, java.util.Map<java.lang.String,java.lang.String> attributes, long timeout)
static <T> T
ServiceFactory. getService(java.lang.Class<T> clazz, java.util.Map<java.lang.String,java.lang.String> attributes, long timeout, boolean logErrorOnTimeout)
Returns an implementation of the desired service API.<T> T
ServiceFactoryObject. getService(java.lang.Class<T> clazz)
<T> T
ServiceFactoryObject. getService(java.lang.Class<T> clazz, long timeout)
<T> T
ServiceFactoryObject. getService(java.lang.Class<T> clazz, java.lang.String nodeName)
<T> T
ServiceFactoryObject. getService(java.lang.Class<T> clazz, java.lang.String nodeName, long timeout)
<T> T
ServiceFactoryObject. getService(java.lang.Class<T> clazz, java.util.Map<java.lang.String,java.lang.String> attributes, long timeout)
Returns an implementation of the desired service API.static <T> org.apache.curator.x.discovery.ServiceInstance<AieServiceInfo>
ServiceFactory. getServiceInstance(java.lang.Class<T> clazz, java.lang.String nodeName)
byte[]
MockUnclusteredIngestionHistory. getSignature(java.lang.String namespace, java.lang.String key)
byte[]
MockUnclusteredNoopIngestionHistory. getSignature(java.lang.String namespace, java.lang.String key)
java.util.Date
MockUnclusteredIngestionHistory. getStartTime(java.lang.String namespace)
java.util.Date
MockUnclusteredNoopIngestionHistory. getStartTime(java.lang.String namespace)
java.lang.Iterable<java.lang.String>
MockUnclusteredIngestionHistory. getUnvisited(java.lang.String namespace)
java.lang.Iterable<java.lang.String>
MockUnclusteredIngestionHistory. getUnvisited(java.lang.String namespace, java.util.Date since)
java.lang.Iterable<java.lang.String>
MockUnclusteredNoopIngestionHistory. getUnvisited(java.lang.String namespace)
java.lang.Iterable<java.lang.String>
MockUnclusteredNoopIngestionHistory. getUnvisited(java.lang.String namespace, java.util.Date since)
static <T> AieServiceInfo
ServiceFactory. prepareServiceInfo(java.lang.String description, java.lang.Class<? extends RemoteClientApiFactory> customFactory, java.lang.Class<? extends java.util.function.Predicate<java.lang.Throwable>>... predicates)
TheServiceFactory.registerService(java.lang.Class<T>, java.lang.String, int, java.lang.Class<? extends com.attivio.service.RemoteClientApiFactory>, java.lang.Class<? extends java.util.function.Predicate<java.lang.Throwable>>...)
method utilizes this method to prepare the basic fields forAieServiceInfo
.static org.apache.curator.x.discovery.ServiceInstanceBuilder<AieServiceInfo>
ServiceFactory. prepareServiceInstanceBuilder(java.lang.String apiClassName, AieServiceInfo serviceInfo, int port)
static <T> org.apache.curator.x.discovery.ServiceInstance<AieServiceInfo>
ServiceFactory. registerService(java.lang.Class<T> api, java.lang.String description, int port, java.lang.Class<? extends RemoteClientApiFactory> customFactory, java.lang.Class<? extends java.util.function.Predicate<java.lang.Throwable>>... predicates)
static org.apache.curator.x.discovery.ServiceInstance<AieServiceInfo>
ServiceFactory. registerService(org.apache.curator.x.discovery.ServiceInstance<AieServiceInfo> service)
void
MockUnclusteredIngestionHistory. removeDocumentByKey(java.lang.String namespace, java.lang.String key)
void
MockUnclusteredNoopIngestionHistory. removeDocumentByKey(java.lang.String namespace, java.lang.String key)
static org.apache.curator.x.discovery.ServiceInstanceBuilder<AieServiceInfo>
CuratorHelper. serviceInstanceBuilder()
The Curator service discovery framework will initialize the address for a service to the IP address of the first NIC found on the host.java.util.Date
MockUnclusteredIngestionHistory. startSession(java.lang.String namespace)
java.util.Date
MockUnclusteredNoopIngestionHistory. startSession(java.lang.String namespace)
static void
ServiceFactory. unregisterService(org.apache.curator.x.discovery.ServiceInstance<AieServiceInfo> service)
protected void
MockUnclusteredIngestionHistory. updateDocumentWithDate(java.lang.String namespace, java.lang.String key, byte[] signature, java.util.Date useDate)
protected void
MockUnclusteredIngestionHistory. updateDocumentWithDate(java.lang.String namespace, java.lang.String key, java.util.Date useDate)
*****************************************************************************************************************void
MockUnclusteredIngestionHistory. visit(java.lang.String namespace, java.lang.String key, byte[] signature)
void
MockUnclusteredNoopIngestionHistory. visit(java.lang.String namespace, java.lang.String key, byte[] signature)
-
Uses of AttivioException in com.attivio.transport
Methods in com.attivio.transport that throw AttivioException Modifier and Type Method Description <T> T
HttpClientTransport. transport(java.lang.Class<? extends T> clazz, java.lang.Object o, java.lang.String uri)
Sends the object synchronously to the uri via HTTP POST.void
HttpClientTransport. transportAsync(java.lang.Object o, java.lang.String uri)
Sends the object asynchronously to the uri via HTTP POST. -
Uses of AttivioException in com.attivio.util
Methods in com.attivio.util with parameters of type AttivioException Modifier and Type Method Description void
AttivioLogger. error(AttivioException ae)
Log an AttivioException at an error levelstatic java.io.IOException
IOUtils. toIOException(AttivioException ex)
If the parameter was caused by an IOException, the cause is returned, otherwise a new IOException with the parameter is constructed and returned.void
AttivioLogger. warn(AttivioException ae)
Log an AttivioException at a warning level.default void
StatusListener. warn(AttivioException ae)
Log an AttivioException at a warning level.void
StatusListenerTee. warn(AttivioException ae)
Log an AttivioException at a warning level.Methods in com.attivio.util that throw AttivioException Modifier and Type Method Description static void
EventUtils. addEventWithTimeout(SystemEvent event)
Adds theevent
to the system repository.static boolean
SchemaUtils. deploy(SchemaApi src, SchemaApi dest)
Deploy schemas fromsrc
todest
.static boolean
SchemaUtils. deploy(StatusListener log, SchemaApi src, SchemaApi dest)
Deploy schemas fromsrc
todest
.static void
MessageUtils. dispatch(PlatformMessage msg, java.lang.String endpointName)
Sends the message to theendpointName
asynchronously.static org.apache.http.client.methods.CloseableHttpResponse
HTTPUtils. execute(org.apache.http.client.methods.HttpUriRequest method)
Executes the method and returns the response.static byte[]
HTTPUtils. getAsBytes(java.lang.String url)
Executes a GET and returns results as byte array.static int
HTTPUtils. getAsBytes(java.lang.String url, byte[] bytes)
Executes a GET and populates results in the provided byte array.static java.io.InputStream
HTTPUtils. getAsStream(java.lang.String url)
Executes an HTTP get and returns the response back as a stream using the default client.static java.io.InputStream
HTTPUtils. getAsStream(java.lang.String url, boolean close)
Executes an HTTP get and returns the response back as a stream using the default client.static java.lang.String
HTTPUtils. getAsText(java.lang.String url)
Executes a GET and returns results as a string in the default encoding.static java.io.InputStream
HTTPUtils. getConnectionClosingStream(org.apache.http.client.methods.HttpRequestBase m)
Gets a stream from the HTTP method that will be automatically closed when the stream is closed.static long
HTTPUtils. getContentLength(java.lang.String url)
Executes a HTTP header request and returns the content lengthstatic <T> T
JmxUtils. getRemoteJmxApi(java.lang.Class<T> clazz, java.lang.String host, int remotePort)
static <T> T
JmxUtils. getRemoteJmxApi(java.lang.Class<T> clazz, java.lang.String host, int remotePort, java.lang.String username, java.lang.String password)
static int
HTTPUtils. getSizeReturned(java.lang.String url)
Executes a GET and returns the number of size in bytes of the result returned.static void
HTTPUtils. getToStream(java.lang.String url, java.io.OutputStream out)
Reads the full contents of a URL.static boolean
IOUtils. isSameHost(java.lang.String otherHost)
Determines is the local host is the same as theotherHost
specified.static long
HTTPUtils. lastModified(java.lang.String url)
Executes a HTTP header request and returns the lastModified header as a unix timestampstatic java.lang.String
HTTPUtils. post(InputStreamBuilder in, java.lang.String url)
Executes an HTTP request and gets a response back for inspection.static <T> T
HTTPUtils. post(java.lang.Class<? extends T> clazz, org.apache.http.entity.AbstractHttpEntity entity, java.lang.String url, boolean close)
static java.lang.String
HTTPUtils. postAndGetText(java.lang.String request, java.lang.String uri, org.apache.http.entity.ContentType contentType)
Executes an HTTP request and gets the text response.static java.lang.String
HTTPUtils. postAndGetText(java.lang.String request, java.lang.String uri, org.apache.http.entity.ContentType contentType, java.lang.String encoding)
Executes an HTTP request and gets the text response.static <T> T
HTTPUtils. put(java.lang.Class<? extends T> clazz, org.apache.http.HttpEntity entity, java.lang.String url)
static PlatformMessage
MessageUtils. rawSend(PlatformMessage msg, java.lang.String endpointName, boolean synchronous)
Sends a message to theendpointName
.static PlatformMessage
MessageUtils. rawSendWithRetry(PlatformMessage msg, java.lang.String endpointName, boolean synchronous)
Sends a message to theendpointName
.static PlatformMessage
MessageUtils. rawSendWithRetry(PlatformMessage msg, java.lang.String endpointName, boolean synchronous, int maxRetries, long retryWaitTime)
Method for sending a message, retrying on transport error.static PlatformMessage
MessageUtils. send(PlatformMessage msg, java.lang.String endpointName)
Sends a message to theendpointName
synchronously.static PlatformMessage
MessageUtils. send(PlatformMessage msg, java.lang.String endpointName, boolean allowNullResponse)
Sends a message to theendpointName
synchronously.static PlatformMessage
MessageUtils. send(PlatformMessage msg, java.lang.String endpointName, boolean allowNullResponse, int maxRetries, long retryWaitTime)
Sends a message toendpointName
synchronously, retrying on transport error.static PlatformMessage
MessageUtils. send(PlatformMessage msg, java.lang.String endpointName, int maxRetries, long retryWaitTime)
Sends a message toendpointName
synchronously, retrying on transport error.static HttpResponseStream
HTTPUtils. stream(java.lang.String url)
Initialize a streaming client connection. -
Uses of AttivioException in com.attivio.util.serialization
Methods in com.attivio.util.serialization that return AttivioException Modifier and Type Method Description protected AttivioException
AttivioExceptionConverter. newAttivioException(java.lang.String context, ErrorCode code, java.lang.Throwable cause, java.lang.String message)
Create a new AttivioException instance.Methods in com.attivio.util.serialization that throw AttivioException Modifier and Type Method Description static long
ConverterUtils. getByteCount(java.lang.String memory)
Convert the memory specification string from GB, MB, or KB to a byte count value.
-