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

A

AbstractListenableMapAdapter<K,V> - Class in org.dataone.cn.batch.synchronization.type
A helper class to simplify making maps listenable, cleaving to the Hazelcast definition
AbstractListenableMapAdapter(Map<K, V>) - Constructor for class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
add(SyncObject) - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
Adds a task to the appropriate queue, creating the queue if one doesn't exist
addEntryListener(EntryListener<K, V>, boolean) - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
addEntryListener(EntryListener<K, V>, boolean) - Method in interface org.dataone.cn.batch.synchronization.type.DistributedDataClient.ListenableMap
 
addListener() - Method in class org.dataone.cn.batch.synchronization.listener.NodeTopicListener
 
addWithPriority(SyncObject) - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
Adds a task to the appropriate priority queue, creating the queue if one doesn't exist.
adjustFilterWindow(NodeComm, int, int, Date, Date) - Method in class org.dataone.cn.batch.synchronization.tasks.ObjectListHarvestTask
This method should optimize the time window size so that the total within group is not more than the maximum synchronization will take.

B

buildStandardLogMessage(Throwable, String) - Method in class org.dataone.cn.batch.synchronization.tasks.V2TransferObjectTask
 

C

call() - Method in class org.dataone.cn.batch.synchronization.tasks.ObjectListHarvestTask
Calls listObjects on the Member Node and manages putting SyncObjects onto the SynchronizationObjectQueue (one per object) for asynchronous processing.
call() - Method in class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
runs the queue processor until interrupted.
call() - Method in class org.dataone.cn.batch.synchronization.tasks.SyncFailedTask
Implement the Callable interface.
call() - Method in class org.dataone.cn.batch.synchronization.tasks.SyncObjectTask
Method to be called in a separately executing thread.
call() - Method in class org.dataone.cn.batch.synchronization.tasks.TransferObjectTask
Implement the Callable interface.
call() - Method in class org.dataone.cn.batch.synchronization.tasks.V2TransferObjectTask
Attempts to process the item to be synchronized.
cleanupTask(E) - Method in class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
 
clear() - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
compareTo(Delayed) - Method in class org.dataone.cn.batch.synchronization.tasks.DelayWrapper
 
containsKey(Object) - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
containsValue(Object) - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
createSynchronizationFailed(String, String, Exception) - Static method in class org.dataone.cn.batch.synchronization.tasks.SyncFailedTask
Creates a SynchronizationFailed exception with a standardized message for submitting back to the MN.
customSerializationCompareComplexFields(SystemMetadata) - Method in class org.dataone.cn.batch.synchronization.type.SystemMetadataValidator
 

D

D1TypeUtils - Class in org.dataone.cn.batch.synchronization
This class offers direct and efficient equality comparison of DataONE types without having to do any null & empty-string checking prior to the comparison.
D1TypeUtils() - Constructor for class org.dataone.cn.batch.synchronization.D1TypeUtils
 
DEFAULT_MAX_NODE_COMM_PER_MN - Static variable in class org.dataone.cn.batch.synchronization.NodeCommSyncObjectFactory
The default max number of NodeComms available for a given Member Node
DelayWrapper<T> - Class in org.dataone.cn.batch.synchronization.tasks
A wrapper class for objects that implements Delayed.
DelayWrapper(T) - Constructor for class org.dataone.cn.batch.synchronization.tasks.DelayWrapper
 
DelayWrapper(T, long) - Constructor for class org.dataone.cn.batch.synchronization.tasks.DelayWrapper
 
DistributedDataClient - Interface in org.dataone.cn.batch.synchronization.type
 
DistributedDataClient.ListenableMap<K,V> - Interface in org.dataone.cn.batch.synchronization.type
 

E

emptyEquals(Identifier, Identifier) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
Similar to equals, but treats a null object, null value-property, and empty string value-property as equal to each other.
emptyEquals(NodeReference, NodeReference) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
Similar to equals, but treats a null object, null value-property, and empty string value-property as equal to each other.
emptyEquals(ObjectFormatIdentifier, ObjectFormatIdentifier) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
Similar to equals, but treats a null object, null value-property, and empty string value-property as equal to each other.
emptyEquals(Subject, Subject) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
Similar to equals, but treats a null object, null value-property, and empty string value-property as equal to each other.
entryAdded(EntryEvent<String, String>) - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
listens to map entries so that the round robin can be expanded to include the new node entry.
entryEvicted(EntryEvent<String, String>) - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
 
entryRemoved(EntryEvent<String, String>) - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
 
entrySet() - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
entryUpdated(EntryEvent<String, String>) - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
 
equals(Identifier, Identifier) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
A null-safe equality test for two Identifiers.
equals(NodeReference, NodeReference) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
A null-safe equality test for two NodeReferences (null object and null object.getValue() are considered the equal)
equals(ObjectFormatIdentifier, ObjectFormatIdentifier) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
A null-safe equality test for two ObjectFormatIdentifiers (null object and null object.getValue() are considered the equal)
equals(Subject, Subject) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
A null-safe equality test for two Subjects.
equals(Object) - Method in class org.dataone.cn.batch.synchronization.tasks.DelayWrapper
 
execute(JobExecutionContext) - Method in class org.dataone.cn.batch.synchronization.jobs.MemberNodeHarvestJob
 
execute(JobExecutionContext) - Method in class org.dataone.cn.batch.synchronization.jobs.SyncMetricLogJob
 
extractRetryableException(ServiceFailure) - Static method in class org.dataone.cn.batch.synchronization.tasks.V2TransferObjectTask
This method is used to re-wrap the Exceptions that affect the processing of a TransferObjectTask, particularly various types of time out exceptions that we would want to retry instead of ending in SynchronizationFailed.

G

get(Object) - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
getCnCore() - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
getCnRead() - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
getCnReplication() - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
getDateLastHarvested(NodeReference) - Method in class org.dataone.cn.batch.service.v2.impl.NodeRegistrySyncServiceImpl
 
getDateLastHarvested(NodeReference) - Method in interface org.dataone.cn.batch.service.v2.NodeRegistrySyncService
 
getDateLastHarvested(NodeReference) - Method in class org.dataone.cn.ldap.NodeRegistrySyncFacade
 
getDelay() - Method in exception org.dataone.cn.batch.exceptions.RetryableException
 
getDelay(TimeUnit) - Method in class org.dataone.cn.batch.synchronization.tasks.DelayWrapper
 
getFullObjectList(NodeComm, Integer) - Method in class org.dataone.cn.batch.synchronization.tasks.ObjectListHarvestTask
get the set of timepoints and associated pids to put on the sync queue
getHarvestSchedulingManager() - Method in class org.dataone.cn.batch.synchronization.listener.NodeTopicListener
 
getHarvestSchedulingManager() - Method in class org.dataone.cn.batch.synchronization.SyncObjectTaskManager
 
getInstance() - Static method in class org.dataone.cn.batch.synchronization.NodeCommObjectListHarvestFactory
 
getInstance() - Static method in class org.dataone.cn.batch.synchronization.NodeCommSyncObjectFactory
 
getLegacyQueue() - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
A special accessor for the legacy queue to support synchronization metrics collection.
getLock(String) - Method in interface org.dataone.cn.batch.synchronization.type.DistributedDataClient
 
getMap(String) - Method in interface org.dataone.cn.batch.synchronization.type.DistributedDataClient
 
getMaxNumberOfClientsPerMemberNode() - Method in class org.dataone.cn.batch.synchronization.tasks.SyncObjectTask
 
getMnRead() - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
getName() - Method in class org.dataone.cn.batch.synchronization.listener.SyncMetricLogJobTriggerListener
 
getNextNodeId() - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
implements the Round Robin approach to reading from multiple queues It reads the first item of the queue, then cycles it to the end of the queue and returns that value.
getNode(NodeReference) - Method in class org.dataone.cn.batch.service.v2.impl.NodeRegistrySyncServiceImpl
 
getNode(NodeReference) - Method in interface org.dataone.cn.batch.service.v2.NodeRegistrySyncService
 
getNodeComm(NodeReference) - Method in interface org.dataone.cn.batch.synchronization.NodeCommFactory
 
getNodeComm(NodeReference) - Method in class org.dataone.cn.batch.synchronization.NodeCommObjectListHarvestFactory
 
getNodeComm(NodeReference) - Method in class org.dataone.cn.batch.synchronization.NodeCommSyncObjectFactory
returns a NodeComm set to the RUNNING state.
getNodeCommunicationsFactory() - Method in class org.dataone.cn.batch.synchronization.tasks.SyncObjectTask
 
getNodeRegistryService() - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
getNumber() - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
getQueue(String) - Method in interface org.dataone.cn.batch.synchronization.type.DistributedDataClient
 
getQueueNames() - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
builds a sorted set from the keys of the two queue maps
getReferenceSystemMetadata() - Method in class org.dataone.cn.batch.synchronization.type.SystemMetadataValidator
 
getReserveIdentifierService() - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
getRunningStartDate() - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
getScheduler() - Method in class org.dataone.cn.batch.synchronization.HarvestSchedulingManager
 
getSet(String) - Method in interface org.dataone.cn.batch.synchronization.type.DistributedDataClient
 
getState() - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
getSyncObjectTask() - Method in class org.dataone.cn.batch.synchronization.SyncObjectTaskManager
 
getTaskExecutor() - Method in class org.dataone.cn.batch.synchronization.SyncObjectTaskManager
 
getThreadPoolTaskExecutor() - Method in class org.dataone.cn.batch.synchronization.tasks.SyncObjectTask
 
getWrappedObject() - Method in class org.dataone.cn.batch.synchronization.tasks.DelayWrapper
 

H

halt() - Method in class org.dataone.cn.batch.synchronization.HarvestSchedulingManager
 
HarvestSchedulingManager - Class in org.dataone.cn.batch.synchronization
this bean must be managed by Spring upon startup of spring it will execute via init method evaluate whether the NodeList contains nodes that should be executed on the executing coordinating node.
HarvestSchedulingManager() - Constructor for class org.dataone.cn.batch.synchronization.HarvestSchedulingManager
 
hashCode() - Method in class org.dataone.cn.batch.synchronization.tasks.DelayWrapper
 
hasReservation(Session, Subject, Identifier) - Method in interface org.dataone.cn.batch.service.v2.IdentifierReservationQueryService
 
hasValidUpdates(SystemMetadata) - Method in class org.dataone.cn.batch.synchronization.type.SystemMetadataValidator
Compares the passed in SystemMetadata to the reference SystemMetadata to determine if the new SystemMetadata represents valid updates of the reference sysmeta.

I

IdentifierReservationQueryService - Interface in org.dataone.cn.batch.service.v2
 
inactivate - Variable in class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
 
init() - Method in class org.dataone.cn.batch.synchronization.HarvestSchedulingManager
 
init() - Method in class org.dataone.cn.batch.synchronization.SyncObjectTaskManager
 
isEmpty() - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
isInactivated() - Method in class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
override this method (and possibly setIsInactivated) to set the activation status by properties

K

keySet() - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 

L

latestResults - Variable in class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
 
listNodes() - Method in class org.dataone.cn.batch.service.v2.impl.NodeRegistrySyncServiceImpl
 
listNodes() - Method in interface org.dataone.cn.batch.service.v2.NodeRegistrySyncService
 

M

manageHarvest() - Method in class org.dataone.cn.batch.synchronization.HarvestSchedulingManager
will perform the recalculation of the scheduler.
map - Variable in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
MemberNodeHarvestJob - Class in org.dataone.cn.batch.synchronization.jobs
Quartz Job that starts off the hazelcast distributed execution of harvesting for a nodeList from a Membernode It executes only for a given membernode, and while executing excludes via a lock any other execution of a job on that membernode It also sets and persists the LastHarvested date on a node after completion before releasing the lock
MemberNodeHarvestJob() - Constructor for class org.dataone.cn.batch.synchronization.jobs.MemberNodeHarvestJob
 

N

NodeComm - Class in org.dataone.cn.batch.synchronization.type
Assemble and manage communication channels used by TransferObjectTask.
NodeComm(Object, NodeRegistrySyncService) - Constructor for class org.dataone.cn.batch.synchronization.type.NodeComm
 
NodeComm(Object, Object, NodeRegistrySyncService, CNCore, CNReplication, IdentifierReservationQueryService) - Constructor for class org.dataone.cn.batch.synchronization.type.NodeComm
 
NodeCommFactory - Interface in org.dataone.cn.batch.synchronization
Provides an interface for access to NodeComm objects that should be pooled for re-use.
NodeCommObjectListHarvestFactory - Class in org.dataone.cn.batch.synchronization
Creates a NodeComm (node communications) bundle for use by the ObjectListHarvestTask.
NodeCommState - Enum in org.dataone.cn.batch.synchronization.type
 
NodeCommSyncObjectFactory - Class in org.dataone.cn.batch.synchronization
Creates/maintains NodeComm pools (per MN NodeReference) for use by the TransferObjectTask.
NodeCommUnavailable - Exception in org.dataone.cn.batch.exceptions
 
NodeCommUnavailable(String) - Constructor for exception org.dataone.cn.batch.exceptions.NodeCommUnavailable
 
nodeIdRoundRobin - Variable in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
 
NodeRegistrySyncFacade - Class in org.dataone.cn.ldap
Extend the NodeFacade class in d1_cn_noderegistery to allow for synchronization specific behaviour Expose public access to protected methods in NodeAccess The public methods will also control the borrowing and returning of LDAPContexts to the LDAP Pool
NodeRegistrySyncFacade() - Constructor for class org.dataone.cn.ldap.NodeRegistrySyncFacade
 
NodeRegistrySyncService - Interface in org.dataone.cn.batch.service.v2
 
NodeRegistrySyncServiceImpl - Class in org.dataone.cn.batch.service.v2.impl
 
NodeRegistrySyncServiceImpl() - Constructor for class org.dataone.cn.batch.service.v2.impl.NodeRegistrySyncServiceImpl
 
NodeTopicListener - Class in org.dataone.cn.batch.synchronization.listener
Listen to the nodeTopic for any messages.
NodeTopicListener() - Constructor for class org.dataone.cn.batch.synchronization.listener.NodeTopicListener
 
notifyEntryListeners(String, K, V) - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
notifyEntryListeners(String, K, V) - Method in interface org.dataone.cn.batch.synchronization.type.DistributedDataClient.ListenableMap
 

O

ObjectListHarvestTask - Class in org.dataone.cn.batch.synchronization.tasks
An executable task that retrieve a list of ObjectInfos by calling listObject on a MN and then submits them on the SyncTaskQueue for processing.
ObjectListHarvestTask(NodeReference, Integer) - Constructor for class org.dataone.cn.batch.synchronization.tasks.ObjectListHarvestTask
Define the ObjectList Harvest task for a Member Node.
onMessage(Message<NodeReference>) - Method in class org.dataone.cn.batch.synchronization.listener.NodeTopicListener
 
org.dataone.cn.batch.exceptions - package org.dataone.cn.batch.exceptions
 
org.dataone.cn.batch.service.v2 - package org.dataone.cn.batch.service.v2
 
org.dataone.cn.batch.service.v2.impl - package org.dataone.cn.batch.service.v2.impl
 
org.dataone.cn.batch.synchronization - package org.dataone.cn.batch.synchronization
 
org.dataone.cn.batch.synchronization.jobs - package org.dataone.cn.batch.synchronization.jobs
 
org.dataone.cn.batch.synchronization.listener - package org.dataone.cn.batch.synchronization.listener
 
org.dataone.cn.batch.synchronization.tasks - package org.dataone.cn.batch.synchronization.tasks
 
org.dataone.cn.batch.synchronization.type - package org.dataone.cn.batch.synchronization.type
 
org.dataone.cn.ldap - package org.dataone.cn.ldap
 

P

pendingQueueItem - Variable in class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
 
poll(long, TimeUnit) - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
Returns the next SyncObject from one of the syncQueues, or null if none exist in any of the SyncQueues.
prepareTask(E) - Method in class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
builds the repeatable task
put(K, V) - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
putAll(Map<? extends K, ? extends V>) - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 

Q

queue - Variable in class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
 
QueueProcessorCallable<E,V> - Class in org.dataone.cn.batch.synchronization.tasks
A Callable for executing a Queue processing loop using a ThreadPoolTaskExecutor.
QueueProcessorCallable() - Constructor for class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
 

R

remove(Object) - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
reportSyncMetrics(SyncQueueFacade) - Method in class org.dataone.cn.batch.synchronization.tasks.SyncMetricLogReport
 
RetryableException - Exception in org.dataone.cn.batch.exceptions
An exception to capture cases where an internal failure in synchronization happened that warrants retrying the synchronization of the object in the near future.
RetryableException() - Constructor for exception org.dataone.cn.batch.exceptions.RetryableException
 
RetryableException(String) - Constructor for exception org.dataone.cn.batch.exceptions.RetryableException
 
RetryableException(String, Throwable) - Constructor for exception org.dataone.cn.batch.exceptions.RetryableException
 
RetryableException(String, Throwable, long) - Constructor for exception org.dataone.cn.batch.exceptions.RetryableException
 
run() - Method in class org.dataone.cn.batch.synchronization.SyncObjectTaskManager
Method to be called in a separately executing thread.

S

schemaValidateSystemMetadata(SystemMetadata) - Static method in class org.dataone.cn.batch.synchronization.type.SystemMetadataValidator
Makes sure the system metadata is valid against the schema.
serializedFormEquals(Object, Object) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
A null-safe equality test for two Dataone objects that bases the comparison on the equality of their serialized representations.
setApplicationContext(ApplicationContext) - Method in class org.dataone.cn.batch.synchronization.HarvestSchedulingManager
 
setCnCore(CNCore) - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
setCnRead(Object) - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
setCnReplication(CNReplication) - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
setDateLastHarvested(NodeReference, Date) - Method in class org.dataone.cn.batch.service.v2.impl.NodeRegistrySyncServiceImpl
 
setDateLastHarvested(NodeReference, Date) - Method in interface org.dataone.cn.batch.service.v2.NodeRegistrySyncService
 
setDateLastHarvested(NodeReference, Date) - Method in class org.dataone.cn.ldap.NodeRegistrySyncFacade
 
setDelay(long) - Method in exception org.dataone.cn.batch.exceptions.RetryableException
 
setHarvestSchedulingManager(HarvestSchedulingManager) - Method in class org.dataone.cn.batch.synchronization.listener.NodeTopicListener
 
setHarvestSchedulingManager(HarvestSchedulingManager) - Method in class org.dataone.cn.batch.synchronization.SyncObjectTaskManager
 
setIsInactivated(boolean) - Method in class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
Change the processing state of this instance
setMaxNumberOfClientsPerMemberNode(Integer) - Method in class org.dataone.cn.batch.synchronization.tasks.SyncObjectTask
 
setMnRead(Object) - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
setNodeCommunicationsFactory(NodeCommFactory) - Method in class org.dataone.cn.batch.synchronization.tasks.SyncObjectTask
 
setNodeRegistryService(NodeRegistrySyncService) - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
setNumber(Integer) - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
setQueue(Queue<E>) - Method in class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
 
setReserveIdentifierService(IdentifierReservationQueryService) - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
setRunningStartDate(Date) - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
setScheduler(Scheduler) - Method in class org.dataone.cn.batch.synchronization.HarvestSchedulingManager
 
setState(NodeCommState) - Method in class org.dataone.cn.batch.synchronization.type.NodeComm
 
setSyncObjectTask(SyncObjectTask) - Method in class org.dataone.cn.batch.synchronization.SyncObjectTaskManager
 
setTaskExecutor(SimpleAsyncTaskExecutor) - Method in class org.dataone.cn.batch.synchronization.SyncObjectTaskManager
 
setThreadPoolTaskExecutor(ThreadPoolTaskExecutor) - Method in class org.dataone.cn.batch.synchronization.tasks.QueueProcessorCallable
 
setThreadPoolTaskExecutor(ThreadPoolTaskExecutor) - Method in class org.dataone.cn.batch.synchronization.tasks.SyncObjectTask
 
size() - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
size() - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
Returns the total number of items in the sync queues
size(String) - Method in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
 
SortedHarvestTimepointMap - Class in org.dataone.cn.batch.synchronization.tasks
This class represents a high-level type for the items retrieved in a MemberNode harvest.
SortedHarvestTimepointMap(Date, Date, Integer) - Constructor for class org.dataone.cn.batch.synchronization.tasks.SortedHarvestTimepointMap
Constructor that accepts optional limits on what gets added
spoolToSynchronizationQueue(SortedHarvestTimepointMap, SyncQueueFacade, NodeRegistrySyncService, Integer) - Method in class org.dataone.cn.batch.synchronization.tasks.ObjectListHarvestTask
Submit the harvest to the sync queue, periodically updating the node's lastHarvestedDate (able to do this since the pids are already sorted)
submitSynchronizationFailed(String, String, BaseException) - Method in class org.dataone.cn.batch.synchronization.tasks.SyncFailedTask
 
submitSynchronizationFailed(SynchronizationFailed) - Method in class org.dataone.cn.batch.synchronization.tasks.SyncFailedTask
 
SyncFailedTask - Class in org.dataone.cn.batch.synchronization.tasks
This is a callable class to report back to the MN when a failure has occurred during synchronization.
SyncFailedTask(NodeComm, SyncObject) - Constructor for class org.dataone.cn.batch.synchronization.tasks.SyncFailedTask
 
synchronizationObjectQueue - Variable in class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
 
SyncMetricLogJob - Class in org.dataone.cn.batch.synchronization.jobs
Periodically report on synchronization statistics that can be calculated independently of other running job threads/tasks Runs as a Quartz Job
SyncMetricLogJob() - Constructor for class org.dataone.cn.batch.synchronization.jobs.SyncMetricLogJob
 
SyncMetricLogJobTriggerListener - Class in org.dataone.cn.batch.synchronization.listener
SyncMetricLogJob does not allow concurrent execution of jobs.
SyncMetricLogJobTriggerListener() - Constructor for class org.dataone.cn.batch.synchronization.listener.SyncMetricLogJobTriggerListener
 
SyncMetricLogReport - Class in org.dataone.cn.batch.synchronization.tasks
Create a Report of the number of tasks queued for processing per MemberNode and a total of tasks queued for the processor
SyncMetricLogReport() - Constructor for class org.dataone.cn.batch.synchronization.tasks.SyncMetricLogReport
 
SyncObjectState - Enum in org.dataone.cn.batch.synchronization.type
 
SyncObjectTask - Class in org.dataone.cn.batch.synchronization.tasks
Regulates the processing of the hzSyncObjectQueue by assigning SyncObjects to available resources (NodeComms), submitting FutureTasks to (SpringFramework) task executor, and managing task-related processing failures.
SyncObjectTask() - Constructor for class org.dataone.cn.batch.synchronization.tasks.SyncObjectTask
 
SyncObjectTaskManager - Class in org.dataone.cn.batch.synchronization
Manages the SyncObjectTask runnable class as a single daemon threaded executable.
SyncObjectTaskManager() - Constructor for class org.dataone.cn.batch.synchronization.SyncObjectTaskManager
 
SyncQueueFacade - Class in org.dataone.cn.batch.synchronization.type
A class to manage the particulars of adding and removing SyncObjects to the set of backing synchronization queues.
SyncQueueFacade() - Constructor for class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
A convenience constructor that implements HazelcastClient
SyncQueueFacade(DistributedDataClient) - Constructor for class org.dataone.cn.batch.synchronization.type.SyncQueueFacade
 
SystemMetadataValidator - Class in org.dataone.cn.batch.synchronization.type
This class contains methods for validating a SystemMetata instance against a reference systemMetadata instance (the one it intends to replace), and against its schema.
SystemMetadataValidator(SystemMetadata) - Constructor for class org.dataone.cn.batch.synchronization.type.SystemMetadataValidator
Creates a new instance of a SystemMetadataValidator with the reference SystemMetadata (the sysmeta to validate against) as the required parameter.

T

TransferObjectTask - Class in org.dataone.cn.batch.synchronization.tasks
Transfer an object from a MemberNode(MN) to a CoordinatingNode(CN).
TransferObjectTask(NodeComm, SyncObject) - Constructor for class org.dataone.cn.batch.synchronization.tasks.TransferObjectTask
 
triggerComplete(Trigger, JobExecutionContext, Trigger.CompletedExecutionInstruction) - Method in class org.dataone.cn.batch.synchronization.listener.SyncMetricLogJobTriggerListener
 
triggerFired(Trigger, JobExecutionContext) - Method in class org.dataone.cn.batch.synchronization.listener.SyncMetricLogJobTriggerListener
 
triggerMisfired(Trigger) - Method in class org.dataone.cn.batch.synchronization.listener.SyncMetricLogJobTriggerListener
 

U

UnrecoverableException - Exception in org.dataone.cn.batch.exceptions
An exception to capture cases where an internal failure in synchronization happens that was not due to issues with Member Node content.
UnrecoverableException(String) - Constructor for exception org.dataone.cn.batch.exceptions.UnrecoverableException
 
UnrecoverableException(String, Throwable) - Constructor for exception org.dataone.cn.batch.exceptions.UnrecoverableException
 

V

V2TransferObjectTask - Class in org.dataone.cn.batch.synchronization.tasks
Transfer an object from a MemberNode(MN) to a CoordinatingNode(CN).
V2TransferObjectTask(NodeComm, SyncObject) - Constructor for class org.dataone.cn.batch.synchronization.tasks.V2TransferObjectTask
 
validateCNRequiredNonNullFields(SystemMetadata) - Static method in class org.dataone.cn.batch.synchronization.type.SystemMetadataValidator
Checks to make sure that the properties that need to be set prior to initial synchronization are not null.
validateEssentialProperties(SystemMetadata, Object) - Method in class org.dataone.cn.batch.synchronization.type.SystemMetadataValidator
Validates the essential properties of the system metadata that determine whether or not the two are describing the same object.
valueEquals(Identifier, Identifier) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
Similar to equals method, but also returns true if one ID is null, and the other ID's value property is null.
valueEquals(NodeReference, NodeReference) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
Similar to equals method, but also returns true if one ID is null, and the other ID's value property is null.
valueEquals(ObjectFormatIdentifier, ObjectFormatIdentifier) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
Similar to equals method, but also returns true if one ID is null, and the other ID's value property is null.
valueEquals(Subject, Subject) - Static method in class org.dataone.cn.batch.synchronization.D1TypeUtils
Similar to equals method, but also returns true if one ID is null, and the other ID's value property is null.
valueOf(String) - Static method in enum org.dataone.cn.batch.synchronization.type.NodeCommState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.dataone.cn.batch.synchronization.type.SyncObjectState
Returns the enum constant of this type with the specified name.
values() - Method in class org.dataone.cn.batch.synchronization.type.AbstractListenableMapAdapter
 
values() - Static method in enum org.dataone.cn.batch.synchronization.type.NodeCommState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.dataone.cn.batch.synchronization.type.SyncObjectState
Returns an array containing the constants of this enum type, in the order they are declared.
vetoJobExecution(Trigger, JobExecutionContext) - Method in class org.dataone.cn.batch.synchronization.listener.SyncMetricLogJobTriggerListener
 
A B C D E G H I K L M N O P Q R S T U V 
Skip navigation links

Copyright © 2021. All rights reserved.