A C D E F G H I J K L M N O P Q R S T U V W Z 

A

ABNORMAL_TERMINATION - Static variable in interface ds.granules.scheduler.TaskLifecycleMetrics
 
abnormalOperationTermination(String, String) - Method in interface ds.granules.scheduler.TaskLifecycleObserver
Indicates that the task in question has terminated abnormally.
abnormalOperationTermination(String, String) - Method in class ds.granules.scheduler.TaskManagement
 
ABORT - Static variable in class ds.granules.exchange.DeploymentMessage
 
ABORTED - Static variable in interface ds.granules.scheduler.TaskLifecycleMetrics
 
abortTask(String, String) - Method in class ds.granules.operation.JobSubmission
Send an abort request for a specific task.
abortTask() - Method in interface ds.granules.scheduler.Controller
 
AbstractStreamEvent - Class in ds.granules.streaming.core.datatype
Abstracts out the boilerplate code from different data type implementations for Granules streaming API.
AbstractStreamEvent() - Constructor for class ds.granules.streaming.core.datatype.AbstractStreamEvent
 
addDataset(Dataset) - Method in interface ds.granules.dataset.DatasetCollection
Add a dataset to this collection.
addDataset(Dataset) - Method in class ds.granules.dataset.DatasetCollectionManagement
 
addDeploymentRequest(String, DeploymentMessage) - Method in class ds.granules.scheduler.Diagnostics
Add the deployment request associated with the task.
addFile(String, String) - Method in interface ds.granules.dataset.FileAccess
Deprecated.
Adds a file with the specified permission "r", "w" or "rw" to this dataset.
addFile(String, String) - Method in interface ds.granules.dataset.FileDataset
Adds a file with the specified permission "r", "w" or "rw" to this dataset.
addFile(String, String) - Method in class ds.granules.dataset.FileDatasetImpl
 
addFile(String, String) - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
addInputStream(Topic) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
addInputStream(Topic, String) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
addInputStream(Topic) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
addInputStream(Topic, String) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
addInputStream(Topic) - Method in interface ds.granules.dataset.StreamDataset
Add an input stream to this dataset.
addInputStream(Topic, String) - Method in interface ds.granules.dataset.StreamDataset
Add an input stream to the data set
addInputStream(String, int) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
addInputStream(String, int) - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Add an input stream to this dataset.
addInputStreams(Collection<Topic>) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
addInputStreams(Collection<Topic>) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
addInputStreams(Collection<Topic>) - Method in interface ds.granules.dataset.StreamDataset
Adds a set of input streams to this dataset.
addInputStreams(ConcurrentHashMap<String, Integer>) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
addInputStreams(ConcurrentHashMap<String, Integer>) - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Adds a set of input streams to this dataset.
addLink(String, String, String, int) - Method in class ds.granules.streaming.core.Job
Adds a link connecting two stream processors/sources.
addMap(Map) - Method in class ds.granules.operation.MapReduceBase
 
addMap(Map) - Method in interface ds.granules.operation.Reduce
Adds a Map that will be reduced.
addMapper(Map) - Method in class ds.granules.operation.MapReduceBase
This method is called on a Reduce, once it has been added to a Map using the Map.addReduce() method.
addNewConnection(String, int) - Method in interface ds.granules.communication.direct.ChannelConnector
 
addNewConnection(String, int) - Method in class ds.granules.communication.direct.netty.client.NettyChannelConnector
 
addNewConnection(String, int) - Method in class ds.granules.communication.direct.nio.client.NIOChannelConnector
 
addOutputStream(Topic) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
addOutputStream(Topic) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
addOutputStream(Topic) - Method in interface ds.granules.dataset.StreamDataset
Add an output stream to this dataset.
addOutputStream(String, int) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
addOutputStream(String, int) - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Add an output stream to this dataset.
addOutputStreams(Collection<Topic>) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
addOutputStreams(Collection<Topic>) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
addOutputStreams(Collection<Topic>) - Method in interface ds.granules.dataset.StreamDataset
Adds a set of output streams to this dataset.
addOutputStreams(ConcurrentHashMap<String, Integer>) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
addOutputStreams(ConcurrentHashMap<String, Integer>) - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Adds a set of output streams to this dataset.
addReduce(Reduce) - Method in interface ds.granules.operation.Map
Adds a Reduce for this particular Map.
addReduce(Reduce) - Method in class ds.granules.operation.MapReduceBase
 
addReducer(Reduce) - Method in class ds.granules.operation.MapReduceBase
This method is called on a Map, once it has been added to a Reduce using the Reduce.addMap() method.
addStreamConsumer(Topic, StreamBase) - Method in class ds.granules.streaming.core.StreamBase
 
addStreamProcessor(String, Class, int) - Method in class ds.granules.streaming.core.Job
Adds a new stream processing element to the job.
addStreamSource(String, Class, int) - Method in class ds.granules.streaming.core.Job
Adds a new stream source to the job.
addTask() - Method in interface ds.granules.scheduler.Controller
 
ADVERTISEMENT - Static variable in interface ds.granules.exchange.ExchangeType
 
allowInst - Static variable in class ds.granules.Granules
 
APP_LAYER_BUFF_SIZE - Static variable in class ds.granules.util.Constants
 
averageRateOfTaskArrivals() - Method in class ds.granules.scheduler.Diagnostics
 
averageTaskExecutionTime() - Method in interface ds.granules.scheduler.ResourceProfile
Retrieves the average execution time for a given task.

C

chainTo(UUID) - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
changeToExecuteContinuously() - Method in class ds.granules.operation.ExecutionProfileSetup
 
changeToExecuteFixedNumberOfTimes(int) - Method in class ds.granules.operation.ExecutionProfileSetup
 
changeToExecuteFixedNumberOfTimes(int) - Method in class ds.granules.operation.OperationBase
This is a protected method, which allows only the sub-classes of Operation to change the execution profile of the operation appropriately.
changeToExecuteOnce() - Method in class ds.granules.operation.ExecutionProfileSetup
 
changeToExecuteOnce() - Method in class ds.granules.operation.OperationBase
This is a protected method, which allows only the sub-classes of Operation to change the execution profile of the operation appropriately.
changeToExecutePeriodically(long) - Method in class ds.granules.operation.ExecutionProfileSetup
 
changeToExecutePeriodically(long) - Method in class ds.granules.operation.OperationBase
This is a protected method, which allows only the sub-classes of Operation to change the execution profile of the operation appropriately.
changeToExecuteWhenDataAvailable() - Method in class ds.granules.operation.ExecutionProfileSetup
 
changeToExecuteWhenDataAvailable() - Method in class ds.granules.operation.OperationBase
This is a protected method, which allows only the sub-classes of Operation to change the execution profile of the operation appropriately.
changeToStayAlive() - Method in class ds.granules.operation.ExecutionProfileSetup
 
changeToStayAlive() - Method in class ds.granules.operation.OperationBase
This is a protected method, which allows only the sub-classes of Operation to change the execution profile of the operation appropriately.
ChannelAcceptor - Class in ds.granules.communication.direct.nio.server
 
ChannelAcceptor(InetSocketAddress, int) - Constructor for class ds.granules.communication.direct.nio.server.ChannelAcceptor
 
channelActive(ChannelHandlerContext) - Method in class ds.granules.communication.direct.netty.server.ServerHandler
 
ChannelConnector - Interface in ds.granules.communication.direct
 
channelRead0(ChannelHandlerContext, byte[]) - Method in class ds.granules.communication.direct.netty.server.ServerHandler
 
ChannelReaderCallback - Interface in ds.granules.communication.direct
 
ChannelReaderDataHolder - Class in ds.granules.communication.direct.nio.server
 
ChannelReaderDataHolder() - Constructor for class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
ChannelToStreamDeMultiplexer - Class in ds.granules.communication.direct
DeMultiplexing data from a Channel to the appropriate Stream.
ChannelWriter - Interface in ds.granules.communication.direct
Any direct communication framework should implement this interface to perform communication with another node.
ChannelWriterCache - Class in ds.granules.communication.direct
Caches the ChannelWriterDataHolders.
ChannelWriterDataHolder - Class in ds.granules.communication.direct.nio.client
 
ChannelWriterDataHolder() - Constructor for class ds.granules.communication.direct.nio.client.ChannelWriterDataHolder
 
Checksum - Class in ds.granules.util
Provides convenience functions for dealing with MessageDigest algorithms.
Checksum() - Constructor for class ds.granules.util.Checksum
Initializes a new Checksum generator using the default SHA-1 algorithm.
Checksum(String) - Constructor for class ds.granules.util.Checksum
Initializes a new Checksum generator using the specified algorithm.
clearExternalLibraries() - Method in interface ds.granules.scheduler.LibraryManager
 
close() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
close() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
close() - Method in interface ds.granules.dataset.Dataset
Close access to this dataset.
close() - Method in class ds.granules.dataset.FileDatasetImpl
 
close() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
close() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
COMM_LAYER_LAUNCHER - Static variable in class ds.granules.util.Constants
 
CommFrameworkLauncher - Interface in ds.granules.communication
Launch the communication framework.
CommFrameworkLauncherFactory - Class in ds.granules.communication
Used to get the instances of appropriate framework launcher.
commitUpdates() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
commitUpdates() - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Commit any changes that have been made to the set of streams managed by this dataset.
COMMUNICATION_MODE - Static variable in class ds.granules.util.Constants
 
CommunicationsException - Exception in ds.granules.exception
This is an exception that is thrown when there are communications related problems that have been encountered.
CommunicationsException(String) - Constructor for exception ds.granules.exception.CommunicationsException
Constructs an CommunicationsException with the specified detail message.
CommunicationsException(String, Throwable) - Constructor for exception ds.granules.exception.CommunicationsException
Constructs an CommunicationsException with the specified detail message.
COMPLETE - Static variable in interface ds.granules.scheduler.TaskLifecycleMetrics
 
completedExecution(String, String, TaskLifecycleMetrics) - Method in class ds.granules.operation.InstanceDeployer
 
completedExecution(String, String, TaskLifecycleMetrics) - Method in interface ds.granules.operation.JobLifecycleObserver
This method is invoked when a task has completed execution either successfully or due to an abnormal termination or previously issued abort request.
completedSuccessfully(String, ProgressTracker) - Method in class ds.granules.operation.InstanceDeployer
 
completedSuccessfully(String, ProgressTracker) - Method in interface ds.granules.operation.JobLifecycleObserver
This method is invoked when all the constituent distributed tasks have finished executing successfully.
completedTask(String) - Method in class ds.granules.scheduler.Diagnostics
Process the completion of the task.
completedWithErrors(String, ProgressTracker) - Method in class ds.granules.operation.InstanceDeployer
 
completedWithErrors(String, ProgressTracker) - Method in interface ds.granules.operation.JobLifecycleObserver
This method is invoked when we have heard from all the sub-tasks, and one or more errors have been encountered in the execution of constituent tasks.
ConditionFlag - Interface in ds.granules.exchange
This interface outlines the status associated with various exchanges.
Constants - Class in ds.granules.util
Constants used in Granules code.
Constants() - Constructor for class ds.granules.util.Constants
 
Constants.PartitionSchemes - Class in ds.granules.util
 
Constants.PartitionSchemes() - Constructor for class ds.granules.util.Constants.PartitionSchemes
 
Controller - Interface in ds.granules.scheduler
This is an interface which snapshots functionalities that need to be supported for managing tasks and their constituent libraries.
convertByteArrayToLongArray(byte[]) - Method in class ds.granules.util.MarshallingUtil
Converts a byte[] into a long[]
convertLongArrayToByteArray(long[]) - Method in class ds.granules.util.MarshallingUtil
Converts a long[] into a byte[].
createConsumer(NBEventListener) - Method in class ds.granules.scheduler.StreamingService
Create an event consumer
createDatasetCollection() - Method in class ds.granules.dataset.DatasetFactory
Creates a dataset collection
createDenseIntColumn(int) - Method in class ds.granules.util.Matrix
 
createDenseIntRow() - Method in class ds.granules.util.Matrix
 
createDeploymentResponse(String, String, int, int, String) - Method in class ds.granules.exchange.ExchangeFactory
Creates a deployment response, to a previously issued request.
createDeploymentStatusOrAbortRequest(String, String, String, int) - Method in class ds.granules.exchange.ExchangeFactory
Creates a DeploymentMessage that is a request for either getting the STATUS or ABORTing a previously deployment operation.
createDepoymentRequest(String, Operation, String) - Method in class ds.granules.exchange.ExchangeFactory
Creates a deployment request based on the specified parameters.
createDirectory(ZooKeeper, String, byte[], CreateMode) - Static method in class ds.granules.util.ZooKeeperUtils
 
createdTask(String, TaskLifecycleMetrics) - Method in class ds.granules.scheduler.Diagnostics
Manage information about the newly created task.
createExecutionStatusRequest(String, String, String) - Method in class ds.granules.exchange.ExchangeFactory
Creates an ExecutionStatus REQUEST based on the specified parameters
createExecutionStatusResponse(String, String, int, String, TaskLifecycleMetrics, String) - Method in class ds.granules.exchange.ExchangeFactory
Creates an ExecutionStatus RESPONSE based on the specified parameters
createFileDataset(String, String) - Method in class ds.granules.dataset.DatasetFactory
Creates a file dataset based on the specified arguments.
createJobIdentifier() - Method in class ds.granules.operation.InstanceDeployer
Create a Job Identifier.
createJobIdentifier() - Method in class ds.granules.operation.JobSubmission
Creates a Job Identifier
createLegacyFileDataset(String, String) - Method in class ds.granules.dataset.DatasetFactory
Deprecated.
createProducer() - Method in class ds.granules.scheduler.StreamingService
Create a stream producer
createProfile(String, int) - Method in class ds.granules.scheduler.StreamingService
Create a profile based on the synopsisTypeString and the synopsis
createResourceDiscoveryRequest(int, String) - Method in class ds.granules.exchange.ExchangeFactory
Create a ResourceDiscovery request
createResourceDiscoveryResponse(int, String, ResourceMetrics, String) - Method in class ds.granules.exchange.ExchangeFactory
Creates a ResourceDiscovery response
createResult(String, boolean, boolean) - Method in class ds.granules.results.ResultsFactory
This method creates a Results object.
createResults(boolean, boolean) - Method in interface ds.granules.operation.MapReduce
Create the Results type to be used for reporting results produced as a result of the processing.
createResults(boolean, boolean) - Method in class ds.granules.operation.MapReduceBase
 
createSequenceInfo() - Method in interface ds.granules.results.Results
Create the sequencing information to be associated with this result.
createSequenceInfo() - Method in class ds.granules.results.ResultsWidget
 
createSequencingInfo() - Method in class ds.granules.results.ResultsFactory
Creates a sequencing info object.
createStreamDataset(String, String) - Method in class ds.granules.dataset.DatasetFactory
Creates a streaming dataset based on the specified arguments.
createStreamDataset() - Method in class ds.granules.dataset.DatasetFactory
 
createStreamingDataset(String, String) - Method in class ds.granules.dataset.DatasetFactory
Deprecated.

D

DataAvailabilityNotifier - Interface in ds.granules.dataset
This is a notifier that keeps track of when data is available on a given dataset and then proceeds to notify the availability of the data to the registered observers.
DataAvailabilityObserver - Interface in ds.granules.dataset
This is the interface which allows an observer to track the availability of a dataset.
dataAvailable(String) - Method in class ds.granules.dataset.DatasetNotifier
Called by the dataset as soon as additional data is available.
DataLengthEncoder - Class in ds.granules.communication.direct.netty.client
 
DataLengthEncoder() - Constructor for class ds.granules.communication.direct.netty.client.DataLengthEncoder
 
Dataset - Interface in ds.granules.dataset
The interface outlines the core functionalities that need to be supported within datasets.
Dataset.DatasetType - Enum in ds.granules.dataset
 
datasetClosure(String) - Method in class ds.granules.dataset.DatasetNotifier
Called by the dataset, just before it is ready to close down.
DatasetCollection - Interface in ds.granules.dataset
The DataCollection interface manages a collection of datasets that would be operated upon by an application instance.
DatasetCollectionManagement - Class in ds.granules.dataset
This is an implementation of the DataCollection Interface.
DatasetCollectionManagement() - Constructor for class ds.granules.dataset.DatasetCollectionManagement
 
DatasetCollectionManagement(FormatReader) - Constructor for class ds.granules.dataset.DatasetCollectionManagement
 
DatasetCollectionObserver - Interface in ds.granules.dataset
The observer interface for the DatasetCollection.
DatasetException - Exception in ds.granules.dataset
The DatasetException is thrown when problems are encountered with the dataset.
DatasetException() - Constructor for exception ds.granules.dataset.DatasetException
Constructs an DatasetException with no detail message.
DatasetException(String) - Constructor for exception ds.granules.dataset.DatasetException
Constructs an DatasetException with the specified detail message.
DatasetException(String, Throwable) - Constructor for exception ds.granules.dataset.DatasetException
Constructs an DatasetException with the specified detail message.
DatasetFactory - Class in ds.granules.dataset
A factory for creating different types of datasets.
DatasetFactory() - Constructor for class ds.granules.dataset.DatasetFactory
 
DatasetNotifier - Class in ds.granules.dataset
This is a class which implements the DataAvailabilityNotifier interface.
DatasetNotifier(String, String) - Constructor for class ds.granules.dataset.DatasetNotifier
 
declareOutputStreams() - Method in class ds.granules.streaming.core.StreamBase
The classes that extend StreamProcessor and StreamSource should implement this method in order to declare output streams.
declareStream(String, String) - Method in class ds.granules.streaming.core.StreamBase
Declare an output stream from the Stream operator.
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class ds.granules.communication.direct.netty.server.MessageReceiver
 
defaultOutputStream - Variable in class ds.granules.operation.MapReduceBase
 
DEPLOY - Static variable in class ds.granules.exchange.DeploymentMessage
 
deploy(Operation[], int, String, JobLifecycleObserver) - Method in class ds.granules.operation.JobSubmission
 
deploy() - Method in class ds.granules.streaming.core.Job
Deploy the current job in the Granules runtime.
Deployer - Interface in ds.granules.operation
 
DEPLOYMENT - Static variable in interface ds.granules.exchange.ExchangeType
 
DeploymentException - Exception in ds.granules.exception
This is an exception that is thrown when there are problems in deployment-related actions that are initiated on operations.
DeploymentException() - Constructor for exception ds.granules.exception.DeploymentException
Constructs an DeploymentException with no detail message.
DeploymentException(String) - Constructor for exception ds.granules.exception.DeploymentException
Constructs an DeploymentException with the specified detail message.
DeploymentException(String, Throwable) - Constructor for exception ds.granules.exception.DeploymentException
 
DeploymentMessage - Class in ds.granules.exchange
This class encapsulates the exchanges related to the deployment of an application instance.
DeploymentMessage() - Constructor for class ds.granules.exchange.DeploymentMessage
The null constructor for the DeploymnetMessage
DeploymentMessage(String, Operation, String) - Constructor for class ds.granules.exchange.DeploymentMessage
Creates a deployment message based on the specified parameters.
DeploymentMessage(String, String, String, int) - Constructor for class ds.granules.exchange.DeploymentMessage
Creates a DeploymentMessage that is a request for either getting the STATUS or ABORTing a previously deployment operation.
DeploymentMessage(String, String, int, int, String) - Constructor for class ds.granules.exchange.DeploymentMessage
Creates a deployment response, to a previously issued request.
deployOperations(Operation[]) - Method in class ds.granules.communication.direct.JobDeployer
 
deployOperations(Operation[]) - Method in interface ds.granules.operation.Deployer
 
deployOperations(Operation[]) - Method in class ds.granules.operation.InstanceDeployer
This method deploys a set of operations on a specified number of resources.
deployOperations(Operation[], String) - Method in class ds.granules.operation.InstanceDeployer
This method deploys a set of operations on the set of available resources.
deployOperations(Operation[], int, String) - Method in class ds.granules.operation.InstanceDeployer
This method deploys a set of operations on a specified number of resources.
deregisterDataAvailabilityObserver(DataAvailabilityObserver) - Method in interface ds.granules.dataset.DataAvailabilityNotifier
Deregisters a data availability observer
deregisterDataAvailabilityObserver(DataAvailabilityObserver) - Method in class ds.granules.dataset.DatasetNotifier
 
DIAGNOSTIC - Static variable in interface ds.granules.exchange.ExchangeType
 
Diagnostics - Class in ds.granules.scheduler
This class keeps track of various diagnostic-related elements.
Diagnostics(String, int) - Constructor for class ds.granules.scheduler.Diagnostics
 
DIRECT_COMM_IMPL - Static variable in class ds.granules.util.Constants
 
DIRECT_COMM_IMPL_NETTY - Static variable in class ds.granules.util.Constants
 
DIRECT_COMM_IMPL_NIO - Static variable in class ds.granules.util.Constants
 
DIRECT_COMM_LISTENER_PORT - Static variable in class ds.granules.util.Constants
 
DirectCommFrameworkLauncher - Class in ds.granules.communication.direct
 
DirectCommFrameworkLauncher() - Constructor for class ds.granules.communication.direct.DirectCommFrameworkLauncher
 
DirectCommStreamDatasetImpl - Class in ds.granules.communication.direct
StreamDataset implementation for NIO based direct communication.
DirectCommStreamDatasetImpl() - Constructor for class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
DirectivesException - Exception in ds.granules.exception
This is an exception that is thrown when there are problems enforcing the directives associated with an application instance.
DirectivesException() - Constructor for exception ds.granules.exception.DirectivesException
Constructs an DirectivesException with no detail message.
DirectivesException(String) - Constructor for exception ds.granules.exception.DirectivesException
Constructs an DirectivesException with the specified detail message.
discoverResource() - Method in class ds.granules.operation.JobSubmission
Discovers the available computational resources.
discoverResource(int) - Method in class ds.granules.operation.JobSubmission
Discovers the available computational resources.
dispatch(byte[]) - Method in class ds.granules.communication.direct.ChannelToStreamDeMultiplexer
 
dispose() - Method in interface ds.granules.operation.Operation
Reclaim resources if any prior to exiting ...
dispose() - Method in class ds.granules.operation.OperationBase
 
DOUBLE - Static variable in class ds.granules.results.ResultPayload
 
DOUBLE_2D_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
DOUBLE_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
ds.granules - package ds.granules
 
ds.granules.communication - package ds.granules.communication
 
ds.granules.communication.direct - package ds.granules.communication.direct
 
ds.granules.communication.direct.netty.client - package ds.granules.communication.direct.netty.client
 
ds.granules.communication.direct.netty.server - package ds.granules.communication.direct.netty.server
 
ds.granules.communication.direct.nio.client - package ds.granules.communication.direct.nio.client
 
ds.granules.communication.direct.nio.server - package ds.granules.communication.direct.nio.server
 
ds.granules.communication.direct.util - package ds.granules.communication.direct.util
 
ds.granules.communication.funnel - package ds.granules.communication.funnel
 
ds.granules.dataset - package ds.granules.dataset
This package contains functionality related to datasets that deployed application instances need to operate on.
ds.granules.exception - package ds.granules.exception
This package contains exceptions that are used across multiple packages within the project.
ds.granules.exchange - package ds.granules.exchange
This package contains classes related to processing exchanges.
ds.granules.operation - package ds.granules.operation
This package encapsulates functionality related to application instances that will be deployed on the cloud.
ds.granules.results - package ds.granules.results
Functionality for processing results generated by application instances.
ds.granules.scheduler - package ds.granules.scheduler
This package contains functionality related to scheduling the application instances.
ds.granules.streaming.core - package ds.granules.streaming.core
 
ds.granules.streaming.core.datatype - package ds.granules.streaming.core.datatype
 
ds.granules.streaming.core.exception - package ds.granules.streaming.core.exception
 
ds.granules.streaming.core.partition - package ds.granules.streaming.core.partition
 
ds.granules.streaming.core.partition.scheme - package ds.granules.streaming.core.partition.scheme
 
ds.granules.util - package ds.granules.util
This package contains utility classes used by several components.

E

emit() - Method in class ds.granules.streaming.core.StreamSource
Emit the next tuple.
ENABLE_APP_LEVEL_BUFFERING - Static variable in class ds.granules.util.Constants
 
encode(ChannelHandlerContext, byte[], ByteBuf) - Method in class ds.granules.communication.direct.netty.client.DataLengthEncoder
 
equals(Object) - Method in class ds.granules.scheduler.ExecutableTask
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class ds.granules.communication.direct.netty.server.ServerHandler
 
Exchange - Class in ds.granules.exchange
This is the base class for exchanges.
Exchange() - Constructor for class ds.granules.exchange.Exchange
 
ExchangeFactory - Class in ds.granules.exchange
This is a singleton class which encapsulates functionality related to creation and reconstructing various exchanges.
ExchangeFactory() - Constructor for class ds.granules.exchange.ExchangeFactory
 
ExchangeProcessor - Class in ds.granules.scheduler
This is a class which is reponsible for processing various exchanges related to the deployment, discovery and advertisement of application instances and resources.
ExchangeProcessor(Diagnostics, String, int) - Constructor for class ds.granules.scheduler.ExchangeProcessor
 
ExchangeType - Interface in ds.granules.exchange
This is an interface which outlines the different types of exchanges that are currently supported.
ExecutableTask - Class in ds.granules.scheduler
This is an executable task, which manages the execution of the operation.
ExecutableTask(String, Operation, TaskLifecycleObserver) - Constructor for class ds.granules.scheduler.ExecutableTask
 
execute() - Method in interface ds.granules.operation.Operation
Execute the operation.
execute() - Method in class ds.granules.operation.OperationBase
 
execute() - Method in class ds.granules.streaming.core.StreamProcessor
 
execute() - Method in class ds.granules.streaming.core.StreamSource
 
executeCommand(String, String[], File, boolean) - Method in class ds.granules.util.SystemCommand
This method executes a system command based on the specified parameter.
EXECUTING - Static variable in interface ds.granules.exchange.ConditionFlag
 
executing - Variable in class ds.granules.scheduler.ExecutableTask
 
EXECUTING - Static variable in interface ds.granules.scheduler.TaskLifecycleMetrics
 
EXECUTION_STATUS - Static variable in interface ds.granules.exchange.ExchangeType
 
ExecutionProfile - Interface in ds.granules.operation
This interfaces encapsulates the execution profile of the operation.
ExecutionProfileSetup - Class in ds.granules.operation
Implements the ExecutionProfile.
ExecutionProfileSetup(String) - Constructor for class ds.granules.operation.ExecutionProfileSetup
 
ExecutionProfileSetup(byte[]) - Constructor for class ds.granules.operation.ExecutionProfileSetup
 
ExecutionStatus - Class in ds.granules.exchange
This class encapsulates exchanges related to retrieving the status of a message.
ExecutionStatus() - Constructor for class ds.granules.exchange.ExecutionStatus
 
ExecutionStatus(String, String, String) - Constructor for class ds.granules.exchange.ExecutionStatus
 
ExecutionStatus(String, String, int, String, TaskLifecycleMetrics, String) - Constructor for class ds.granules.exchange.ExecutionStatus
 
expectedBeginTime() - Method in interface ds.granules.scheduler.ResourceProfile
Retrieves the expect starting time for a given task's execution.

F

FAILURE - Static variable in interface ds.granules.exchange.ConditionFlag
 
FieldPartitioner - Class in ds.granules.streaming.core.partition.scheme
Partitioner implementation for partitioning based on a key.
FieldPartitioner() - Constructor for class ds.granules.streaming.core.partition.scheme.FieldPartitioner
 
FileAccess - Interface in ds.granules.dataset
Deprecated.
FileDataset - Interface in ds.granules.dataset
The interface for accessing a dataset comprising files.
FileDatasetImpl - Class in ds.granules.dataset
An implementation of the FileAccess dataset interface.
FileDatasetImpl(String, String) - Constructor for class ds.granules.dataset.FileDatasetImpl
 
FileDatasetImpl(FormatReader) - Constructor for class ds.granules.dataset.FileDatasetImpl
 
FileDatasetImplLegacy - Class in ds.granules.dataset
Deprecated.
FileDatasetImplLegacy(String, String) - Constructor for class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
FileDatasetImplLegacy(FormatReader) - Constructor for class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
FLOAT - Static variable in class ds.granules.results.ResultPayload
 
FLOAT_2D_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
FLOAT_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
FUNNEL_BOOTSTRAP_ENV_VAR - Static variable in class ds.granules.util.Constants
 
FunnelLauncher - Class in ds.granules.communication.funnel
 
FunnelLauncher() - Constructor for class ds.granules.communication.funnel.FunnelLauncher
 
FunnelStreamDatasetImpl - Class in ds.granules.communication.funnel
This class is a streaming implementation of the dataset.
FunnelStreamDatasetImpl() - Constructor for class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
FunnelStreamDatasetImpl(String, String) - Constructor for class ds.granules.communication.funnel.FunnelStreamDatasetImpl
Share the instance of the client service, so that multiple connections are not created to the same broker.

G

generateNameBasedUUID() - Method in class ds.granules.util.UUIDRetriever
 
generateRandomBasedUUID() - Method in class ds.granules.util.UUIDRetriever
 
generateTimeBasedUUID() - Method in class ds.granules.util.UUIDRetriever
 
getArrivalTime() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getArrivalTime() - Method in class ds.granules.exchange.TaskLifecycleMetricsReader
 
getArrivalTime() - Method in interface ds.granules.scheduler.TaskLifecycleMetrics
Retrieve the time at which the operation arrived at this node.
getAwaitingOutputsFrom() - Method in class ds.granules.operation.MapReduceBase
 
getAwaitingOutputsFrom() - Method in interface ds.granules.operation.Reduce
Retrieves the set of Map identifiers from which an Output has not been received so far.
getByteBuffer() - Method in class ds.granules.communication.direct.nio.client.ChannelWriterDataHolder
 
getBytes() - Method in class ds.granules.exchange.Exchange
Retrieve the byte[] representation of the exchange.
getBytes() - Method in class ds.granules.exchange.TaskLifecycleMetricsReader
 
getBytes() - Method in class ds.granules.operation.ExecutionProfileSetup
 
getBytes(int) - Method in class ds.granules.results.ResultPayload
This method converts an int into a byte[].
getBytes(short) - Method in class ds.granules.results.ResultPayload
This method converts a short into a byte[].
getBytes(long) - Method in class ds.granules.results.ResultPayload
This method converts a long into a byte[].
getBytes(double) - Method in class ds.granules.results.ResultPayload
This method converts a double into a byte[].
getBytes(float) - Method in class ds.granules.results.ResultPayload
This method converts a float into a byte[].
getBytes(String) - Method in class ds.granules.results.ResultPayload
This method converts a String into a byte[].
getBytes(int[]) - Method in class ds.granules.results.ResultPayload
This method converts an int[] into a byte[].
getBytes(short[]) - Method in class ds.granules.results.ResultPayload
This method converts a short[] into a byte[].
getBytes(long[]) - Method in class ds.granules.results.ResultPayload
This method converts a long[] into a byte[].
getBytes(double[]) - Method in class ds.granules.results.ResultPayload
This method converts a double[] into a byte[].
getBytes(float[]) - Method in class ds.granules.results.ResultPayload
This method converts a float[] into a byte[].
getBytes(String[]) - Method in class ds.granules.results.ResultPayload
This method converts a String[] into a byte[].
getBytes(Hashtable<?, ?>) - Method in class ds.granules.results.ResultPayload
This method converts a Hashtable into a byte[].
getBytes(HashMap<?, ?>) - Method in class ds.granules.results.ResultPayload
This method converts a HashMap into a byte[].
getBytes(int[][]) - Method in class ds.granules.results.ResultPayload
This method converts a int[][] into a byte[].
getBytes(short[][]) - Method in class ds.granules.results.ResultPayload
This method converts a short[][] into a byte[].
getBytes(long[][]) - Method in class ds.granules.results.ResultPayload
This method converts a long[][] into a byte[].
getBytes(double[][]) - Method in class ds.granules.results.ResultPayload
This method converts a double[][] into a byte[] .
getBytes(float[][]) - Method in class ds.granules.results.ResultPayload
This method converts a float[][] into a byte[].
getBytes(Object[]) - Method in class ds.granules.results.ResultPayload
This method converts an Object[] into a byte[].
getBytes() - Method in interface ds.granules.results.Results
Marshall the result as a set of bytes
getBytes() - Method in class ds.granules.results.ResultsWidget
Deprecated.
getBytes() - Method in class ds.granules.scheduler.ResourceMetrics
 
getBytes() - Method in interface ds.granules.scheduler.TaskLifecycleMetrics
Create the serialized representation of this class.
getChannelWriter(String) - Method in class ds.granules.communication.direct.ChannelWriterCache
 
getChildDirectories(ZooKeeper, String) - Static method in class ds.granules.util.ZooKeeperUtils
 
getClassName() - Method in class ds.granules.exchange.DeploymentMessage
 
getCompletionStatus(String) - Method in interface ds.granules.operation.ProgressTracker
Retrieve the completion status for a specific taskIdentifier
getCompletionStatus(String) - Method in class ds.granules.operation.ProgressTrackerWidget
 
getCompletionTime() - Method in class ds.granules.exchange.TaskLifecycleMetricsReader
 
getCompletionTime() - Method in interface ds.granules.scheduler.TaskLifecycleMetrics
Retrieve the time at which this task was completed
getConditionFlag() - Method in class ds.granules.exchange.Exchange
 
getContentType() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getCPUBoundTime() - Method in class ds.granules.exchange.TaskLifecycleMetricsReader
 
getCPUBoundTime() - Method in interface ds.granules.scheduler.TaskLifecycleMetrics
Retrieve the CPU-bound time of the computation.
getCurrentMessage() - Method in class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
getDataAvailabilityNotifier() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
getDataAvailabilityNotifier() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
getDataAvailabilityNotifier() - Method in interface ds.granules.dataset.Dataset
Retrieve the data availability notifier for this dataset.
getDataAvailabilityNotifier() - Method in class ds.granules.dataset.FileDatasetImpl
 
getDataAvailabilityNotifier() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
getDataAvailabilityNotifier() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
getDataBuffer() - Method in class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
getDataBytes() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getDataReader() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getDataset(String) - Method in interface ds.granules.dataset.DatasetCollection
Retrieve a specific dataset
getDataset(String) - Method in class ds.granules.dataset.DatasetCollectionManagement
 
getDataset(FormatReader) - Method in class ds.granules.dataset.DatasetFactory
Reconstructs the dataset from a set of bytes
getDatasetCollection(FormatReader) - Method in class ds.granules.dataset.DatasetFactory
Reconstruct the dataset collection from a byte[].
getDatasetCollection() - Method in class ds.granules.operation.MapReduceBase
 
getDatasetCollection() - Method in interface ds.granules.operation.Operation
Retrieve the dataset that is associated with this particular operation.
getDatasetCollection() - Method in class ds.granules.operation.OperationBase
 
getDatasetFactory() - Static method in class ds.granules.Granules
Obtain the DatasetFactory instance in this scope.
getDatasetIdentifier() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
getDatasetIdentifier() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
getDatasetIdentifier() - Method in interface ds.granules.dataset.DataAvailabilityNotifier
Indicates the dataset being reported on
getDatasetIdentifier() - Method in interface ds.granules.dataset.Dataset
Retrieve the identifier for this dataset.
getDatasetIdentifier() - Method in class ds.granules.dataset.DatasetNotifier
 
getDatasetIdentifier() - Method in class ds.granules.dataset.FileDatasetImpl
 
getDatasetIdentifier() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
getDatasetIdentifier() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
getDatasetIdentifier() - Method in class ds.granules.streaming.core.StreamBase
 
getDatasets() - Method in interface ds.granules.dataset.DatasetCollection
Retrieve an iterator to iterate over the datasets.
getDatasets() - Method in class ds.granules.dataset.DatasetCollectionManagement
 
getDatasetType() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
getDatasetType() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
getDatasetType() - Method in interface ds.granules.dataset.Dataset
Retrieve the type of the data set
getDatasetType() - Method in class ds.granules.dataset.FileDatasetImpl
 
getDatasetType() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
getDatasetType() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
getDataSize() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getDefaultStreamDataset() - Method in class ds.granules.streaming.core.StreamBase
 
getDeploymentMessage(byte[]) - Method in class ds.granules.exchange.ExchangeFactory
Reconstructs the Deployment Message from a stream of bytes
getDeploymentStream(String) - Method in interface ds.granules.operation.ProgressTracker
Retrieve the deployment stream associated with a given task.
getDeploymentStream(String) - Method in class ds.granules.operation.ProgressTrackerWidget
 
getDeploymentStream() - Method in class ds.granules.scheduler.ResourceMetrics
 
getDescription() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
getDescription() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
getDescription() - Method in interface ds.granules.dataset.Dataset
Retrieve a description of the dataset
getDescription() - Method in class ds.granules.dataset.FileDatasetImpl
 
getDescription() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
getDescription() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
getDescription() - Method in class ds.granules.exchange.Exchange
Retrieve the description associated with this exchange.
getDests() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getDiagnostics() - Method in class ds.granules.scheduler.Resource
Provides diagnostic information for this Resource.
getDomain() - Method in interface ds.granules.operation.Operation
Get information about the domain for this operation
getDomain() - Method in class ds.granules.operation.OperationBase
 
getDouble(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a double.
getDouble2DArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a double[][] .
getDoubleArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a double[].
getEntriesType() - Method in class ds.granules.util.Matrix
 
getExchangeFactory() - Static method in class ds.granules.Granules
Obtain the ExchangeFactory instance in this scope.
getExchangeProcessor() - Method in class ds.granules.scheduler.Resource
 
getExchangeSubType() - Method in class ds.granules.exchange.Exchange
 
getExchangeType() - Method in class ds.granules.exchange.Exchange
 
getExchangeType(byte[]) - Method in class ds.granules.exchange.ExchangeFactory
Retrieves the exchange type information from a stream of bytes.
getExecutionInterval() - Method in interface ds.granules.operation.ExecutionProfile
Retrieve the execution interval.
getExecutionInterval() - Method in class ds.granules.operation.ExecutionProfileSetup
 
getExecutionInterval() - Method in class ds.granules.scheduler.ExecutableTask
For a task that needs to be executed periodically, this method is used to retrieve the interval at which the task needs to be executed periodically.
getExecutionProfile() - Method in interface ds.granules.operation.Operation
Retrieve the execution profile associated with this operation
getExecutionProfile() - Method in class ds.granules.operation.OperationBase
 
getExecutionStatus(byte[]) - Method in class ds.granules.exchange.ExchangeFactory
Reconstruct the execution status object from a byte[].
getExecutionStatus() - Method in class ds.granules.exchange.TaskLifecycleMetricsReader
 
getExecutionStatus() - Method in interface ds.granules.scheduler.TaskLifecycleMetrics
Retrieve the execution status associated with the operation.
getFilenames() - Method in interface ds.granules.dataset.FileAccess
Deprecated.
Retrieves the list of files in this dataset
getFilenames() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
getFiles() - Method in interface ds.granules.dataset.FileDataset
Retrieves the list of files in this dataset.
getFiles() - Method in class ds.granules.dataset.FileDatasetImpl
 
getFloat(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a float.
getFloat2DArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a float[][].
getFloatArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a float[].
getFrameworkLauncher(Properties) - Method in class ds.granules.communication.CommFrameworkLauncherFactory
Get an instance of the framework launcher
getFreeMemory() - Method in class ds.granules.scheduler.ResourceMetrics
Retrieve the available free memory in MB.
getHashMap(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a HashMap.
getHashtable(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a Hashtable.
getHops() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getHostInetAddress() - Method in class ds.granules.communication.direct.DirectCommFrameworkLauncher
 
getIdentifier() - Method in interface ds.granules.dataset.DataAvailabilityObserver
This retrieves the identifier associated with the observer.
getIdentifier() - Method in class ds.granules.dataset.DatasetCollectionManagement
 
getIdentifier() - Method in class ds.granules.exchange.Exchange
 
getIdentifier() - Method in interface ds.granules.operation.ProgressTracker
Retrieve the Job identifier
getIdentifier() - Method in class ds.granules.operation.ProgressTrackerWidget
 
getIdentifier() - Method in class ds.granules.scheduler.ExecutableTask
Retrieve the identifier for the executable task
getInitialDelayForPeriodicTask() - Method in class ds.granules.scheduler.ExecutableTask
This method returns the time at which the periodic task will execute for the first time.
getInitializationDirectives() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
getInputStreams() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
getInputStreams() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
getInputStreams() - Method in interface ds.granules.dataset.StreamDataset
Retrieve a collection of the constituent input streams.
getInputStreams() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
getInputStreams() - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Retrieve a HashMap of the constituent input streams.
getInstance() - Static method in class ds.granules.communication.CommFrameworkLauncherFactory
 
getInstance() - Static method in class ds.granules.communication.direct.ChannelToStreamDeMultiplexer
 
getInstance() - Static method in class ds.granules.communication.direct.ChannelWriterCache
 
getInstance() - Static method in class ds.granules.communication.direct.JobDeployer
 
getInstance(String) - Static method in class ds.granules.communication.direct.util.StatCollector
 
getInstance() - Static method in class ds.granules.communication.direct.ZooKeeperAgent
 
getInstance() - Static method in class ds.granules.dataset.DatasetFactory
Deprecated.
getInstance() - Static method in class ds.granules.exchange.ExchangeFactory
Deprecated.
getInstance() - Static method in class ds.granules.operation.JobSubmission
Deprecated.
getInstance() - Static method in class ds.granules.results.ResultPayload
Deprecated.
getInstance() - Static method in class ds.granules.results.ResultsFactory
Deprecated.
getInstance() - Static method in class ds.granules.scheduler.Resource
Retrieves singleton instance of the Resource.
getInstance() - Static method in class ds.granules.scheduler.StreamingService
Get an instance of the StreamingService
getInstance() - Static method in class ds.granules.streaming.core.partition.PartitionerFactory
 
getInstance(int) - Method in class ds.granules.streaming.core.partition.PartitionerFactory
 
getInstance() - Static method in class ds.granules.util.GranulesStaticConfig
 
getInstance() - Static method in class ds.granules.util.MarshallingUtil
Deprecated.
getInstance() - Static method in class ds.granules.util.MatrixFactory
Deprecated.
getInstance() - Static method in class ds.granules.util.ParamsReader
Deprecated.
getInstance() - Static method in class ds.granules.util.UUIDRetriever
Deprecated.
getInstanceIdentifier() - Method in class ds.granules.exchange.TaskLifecycleMetricsReader
 
getInstanceIdentifier() - Method in interface ds.granules.operation.Operation
Retrieve the instance identifier for this operation.
getInstanceIdentifier() - Method in class ds.granules.operation.OperationBase
 
getInstanceIdentifier() - Method in interface ds.granules.results.Results
Retrieve the instance identifier of the application instance that has generated the result(s).
getInstanceIdentifier() - Method in class ds.granules.results.ResultsWidget
 
getInstanceIdentifier() - Method in interface ds.granules.scheduler.TaskLifecycleMetrics
Retrieve the instance identifier of the operation that was encapsulated within a Task.
getInstanceIdentifier(String) - Static method in class ds.granules.streaming.core.StreamUtil
Returns an instance identifier when creating a group of objects of the same type but used as a cluster E.g.: Multiple instances of a Stream Processor can be named as processor-1, processor-2, etc.
getInt(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into an int.
getInt(byte[], int) - Method in class ds.granules.util.MarshallingUtil
Given a sequence of bytes, this method returns the int value associated with the sequence of bytes.
getInt2DArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a int[][].
getIntArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into an int[].
getJobIdentifier() - Method in class ds.granules.exchange.DeploymentMessage
 
getJobIdentifier() - Method in class ds.granules.exchange.ExecutionStatus
 
getJobSubmission() - Static method in class ds.granules.Granules
Obtain the JobSubmission instance in this scope.
getLastHop() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getLastModificationTime() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
getLastModificationTime() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
getLastModificationTime() - Method in interface ds.granules.dataset.Dataset
Retrieve the last update to this dataset
getLastModificationTime() - Method in class ds.granules.dataset.FileDatasetImpl
 
getLastModificationTime() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
getLastModificationTime() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
getListOfJobs() - Method in class ds.granules.operation.JobSubmission
Get the complete list of jobs that have been submitted from this node.
getLong(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a long.
getLong2DArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a long[][].
getLongArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a long[].
getLower() - Method in interface ds.granules.results.SequencingInfo
Retrieve the lower-bound of the specified range.
getLower() - Method in class ds.granules.results.SequencingWidget
 
getMapIdentifiers() - Method in class ds.granules.operation.MapReduceBase
 
getMapIdentifiers() - Method in interface ds.granules.operation.Reduce
Retrieves the set of Map identifiers
getMapReduceDataset() - Method in class ds.granules.operation.MapReduceBase
 
getMarshallingUtil() - Static method in class ds.granules.Granules
Obtain the MarshallingUtil instance in this scope.
getMatrix(String, int, int, int, boolean) - Method in class ds.granules.util.MatrixFactory
Retrieve/create a matrix based on the specified arguments.
getMatrix(String) - Method in class ds.granules.util.MatrixFactory
Retrieve the Matrix associated with the matrix that was stored in a file.
getMatrixFactory() - Static method in class ds.granules.Granules
Obtain the MatrixFactory instance in this scope.
getMaxSequence() - Method in interface ds.granules.results.SequencingInfo
Retrieve the value of the max-sequence info.
getMaxSequence() - Method in class ds.granules.results.SequencingWidget
 
getMD5Checksum(byte[]) - Static method in class ds.granules.util.MD5Checksum
 
getMemoryUtilization() - Method in class ds.granules.scheduler.ResourceMetrics
Retrieve the memory utilization in MB.
getMemoryUtilization() - Method in interface ds.granules.scheduler.ResourceProfile
The memory utilization at the resource
getMessageID() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getMessageOffSet() - Method in class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
getMessageSize() - Method in class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
getMetadataLength() - Method in class ds.granules.util.Matrix
 
getMsgChainID() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getNameBasedUUIDAsString() - Method in class ds.granules.util.UUIDRetriever
 
getNumberOfAvailableResources() - Method in class ds.granules.operation.JobSubmission
Retrieves the number of available resources.
getNumberOfColumns() - Method in class ds.granules.util.Matrix
 
getNumberOfCompletedTasks() - Method in class ds.granules.scheduler.Diagnostics
 
getNumberOfComputations() - Method in class ds.granules.scheduler.ResourceMetrics
 
getNumberOfConcurrentDeployments() - Method in interface ds.granules.operation.ProgressTracker
Gets the number of concurrent deployments.
getNumberOfConcurrentDeployments() - Method in class ds.granules.operation.ProgressTrackerWidget
 
getNumberOfDatasets() - Method in interface ds.granules.dataset.DatasetCollection
Get the number of datasets in this collection.
getNumberOfDatasets() - Method in class ds.granules.dataset.DatasetCollectionManagement
 
getNumberOfInputStreams() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
getNumberOfInputStreams() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
getNumberOfInputStreams() - Method in interface ds.granules.dataset.StreamDataset
Retrieve the number of input streams in this dataset
getNumberOfInputStreams() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
getNumberOfInputStreams() - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Retrieve the number of input streams in this dataset
getNumberofIterationsSoFar() - Method in class ds.granules.exchange.TaskLifecycleMetricsReader
 
getNumberofIterationsSoFar() - Method in interface ds.granules.scheduler.TaskLifecycleMetrics
Retrieve the number of iterations performed for the operation so far
getNumberOfMaps() - Method in class ds.granules.operation.MapReduceBase
 
getNumberOfMaps() - Method in interface ds.granules.operation.Reduce
Retrieves the number of registered Map instances
getNumberOfOutputStreams() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
getNumberOfOutputStreams() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
getNumberOfOutputStreams() - Method in interface ds.granules.dataset.StreamDataset
Retrieve the number of output streams in this dataset.
getNumberOfOutputStreams() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
getNumberOfOutputStreams() - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Retrieve the number of output streams in this dataset.
getNumberOfProcessors() - Method in class ds.granules.scheduler.ResourceMetrics
Retrieve the number of processors available to this resource.
getNumberOfReducers() - Method in interface ds.granules.operation.Map
Retrieves the number of registered Reduce instances
getNumberOfReducers() - Method in class ds.granules.operation.MapReduceBase
 
getNumberOfResources() - Method in class ds.granules.operation.JobSubmission
 
getNumberOfRows() - Method in class ds.granules.util.Matrix
 
getNumberOfTimesToExecute() - Method in interface ds.granules.operation.ExecutionProfile
Retrieves the number of times the operation needs to be executed.
getNumberOfTimesToExecute() - Method in class ds.granules.operation.ExecutionProfileSetup
 
getObjectArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into an Object[].
getOperation() - Method in class ds.granules.exchange.DeploymentMessage
 
getOperation() - Method in class ds.granules.scheduler.ExecutableTask
Retrieve the operation that will be executed by this task
getOperationIdentifier() - Method in interface ds.granules.operation.Operation
Retrieve the identifier associated with this operation.
getOperationIdentifier() - Method in class ds.granules.operation.OperationBase
 
getOrigin() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getOutputStreams() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
getOutputStreams() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
getOutputStreams() - Method in interface ds.granules.dataset.StreamDataset
Retrieve a collection of the constituent output streams.
getOutputStreams() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
getOutputStreams() - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Retrieve a HashMap of the constituent output streams.
getOverlayVer() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getParamsReader() - Static method in class ds.granules.Granules
Obtain the ParamsReader instance in this scope.
getPartitionKey() - Method in class ds.granules.dataset.StreamEvent
Return the partitioning key used for partitioning a stream.
getPartitionKey() - Method in class ds.granules.streaming.core.datatype.StreamingString
 
getPosition(String) - Method in interface ds.granules.dataset.FileAccess
Deprecated.
Retrieves the position of filePointer for the given dataset
getPosition(String) - Method in interface ds.granules.dataset.FileDataset
Retrieves the position of filePointer for the given dataset
getPosition(String) - Method in class ds.granules.dataset.FileDatasetImpl
 
getPosition(String) - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
getProcessingDirectives() - Method in interface ds.granules.operation.Operation
These properties encapsulate the set of processing directives that are needed to initialize the operation in question.
getProcessingDirectives() - Method in class ds.granules.operation.OperationBase
 
getProcessorInfo() - Method in interface ds.granules.scheduler.ResourceProfile
Retrieve the processor information
getProperties() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getProperties() - Method in class ds.granules.scheduler.Resource
Retrieves Resource streaming properties.
getProperties() - Method in class ds.granules.util.GranulesStaticConfig
 
getProperties(String) - Method in class ds.granules.util.ParamsReader
Constructs a set of properties from the specified configuration file.
getQueueSize() - Method in interface ds.granules.scheduler.ResourceProfile
Retrieve the queue size at the resource/
getRandomBasedUUIDAsString() - Method in class ds.granules.util.UUIDRetriever
 
getReadPosition() - Method in class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
getReduceIdentifiers() - Method in interface ds.granules.operation.Map
Retrieves the set of Reduce identifiers
getReduceIdentifiers() - Method in class ds.granules.operation.MapReduceBase
 
getReplyLink() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getResource() - Static method in class ds.granules.Granules
Obtain the Resource instance in this scope.
getResourceDeploymentStreams() - Method in class ds.granules.operation.JobSubmission
Retrieves the currently-available resource deployment streams known by the JobSubmission singleton instance.
getResourceDeploymentStreams(Collection<String>) - Method in class ds.granules.operation.JobSubmission
Retrieves the currently-available resource deployment streams known by the JobSubmission singleton instance.
getResourceDiscovery(byte[]) - Method in class ds.granules.exchange.ExchangeFactory
Reconstructs the ResourceDiscovery from a stream of bytes
getResourceMetrics() - Method in class ds.granules.exchange.ResourceDiscovery
 
getResourceMetrics() - Method in class ds.granules.scheduler.Diagnostics
Retrieve the resource metrics
getResourceType() - Method in class ds.granules.exchange.ResourceDiscovery
 
getRespondTo() - Method in class ds.granules.exchange.Exchange
Retrieve the respondTo field for this exchange.
getRespondTo() - Method in interface ds.granules.results.Results
Retrieve the respondTo field for the Results
getRespondTo() - Method in class ds.granules.results.ResultsWidget
 
getRestartHistory() - Method in interface ds.granules.scheduler.ResourceProfile
Retrieves the restart history of this resource.
getResultIdentifier() - Method in interface ds.granules.results.Results
Gets the identifier for this slice of the results.
getResultIdentifier() - Method in class ds.granules.results.ResultsWidget
 
getResultPayload() - Static method in class ds.granules.Granules
Obtain the ResultPayload instance in this scope.
getResultPayload() - Method in interface ds.granules.results.Results
Retrieve the payload associated with this result.
getResultPayload() - Method in class ds.granules.results.ResultsWidget
 
getResults(byte[]) - Method in class ds.granules.results.ResultsFactory
Recreate the Results object from a byte[].
getResults(FormatReader) - Method in class ds.granules.results.ResultsFactory
Recreate the Results object from a byte[].
getResultsFactory() - Static method in class ds.granules.Granules
Obtain the ResultsFactory instance in this scope.
getResultType() - Method in interface ds.granules.results.Results
Get the type of the result encapsulated within the payload.
getResultType() - Method in class ds.granules.results.ResultsWidget
 
getSequencingInfo() - Method in interface ds.granules.results.Results
Retrieves the sequencing information associated with this result.
getSequencingInfo(FormatReader) - Method in class ds.granules.results.ResultsFactory
Creates a sequencing info from a set of bytes.
getSequencingInfo() - Method in class ds.granules.results.ResultsWidget
 
getShort(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a short.
getShort2DArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a short[][].
getShortArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a short[].
getSingleSequence() - Method in interface ds.granules.results.SequencingInfo
Retrieve the single-sequence information.
getSingleSequence() - Method in class ds.granules.results.SequencingWidget
 
getSize(String) - Method in interface ds.granules.dataset.FileDataset
Returns the current size of the file in question
getSize(String) - Method in class ds.granules.dataset.FileDatasetImpl
 
getStartTime() - Method in class ds.granules.exchange.TaskLifecycleMetricsReader
 
getStartTime() - Method in interface ds.granules.scheduler.TaskLifecycleMetrics
Retrieve the time this operation was first launched
getStatus() - Method in class ds.granules.operation.InstanceDeployer
Returns the status of all Jobs that have been submitted from this node in question.
getStatus() - Method in class ds.granules.operation.JobSubmission
This method returns a String representation of the status of all jobs that have been submitted from this node.
getStatusOfJob(String) - Method in class ds.granules.operation.JobSubmission
Retrieve the status of a specific job that was submitted from this node.
getStatusOfTask(String, String) - Method in class ds.granules.operation.JobSubmission
Retrieve the status of a task.
getStatusOfTask(String) - Method in class ds.granules.scheduler.Diagnostics
Retrieve the status associated with a specific task.
getStorageInfo() - Method in interface ds.granules.scheduler.ResourceProfile
Retrieves information about the available storage.
getStreamId() - Method in class ds.granules.dataset.StreamEvent
Returns the identifier of the stream to which the event belongs to.
getStreamIdentifier(String) - Method in class ds.granules.streaming.core.StreamBase
 
getStreamIdFromFullQualifiedId(String) - Static method in class ds.granules.streaming.core.StreamUtil
Returns the stream id from the full qualified identifier by removing the instance identifier and dataset identifier
getStreamingData() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
getStreamingData() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
getStreamingData() - Method in interface ds.granules.dataset.StreamDataset
Retrieves a portion of the streaming dataset when data is available.
getStreamingData() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
getStreamingData() - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Retrieves a portion of the streaming dataset when data is available.
getString(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a String.
getStringArray(byte[]) - Method in class ds.granules.results.ResultPayload
This method converts a byte[] into a String[].
getTaskCompletionInfo() - Method in class ds.granules.exchange.TaskLifecycleMetricsReader
 
getTaskCompletionInfo() - Method in interface ds.granules.scheduler.TaskLifecycleMetrics
Retrieve information about the completion of a task.
getTaskIdentifier() - Method in class ds.granules.exchange.DeploymentMessage
 
getTaskIdentifier() - Method in class ds.granules.exchange.ExecutionStatus
 
getTaskIdentifiers() - Method in interface ds.granules.operation.ProgressTracker
Gets the task identifiers associated with the concurrent deployments
getTaskIdentifiers() - Method in class ds.granules.operation.ProgressTrackerWidget
 
getTaskLifecycleMetrics() - Method in class ds.granules.exchange.ExecutionStatus
Retrieve the TaskLifecycleMetrics associated with the RESPONSE.
getTaskLifecycleMetrics(String) - Method in interface ds.granules.operation.ProgressTracker
Retrieve the TaskLifecycleMetrics associated with a given task.
getTaskLifecycleMetrics(String) - Method in class ds.granules.operation.ProgressTrackerWidget
 
getTaskLifecycleMetrics() - Method in class ds.granules.scheduler.ExecutableTask
Retrieve the TaskLifecyleMetrics associated with this task.
getThreadPoolSize() - Method in class ds.granules.scheduler.ResourceMetrics
Retrieve the thread pool size.
getTimeBasedUUIDAsString() - Method in class ds.granules.util.UUIDRetriever
 
getTimeResidentInMemory() - Method in class ds.granules.exchange.TaskLifecycleMetricsReader
 
getTimeResidentInMemory() - Method in interface ds.granules.scheduler.TaskLifecycleMetrics
Retrieve the time this operation spent residing in memory
getTimeStamp() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getTimestamp() - Method in class ds.granules.exchange.Exchange
Retrieve the timestamp for this exchange.
getTimestamp() - Method in interface ds.granules.results.Results
Retrieve the timestamp for this result.
getTimestamp() - Method in class ds.granules.results.ResultsWidget
 
getTopic() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
getTotalMemory() - Method in class ds.granules.scheduler.ResourceMetrics
Retrieve the total memory assigned to the resource in MB.
getUpper() - Method in interface ds.granules.results.SequencingInfo
Retrieve the upper-bound of the specified range.
getUpper() - Method in class ds.granules.results.SequencingWidget
 
getUptime() - Method in interface ds.granules.scheduler.ResourceProfile
Retrieves the time for which this resource has been up-and-running continuously without failures.
getUUIDRetriever() - Static method in class ds.granules.Granules
Obtain the UUIDRetriever instance in this scope.
getValue() - Method in class ds.granules.streaming.core.datatype.StreamingString
 
getVersion() - Static method in class ds.granules.util.Version
 
getVersionInformation() - Method in interface ds.granules.operation.Operation
A monotonically increasing version number needs to be associated with the operations.
getVersionInformation() - Method in class ds.granules.operation.OperationBase
 
getZooKeeperInstance() - Method in class ds.granules.communication.direct.ZooKeeperAgent
 
Granules - Class in ds.granules
Granules.java: A class for obtaining system-wide instances.
Granules() - Constructor for class ds.granules.Granules
 
GranulesConfigurationException - Exception in ds.granules.exception
Exceptions related to Granules Configuration
GranulesConfigurationException(String) - Constructor for exception ds.granules.exception.GranulesConfigurationException
 
GranulesConfigurationException(String, Throwable) - Constructor for exception ds.granules.exception.GranulesConfigurationException
 
GranulesStaticConfig - Class in ds.granules.util
Holds the start up and configuration properties of a Granules resource instance or a job.

H

hasDataset() - Method in interface ds.granules.dataset.DatasetCollection
Check to see if any dataset is part of this collection.
hasDataset(String) - Method in interface ds.granules.dataset.DatasetCollection
Check to see if a dataset with the specified identifier is part of this collection
hasDataset() - Method in class ds.granules.dataset.DatasetCollectionManagement
 
hasDataset(String) - Method in class ds.granules.dataset.DatasetCollectionManagement
 
hasDatasetCollection() - Method in interface ds.granules.operation.Operation
Returns true if this operation operates on an underlying dataset collection.
hasDatasetCollection() - Method in class ds.granules.operation.OperationBase
 
hasExecutionProfile() - Method in interface ds.granules.operation.Operation
Check to see if this operation has an execution profile
hasExecutionProfile() - Method in class ds.granules.operation.OperationBase
 
hasFile(String) - Method in interface ds.granules.dataset.FileDataset
Checks to see if the file is part of a given dataset
hasFile(String) - Method in class ds.granules.dataset.FileDatasetImpl
 
hash(byte[]) - Method in class ds.granules.util.Checksum
Produce a checksum/hashsum of a given block of data.
hashCode() - Method in class ds.granules.scheduler.ExecutableTask
 
HASHMAP - Static variable in class ds.granules.results.ResultPayload
 
HASHTABLE - Static variable in class ds.granules.results.ResultPayload
 
hashToHexString(byte[]) - Method in class ds.granules.util.Checksum
Convert a hash to a hexidecimal String.
hasInputStream(Topic) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
hasInputStream(Topic) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
hasInputStream(Topic) - Method in interface ds.granules.dataset.StreamDataset
Check to see if this dataset has a specified input stream.
hasInputStreams() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
hasInputStreams() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
hasInputStreams() - Method in interface ds.granules.dataset.StreamDataset
Check to see if this dataset has any registered input streams.
hasInputStreams() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
hasInputStreams() - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Check to see if this dataset has any registered input streams.
hasMaxSequence() - Method in interface ds.granules.results.SequencingInfo
Check to see if the max sequence Info has been set.
hasMaxSequence() - Method in class ds.granules.results.SequencingWidget
 
hasOutputStream(Topic) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
hasOutputStream(Topic) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
hasOutputStream(Topic) - Method in interface ds.granules.dataset.StreamDataset
Check to see if this dataset has a specified output stream.
hasOutputStreams() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
hasOutputStreams() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
hasOutputStreams() - Method in interface ds.granules.dataset.StreamDataset
Check to see if this dataset has any registered output streams.
hasOutputStreams() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
hasOutputStreams() - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Check to see if this dataset has any registered output streams.
hasProcessingDirectives() - Method in interface ds.granules.operation.Operation
Checks to see if the operation has processing directives
hasProcessingDirectives() - Method in class ds.granules.operation.OperationBase
 
hasRespondTo() - Method in interface ds.granules.results.Results
Check to see if a respondTo field has been included as part of this result.
hasRespondTo() - Method in class ds.granules.results.ResultsWidget
 
hasSequenceRange() - Method in interface ds.granules.results.SequencingInfo
Check to see if a sequence range has been specified.
hasSequenceRange() - Method in class ds.granules.results.SequencingWidget
 
hasSequencingInfo() - Method in interface ds.granules.results.Results
Check to see if a Sequencing Info has been associated with this result.
hasSequencingInfo() - Method in class ds.granules.results.ResultsWidget
 
hasSingleSequence() - Method in interface ds.granules.results.SequencingInfo
Checks to see if this contains information about a single sequence
hasSingleSequence() - Method in class ds.granules.results.SequencingWidget
 
HIERARCHICAL_SYNOPSIS - Static variable in interface ds.granules.dataset.StreamingAccess
Deprecated.
 

I

identifier - Variable in class ds.granules.streaming.core.StreamBase
 
IllegalModificationException - Exception in ds.granules.results
This is a RuntimeException that will be thrown when an attempt is made to modify results (and its constituent elements) after they have been marked as immutable.
IllegalModificationException() - Constructor for exception ds.granules.results.IllegalModificationException
Constructs an IllegalArgumentException with no detail message.
IllegalModificationException(String) - Constructor for exception ds.granules.results.IllegalModificationException
Constructs an IllegalArgumentException with the specified detail message.
IllegalModificationException(String, Throwable) - Constructor for exception ds.granules.results.IllegalModificationException
Constructs a new exception with the specified detail message and cause.
IllegalModificationException(Throwable) - Constructor for exception ds.granules.results.IllegalModificationException
Constructs a new exception with the specified cause and a detail message of (cause==null ? null : cause.toString()) (which typically contains the class and detail message of cause).
incomingStreamTypes - Variable in class ds.granules.streaming.core.StreamBase
 
incrementCounter() - Method in class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
incrementNumberOfDeployments() - Method in class ds.granules.operation.ProgressTrackerWidget
 
init() - Method in class ds.granules.scheduler.Resource
 
initialize(Properties) - Method in class ds.granules.communication.direct.JobDeployer
 
initialize(Properties) - Method in interface ds.granules.operation.Deployer
 
initialize(Properties) - Method in class ds.granules.operation.InstanceDeployer
This initializes the deployer based on the specified argument.
initialize(Properties, String) - Method in class ds.granules.operation.InstanceDeployer
This initializes the deployer based on the specified arguments.
initialize(String, int, Properties, String) - Method in class ds.granules.operation.InstanceDeployer
This initializes the deployer based on the specified arguments.
initialize(String, int, Properties, String) - Method in class ds.granules.operation.JobSubmission
Initializes communications based on the specified parameters.
initialize(Properties) - Method in interface ds.granules.operation.Operation
Initialize the operation based on the specified processing directives.
initialize(Properties) - Method in class ds.granules.operation.OperationBase
 
initialize() - Method in class ds.granules.scheduler.ExchangeProcessor
 
initialize(String, int, Properties, String) - Method in class ds.granules.scheduler.StreamingService
Initialize the streaming service based on the specified parameters
initialize(Properties) - Method in class ds.granules.streaming.core.StreamBase
 
initialize(Properties) - Static method in class ds.granules.util.GranulesStaticConfig
 
INITIALIZED - Static variable in interface ds.granules.scheduler.TaskLifecycleMetrics
 
initializeDataset() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
initializeDataset() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
initializeDataset() - Method in interface ds.granules.dataset.Dataset
Invokes the initialization of the dataset.
initializeDataset() - Method in class ds.granules.dataset.FileDatasetImpl
 
initializeDataset() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
initializeDataset() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
initializeDatasets() - Method in interface ds.granules.dataset.DatasetCollection
Initializes all the constituent datasets in this collection.
initializeDatasets() - Method in class ds.granules.dataset.DatasetCollectionManagement
 
INITIALIZING - Static variable in interface ds.granules.scheduler.TaskLifecycleMetrics
 
instance - Static variable in class ds.granules.communication.direct.JobDeployer
 
InstanceDeployer - Class in ds.granules.operation
This is a class that encapsulates several of the functionality that need to be supported by Granules application deployers.
InstanceDeployer() - Constructor for class ds.granules.operation.InstanceDeployer
 
INT - Static variable in class ds.granules.results.ResultPayload
 
INT_2D_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
INT_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
INT_ENTRIES - Static variable in class ds.granules.util.Matrix
 
IO_REACTOR_THREAD_COUNT - Static variable in class ds.granules.util.Constants
 
IOReactor - Class in ds.granules.communication.direct.nio.client
 
IOReactor() - Constructor for class ds.granules.communication.direct.nio.client.IOReactor
 
IOReactor - Class in ds.granules.communication.direct.nio.server
 
IOReactor(int) - Constructor for class ds.granules.communication.direct.nio.server.IOReactor
 
isAvailable() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
isAvailable() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
isAvailable() - Method in interface ds.granules.dataset.Dataset
A check to see if the dataset is available
isAvailable() - Method in class ds.granules.dataset.FileDatasetImpl
 
isAvailable() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
isAvailable() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
isAwaitingOutputs() - Method in class ds.granules.operation.MapReduceBase
 
isAwaitingOutputs() - Method in interface ds.granules.operation.Reduce
Check to see is the Reducer is missing outputs from any of the registered Maps.
isBufferingAccess - Variable in class ds.granules.streaming.core.StreamBase
 
isChangedPeriodicExecution(String) - Method in interface ds.granules.scheduler.TaskLifecycleObserver
Indicates that the task in question has changed it execution profile.
isChangedPeriodicExecution(String) - Method in class ds.granules.scheduler.TaskManagement
 
isClosed() - Method in interface ds.granules.dataset.DatasetCollection
This method indicates whether this dataset collection is closed.
isClosed() - Method in class ds.granules.dataset.DatasetCollectionManagement
 
isColumnMajorFormat() - Method in class ds.granules.util.Matrix
 
isComplete() - Method in interface ds.granules.operation.ProgressTracker
Check to see if the Job has completed.
isComplete() - Method in class ds.granules.operation.ProgressTrackerWidget
 
isComplete(String) - Method in interface ds.granules.scheduler.TaskLifecycleObserver
Indicates that the task in question has finished processing.
isComplete(String) - Method in class ds.granules.scheduler.TaskManagement
 
isCompleteResult() - Method in interface ds.granules.results.Results
Check to see if this results encapsulates the complete result from processing.
isCompleteResult() - Method in class ds.granules.results.ResultsWidget
 
isDataAvailable() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
isDataAvailable() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
isDataAvailable() - Method in interface ds.granules.dataset.Dataset
This polls the dataset to see if data is available for consumption.
isDataAvailable() - Method in interface ds.granules.dataset.DatasetCollection
Reports on the availability of data in any of the underlying datasets that are part of this collection.
isDataAvailable() - Method in class ds.granules.dataset.DatasetCollectionManagement
 
isDataAvailable() - Method in class ds.granules.dataset.FileDatasetImpl
 
isDataAvailable() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
isDataAvailable() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
isDropSafe() - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
isExcuteAFixedNumberOfTimes() - Method in interface ds.granules.operation.ExecutionProfile
Indicates whether the operation needs to be executed a fixed number of times
isExcuteAFixedNumberOfTimes() - Method in class ds.granules.operation.ExecutionProfileSetup
 
isExecuteContinuously() - Method in interface ds.granules.operation.ExecutionProfile
This computation task will run continuously as and when it is scheduled.
isExecuteContinuously() - Method in class ds.granules.operation.ExecutionProfileSetup
 
isExecuteOnce() - Method in interface ds.granules.operation.ExecutionProfile
This indicates if the operation needs to be executed exactly once
isExecuteOnce() - Method in class ds.granules.operation.ExecutionProfileSetup
 
isExecutePeriodically() - Method in interface ds.granules.operation.ExecutionProfile
Indicates whether the operation needs to be executed periodically.
isExecutePeriodically() - Method in class ds.granules.operation.ExecutionProfileSetup
 
isExecutePeriodically() - Method in class ds.granules.scheduler.ExecutableTask
A check to see if the task in question needs to be executed periodically.
isExecuteWhenDataAvailable() - Method in interface ds.granules.operation.ExecutionProfile
This indicates that the operation should be run when new data is made available on its input datasets.
isExecuteWhenDataAvailable() - Method in class ds.granules.operation.ExecutionProfileSetup
 
isExecuting(String) - Method in interface ds.granules.scheduler.TaskLifecycleObserver
Indicates that the task in question has been scheduled for execution and is currently executing.
isExecuting(String) - Method in class ds.granules.scheduler.TaskManagement
 
isInitialized() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
isInitialized() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
isInitialized() - Method in interface ds.granules.dataset.Dataset
Check to see if the dataset has been initialized
isInitialized() - Method in class ds.granules.dataset.FileDatasetImpl
 
isInitialized() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
isInitialized() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
isInitialized() - Method in interface ds.granules.operation.Operation
Check if the operation has been initialized
isInitialized() - Method in class ds.granules.operation.OperationBase
 
isInitialized() - Method in class ds.granules.scheduler.StreamingService
Checks to see if the streaming service has been initialized.
isInitializing(String) - Method in interface ds.granules.scheduler.TaskLifecycleObserver
Indicates that the task is question is currently performing initialization related operations.
isInitializing(String) - Method in class ds.granules.scheduler.TaskManagement
 
isMutable() - Method in interface ds.granules.results.Results
Checks to see if this data structure is mutable.
isMutable() - Method in class ds.granules.results.ResultsWidget
 
isMutable() - Method in interface ds.granules.results.SequencingInfo
Check to see if the sequencing information is mutable.
isMutable() - Method in class ds.granules.results.SequencingWidget
 
isPartialResult() - Method in interface ds.granules.results.Results
Check to see if this is a partial result, within a stream of results that constitute the final result.
isPartialResult() - Method in class ds.granules.results.ResultsWidget
 
isPartOfDataset(String) - Method in interface ds.granules.dataset.FileAccess
Deprecated.
Checks to see if the file is part of a given dataset
isPartOfDataset(String) - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
isProcessingComplete() - Method in interface ds.granules.results.Results
Check to see if the instance has completed processing of its input dataset.
isProcessingComplete() - Method in class ds.granules.results.ResultsWidget
 
isReady(String) - Method in interface ds.granules.scheduler.TaskLifecycleObserver
When a task is ready for execution, this method is invoked on its registered observer.
isReady(String) - Method in class ds.granules.scheduler.TaskManagement
 
isRequest() - Method in class ds.granules.exchange.Exchange
Indicates whether this exchange is a Request
isResponse() - Method in class ds.granules.exchange.Exchange
Indicates whether this exchange is a Response to a previously issued request.
isRowMajorFormat() - Method in class ds.granules.util.Matrix
 
isStayAlive() - Method in interface ds.granules.operation.ExecutionProfile
This indicates that the operation should be allowed to continually run until the operation deems necessary.
isStayAlive() - Method in class ds.granules.operation.ExecutionProfileSetup
 
isSuccessful() - Method in interface ds.granules.operation.ProgressTracker
Check to see if the Job completed successfully.
isSuccessful() - Method in class ds.granules.operation.ProgressTrackerWidget
 
isValidExchangeSubType() - Method in class ds.granules.exchange.DeploymentMessage
 
isValidExchangeSubType() - Method in class ds.granules.exchange.Exchange
Checks to see if the exchange sub-type in the reconstructed exchange is a valid one.
isValidExchangeSubType() - Method in class ds.granules.exchange.ExecutionStatus
 
isValidExchangeSubType() - Method in class ds.granules.exchange.ResourceDiscovery
 
isValidExchangeType(int) - Method in class ds.granules.exchange.ExchangeFactory
Checks to see if a given exchange type is a valid one.
isWaitingForData(String) - Method in interface ds.granules.scheduler.TaskLifecycleObserver
Indicates that the task in question is waiting for the arrival of data to begin processing.
isWaitingForData(String) - Method in class ds.granules.scheduler.TaskManagement
 

J

Job - Class in ds.granules.streaming.core
Represents a streaming job.
Job(String) - Constructor for class ds.granules.streaming.core.Job
Initialize a new Job.
JOB_DEPLOYER - Static variable in class ds.granules.util.Constants
 
JobDeployer - Class in ds.granules.communication.direct
Implements the deploying logic for direct communications.
JobDeployer() - Constructor for class ds.granules.communication.direct.JobDeployer
 
JobLifecycleObserver - Interface in ds.granules.operation
JobLifecycleObserver is the interface which needs to be implemented by an entity which wishes to observe the execution of a Job and its constituent tasks.
JobSubmission - Class in ds.granules.operation
This class manages the submission, tracking and cancellation of Jobs and their constituent tasks.
JobSubmission() - Constructor for class ds.granules.operation.JobSubmission
 

K

killJob(String) - Method in class ds.granules.operation.InstanceDeployer
Kill a Job with specified jobIdentifer
killJob(String) - Method in class ds.granules.operation.JobSubmission
Attempts to kill the job while it is in execution at different sites

L

launch(Properties) - Method in interface ds.granules.communication.CommFrameworkLauncher
Launch the framework
launch(Properties) - Method in class ds.granules.communication.direct.DirectCommFrameworkLauncher
 
launch(Properties) - Method in class ds.granules.communication.direct.netty.server.NettyServerLauncher
 
launch(Properties) - Method in class ds.granules.communication.direct.nio.server.NIOServerLauncher
 
launch(Properties) - Method in class ds.granules.communication.funnel.FunnelLauncher
 
LibraryException - Exception in ds.granules.scheduler
This is an exception that is thrown when there are problems loading or unloading libraries that are associated with application instances.
LibraryException(String) - Constructor for exception ds.granules.scheduler.LibraryException
Constructs an LibraryException with the specified detail message.
LibraryManager - Interface in ds.granules.scheduler
This is an interface that outlines functionality needed for managing the loading and unloading of classes and Jar files.
libraryRegisteredForOperation() - Method in interface ds.granules.scheduler.LibraryManager
 
limit - Static variable in class ds.granules.communication.direct.util.StatCollector
 
listOfLoadedLibraries() - Method in interface ds.granules.scheduler.LibraryManager
 
loadClass() - Method in interface ds.granules.scheduler.LibraryManager
 
loadJarLibrary() - Method in interface ds.granules.scheduler.LibraryManager
 
loadLibrary() - Method in interface ds.granules.scheduler.Controller
 
loadNativeLibraries() - Method in interface ds.granules.scheduler.LibraryManager
 
LONG - Static variable in class ds.granules.results.ResultPayload
 
LONG_2D_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
LONG_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
LONG_ENTRIES - Static variable in class ds.granules.util.Matrix
 

M

main(String[]) - Static method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
main(String[]) - Static method in class ds.granules.scheduler.Resource
Main entry point for a Granules computational resource.
main(String[]) - Static method in class ds.granules.scheduler.StreamingService
 
main(String[]) - Static method in class ds.granules.util.Matrix
 
main(String[]) - Static method in class ds.granules.util.MatrixColumnMajor
 
main(String[]) - Static method in class ds.granules.util.SystemCommand
 
main(String[]) - Static method in class ds.granules.util.UUIDRetriever
 
main(String[]) - Static method in class ds.granules.util.Version
 
manageExecution(String, Operation) - Method in class ds.granules.scheduler.TaskManagement
Manage the execution of the given operation
Map - Interface in ds.granules.operation
This interface corresponds to the Map role in a Map-Reduce operation.
MapReduce - Interface in ds.granules.operation
This is an interface which encapsulates functionality that is common to both the Map and Reduce roles that are associated with the applications.
MapReduceBase - Class in ds.granules.operation
This is the base class which will serve as the base for implementations of the Map and Reduce interface.
MapReduceBase() - Constructor for class ds.granules.operation.MapReduceBase
 
mapReduceDataset - Variable in class ds.granules.operation.MapReduceBase
 
MapReduceException - Exception in ds.granules.operation
This is the exception that would be thrown if there are problems in performing Map-Reduce operations.
MapReduceException() - Constructor for exception ds.granules.operation.MapReduceException
Constructs an ProcessingException with no detail message.
MapReduceException(String) - Constructor for exception ds.granules.operation.MapReduceException
Constructs an ProcessingException with the specified detail message.
markInitializationAsComplete() - Method in class ds.granules.operation.OperationBase
 
marshall(FormatWriter) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
marshall(FormatWriter) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
marshall(FormatWriter) - Method in enum ds.granules.dataset.Dataset.DatasetType
 
marshall(FormatWriter) - Method in class ds.granules.dataset.DatasetCollectionManagement
 
marshall(FormatWriter) - Method in class ds.granules.dataset.FileDatasetImpl
 
marshall(FormatWriter) - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
marshall(FormatWriter) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
marshall() - Method in class ds.granules.dataset.StreamEvent
Convert a StreamTuple object into a byte[] for communication.
marshall(FormatWriter) - Method in class ds.granules.operation.MapReduceBase
 
marshall(FormatWriter) - Method in class ds.granules.operation.OperationBase
 
marshall(FormatWriter) - Method in class ds.granules.results.ResultsWidget
 
marshall(FormatWriter) - Method in class ds.granules.results.SequencingWidget
 
marshall() - Method in class ds.granules.streaming.core.datatype.AbstractStreamEvent
 
marshall(FormatWriter) - Method in class ds.granules.streaming.core.StreamBase
 
marshallAsBatch(DataOutputStream) - Method in class ds.granules.dataset.StreamEvent
 
marshallAsBatch(DataOutputStream) - Method in class ds.granules.streaming.core.datatype.AbstractStreamEvent
 
marshallExchangeSpecificElements(FormatWriter) - Method in class ds.granules.exchange.DeploymentMessage
 
marshallExchangeSpecificElements(FormatWriter) - Method in class ds.granules.exchange.Exchange
This method is utilized by the derived classes to marshall (or serialize) elements that are specific to the derived class.
marshallExchangeSpecificElements(FormatWriter) - Method in class ds.granules.exchange.ExecutionStatus
 
marshallExchangeSpecificElements(FormatWriter) - Method in class ds.granules.exchange.ResourceDiscovery
 
MarshallingException - Exception in ds.granules.exception
This is an exception that is thrown if there are problems marshalling or unmarshalling exchanges.
MarshallingException() - Constructor for exception ds.granules.exception.MarshallingException
Constructs an MarshallingException with no detail message.
MarshallingException(String) - Constructor for exception ds.granules.exception.MarshallingException
Constructs an MarshallingException with the specified detail message.
MarshallingUtil - Class in ds.granules.util
This is a utility class which includes methods for marshalling and un-marshalling several commonly used data types.
MarshallingUtil() - Constructor for class ds.granules.util.MarshallingUtil
 
Matrix - Class in ds.granules.util
A class that encapsulates a Matrix.
Matrix(String, int, int, boolean, int) - Constructor for class ds.granules.util.Matrix
 
Matrix(String) - Constructor for class ds.granules.util.Matrix
 
MatrixColumnMajor - Class in ds.granules.util
A matrix encapsulator where the Matrix is stored in column-major format for faster reads from the underlying file system.
MatrixColumnMajor(String, int, int, boolean, int) - Constructor for class ds.granules.util.MatrixColumnMajor
 
MatrixColumnMajor(String) - Constructor for class ds.granules.util.MatrixColumnMajor
 
MatrixFactory - Class in ds.granules.util
This is a Factory class which creates matrices that are stored either in row major or column major formats.
MatrixFactory() - Constructor for class ds.granules.util.MatrixFactory
 
MD5Checksum - Class in ds.granules.util
A class that calculate checksum for a string.
MD5Checksum() - Constructor for class ds.granules.util.MD5Checksum
 
MessageReceiver - Class in ds.granules.communication.direct.netty.server
 
MessageReceiver() - Constructor for class ds.granules.communication.direct.netty.server.MessageReceiver
 
MODULE - Static variable in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
MODULE - Static variable in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
MODULE - Static variable in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
MODULE - Static variable in class ds.granules.operation.InstanceDeployer
 
MODULE - Static variable in class ds.granules.operation.JobSubmission
 
MODULE - Static variable in class ds.granules.operation.MapReduceBase
 
MODULE - Static variable in class ds.granules.results.ResultsWidget
 
MODULE - Static variable in class ds.granules.scheduler.Diagnostics
 
MODULE - Static variable in class ds.granules.scheduler.ExchangeProcessor
 
MODULE - Static variable in class ds.granules.scheduler.ResourceMetrics
 
MODULE - Static variable in class ds.granules.util.UUIDRetriever
 

N

needsInitialization() - Method in interface ds.granules.operation.Operation
Returns an indicator that indicates if the initialization needs to be performed.
needsInitialization() - Method in class ds.granules.operation.OperationBase
 
NettyChannelConnector - Class in ds.granules.communication.direct.netty.client
 
NettyChannelConnector() - Constructor for class ds.granules.communication.direct.netty.client.NettyChannelConnector
 
NettyChannelWriter - Class in ds.granules.communication.direct.netty.client
 
NettyChannelWriter(Channel) - Constructor for class ds.granules.communication.direct.netty.client.NettyChannelWriter
 
NettyServerLauncher - Class in ds.granules.communication.direct.netty.server
Launches the Netty framework.
NettyServerLauncher() - Constructor for class ds.granules.communication.direct.netty.server.NettyServerLauncher
 
NIO_READ_BUFFER_SIZE - Static variable in class ds.granules.util.Constants
 
NIOChannelConnector - Class in ds.granules.communication.direct.nio.client
 
NIOChannelConnector(int) - Constructor for class ds.granules.communication.direct.nio.client.NIOChannelConnector
 
NIOServerLauncher - Class in ds.granules.communication.direct.nio.server
Launches the NIO server to listen to incoming traffic
NIOServerLauncher() - Constructor for class ds.granules.communication.direct.nio.server.NIOServerLauncher
 
NIOTopicDataEvent - Class in ds.granules.communication.direct
 
NIOTopicDataEvent(byte[], Topic) - Constructor for class ds.granules.communication.direct.NIOTopicDataEvent
 
NOT_SET - Static variable in interface ds.granules.exchange.ConditionFlag
 
NOT_SET - Static variable in interface ds.granules.scheduler.TaskLifecycleMetrics
 
NUM_THREADS_ENV_VAR - Static variable in class ds.granules.util.Constants
 

O

OBJECT - Static variable in class ds.granules.results.ResultPayload
 
OBJECT_2D_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
OBJECT_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
onDataAvailability(String) - Method in interface ds.granules.dataset.DataAvailabilityObserver
This method is invoked on the observers to reflect the availability of new data in the input dataset
onDataAvailability(String) - Method in class ds.granules.dataset.DatasetCollectionManagement
 
onDataAvailability() - Method in interface ds.granules.dataset.DatasetCollectionObserver
This method is invoked on the observers to reflect the availability of new data in the dataset collection.
onDataAvailability() - Method in class ds.granules.scheduler.ExecutableTask
 
onDatasetClosure(String) - Method in interface ds.granules.dataset.DataAvailabilityObserver
This method is invoked on the observer when the dataset will be closed and thus no more data will be available.
onDatasetClosure(String) - Method in class ds.granules.dataset.DatasetCollectionManagement
 
onDatasetCollectionClosure() - Method in interface ds.granules.dataset.DatasetCollectionObserver
This method is invoked on the observers to reflect the closure of the dataset collection.
onDatasetCollectionClosure() - Method in class ds.granules.scheduler.ExecutableTask
 
onEvent(TopicDataEvent) - Method in interface ds.granules.communication.direct.ChannelReaderCallback
 
onEvent(TopicDataEvent) - Method in class ds.granules.scheduler.ExchangeProcessor
 
onEvent(StreamEvent) - Method in class ds.granules.streaming.core.StreamProcessor
This method will be invoked by the framework when data is available in one of the input streams.
Operation - Interface in ds.granules.operation
This is the interface which encapsulates an application instance that will be deployed.
Operation.OperationType - Enum in ds.granules.operation
 
OperationBase - Class in ds.granules.operation
This is an implementation of the Operation and OperationConfiguration interfaces.
OperationBase() - Constructor for class ds.granules.operation.OperationBase
 
OperationConfiguration - Interface in ds.granules.operation
This is an interface that allows application instances to be configured.
outGoingStreamTypes - Variable in class ds.granules.streaming.core.StreamBase
 

P

ParamsReader - Class in ds.granules.util
This is a utility class which is useful in reading specified configuration parameters.
ParamsReader() - Constructor for class ds.granules.util.ParamsReader
 
partition(StreamEvent, Topic[]) - Method in interface ds.granules.streaming.core.partition.Partitioner
 
partition(StreamEvent, Topic[]) - Method in class ds.granules.streaming.core.partition.scheme.FieldPartitioner
 
partition(StreamEvent, Topic[]) - Method in class ds.granules.streaming.core.partition.scheme.SendToAllPartitioner
 
partition(StreamEvent, Topic[]) - Method in class ds.granules.streaming.core.partition.scheme.SendToOnePartitioner
 
partition(StreamEvent, Topic[]) - Method in class ds.granules.streaming.core.partition.scheme.SendToRandomPartitioner
 
PARTITION_BY_FIELD - Static variable in class ds.granules.util.Constants.PartitionSchemes
 
Partitioner - Interface in ds.granules.streaming.core.partition
 
PartitionerFactory - Class in ds.granules.streaming.core.partition
Singleton PartitionerFactory class which returns an instance of a partitioner of a specified type.
passesReadinessCheck() - Method in class ds.granules.scheduler.ExecutableTask
Checks to see if the task is ready for execution.
pauseAvailabilityNotifications(DataAvailabilityObserver) - Method in interface ds.granules.dataset.DataAvailabilityNotifier
Pauses data availability notifications for the specified observer
pauseAvailabilityNotifications(DataAvailabilityObserver) - Method in class ds.granules.dataset.DatasetNotifier
 
pauseTask() - Method in interface ds.granules.scheduler.Controller
 
printVersionInformation() - Method in class ds.granules.util.Version
 
PROBLEMS_ENCOUNTERED - Static variable in interface ds.granules.exchange.ConditionFlag
 
process(WatchedEvent) - Method in class ds.granules.communication.direct.ZooKeeperAgent
 
processExecutionStatusRequest(ExecutionStatus) - Method in class ds.granules.scheduler.Diagnostics
 
ProcessingException - Exception in ds.granules.operation
This exception is thrown when an operation wishes to report problems in its execution.
ProcessingException() - Constructor for exception ds.granules.operation.ProcessingException
Constructs an ProcessingException with no detail message.
ProcessingException(String) - Constructor for exception ds.granules.operation.ProcessingException
Constructs an ProcessingException with the specified detail message.
processResourceDiscoveryRequest(ResourceDiscovery) - Method in class ds.granules.scheduler.Diagnostics
 
ProgressTracker - Interface in ds.granules.operation
The ProgressTracker encapsulates information about the status of jobs.
ProgressTrackerWidget - Class in ds.granules.operation
An implementation of the ProgressTracker interface.
ProgressTrackerWidget(String, String, JobLifecycleObserver) - Constructor for class ds.granules.operation.ProgressTrackerWidget
 
publishToStream(String, byte[]) - Method in class ds.granules.util.StreamPublisher
Utility method that allows a producer to publish a set of bytes onto the specified stream.

Q

QUEUE_THRESHOLD - Static variable in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
QUEUED_FOR_EXECUTION - Static variable in interface ds.granules.scheduler.TaskLifecycleMetrics
 

R

read(SelectionKey) - Method in class ds.granules.communication.direct.nio.server.IOReactor
 
read(String, byte[]) - Method in interface ds.granules.dataset.FileAccess
Deprecated.
Attempts to read a set of bytes from the underlying file.
read(String, ByteBuffer) - Method in interface ds.granules.dataset.FileAccess
Deprecated.
Attempts to read a set of bytes from the underlying file.
read(String, byte[]) - Method in interface ds.granules.dataset.FileDataset
Attempts to read a set of bytes from the underlying file.
read(String, ByteBuffer) - Method in interface ds.granules.dataset.FileDataset
Attempts to read a set of bytes from the underlying file.
read(String, byte[]) - Method in class ds.granules.dataset.FileDatasetImpl
 
read(String, ByteBuffer) - Method in class ds.granules.dataset.FileDatasetImpl
 
read(String, byte[]) - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
read(String, ByteBuffer) - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
readIntMatrix() - Method in class ds.granules.util.Matrix
Read a matrix that has been written to a file (specified in the constructor) based on the specified rows and columns.
readIntMatrix() - Method in class ds.granules.util.MatrixColumnMajor
 
readIntMatrixColumn(int) - Method in class ds.granules.util.Matrix
This method reads a specified column from the matrix that has been written to a file.
readIntMatrixColumn(int) - Method in class ds.granules.util.MatrixColumnMajor
 
readIntMatrixElement(int, int) - Method in class ds.granules.util.Matrix
Reads a matrix element from the underlying file based on the specified [rowId, columId].
readIntMatrixElement(int, int) - Method in class ds.granules.util.MatrixColumnMajor
 
readIntMatrixRow(int) - Method in class ds.granules.util.Matrix
This method reads the specified row of a matrix that has been written to a file.
readIntMatrixRow(int) - Method in class ds.granules.util.MatrixColumnMajor
 
readLongMatrix() - Method in class ds.granules.util.Matrix
Read a matrix that has been written to a file (specified in the constructor) based on the specified rows and columns.
readLongMatrix() - Method in class ds.granules.util.MatrixColumnMajor
 
readLongMatrixColumn(int) - Method in class ds.granules.util.Matrix
This method reads a specified column from the matrix that has been written to a file.
readLongMatrixColumn(int) - Method in class ds.granules.util.MatrixColumnMajor
 
readLongMatrixElement(int, int) - Method in class ds.granules.util.Matrix
Reads a matrix element from the underlying file based on the specified [rowId, columId].
readLongMatrixElement(int, int) - Method in class ds.granules.util.MatrixColumnMajor
 
readLongMatrixRow(int) - Method in class ds.granules.util.Matrix
This method reads the specified row of a matrix that has been written to a file.
readLongMatrixRow(int) - Method in class ds.granules.util.MatrixColumnMajor
 
readProperties(DataInputStream) - Method in class ds.granules.util.MarshallingUtil
Reads a property object from the underlying DataInputStream
readString(DataInputStream) - Method in class ds.granules.util.MarshallingUtil
Reads a String from the underlying DataInputStream
readValues(DataInputStream) - Method in class ds.granules.streaming.core.datatype.AbstractStreamEvent
Read values specific to the data type from the input stream.
readValues(DataInputStream) - Method in class ds.granules.streaming.core.datatype.StreamingString
 
READY - Static variable in interface ds.granules.scheduler.TaskLifecycleMetrics
 
readZNodeData(ZooKeeper, String) - Static method in class ds.granules.util.ZooKeeperUtils
 
RECEIVED - Static variable in class ds.granules.communication.direct.util.StatCollector
 
reconstruct(byte[]) - Method in class ds.granules.exchange.Exchange
Reconstruct the exchange from the byte[] representation.
Reduce - Interface in ds.granules.operation
This interface corresponds to the Reduce role in a Map-Reduce operation.
refreshStatus(String) - Method in class ds.granules.operation.InstanceDeployer
This method refreshes the status of various tasks that comprise a Job.
refreshStatus(String, String) - Method in class ds.granules.operation.InstanceDeployer
This method refreshes the status of a specific task that is part of the Job in question.
REG_EXPRESSIONS_SYNOPSIS - Static variable in interface ds.granules.dataset.StreamingAccess
Deprecated.
 
registerCallback(String, ChannelReaderCallback) - Method in class ds.granules.communication.direct.ChannelToStreamDeMultiplexer
 
registerChannel(SocketChannel, ChannelWriterDataHolder) - Method in class ds.granules.communication.direct.nio.client.IOReactor
 
registerDataAvailabilityObserver(DataAvailabilityObserver) - Method in interface ds.granules.dataset.DataAvailabilityNotifier
Registers a data availability observer
registerDataAvailabilityObserver(DataAvailabilityObserver) - Method in class ds.granules.dataset.DatasetNotifier
 
registerSocketChannel(SocketChannel) - Method in class ds.granules.communication.direct.nio.server.IOReactor
 
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class ds.granules.scheduler.TaskManagement
 
removeDataset(String) - Method in interface ds.granules.dataset.DatasetCollection
Remove a dataset from this collection
removeDataset(String) - Method in class ds.granules.dataset.DatasetCollectionManagement
 
removeDeploymentRequest(String) - Method in class ds.granules.scheduler.Diagnostics
Remove the deployment request associated with a task.
removeFile(String) - Method in interface ds.granules.dataset.FileAccess
Deprecated.
Removes a file from this dataset.
removeFile(String) - Method in interface ds.granules.dataset.FileDataset
Removes a file from this dataset.
removeFile(String) - Method in class ds.granules.dataset.FileDatasetImpl
 
removeFile(String) - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
removeInputStream(Topic) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
removeInputStream(Topic) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
removeInputStream(Topic) - Method in interface ds.granules.dataset.StreamDataset
Removes an input stream from this dataset.
removeInputStream(String) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
removeInputStream(String) - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Removes an input stream from this dataset.
removeInputStreams(Collection<Topic>) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
removeInputStreams(Collection<Topic>) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
removeInputStreams(Collection<Topic>) - Method in interface ds.granules.dataset.StreamDataset
Removes a set of input streams from this dataset.
removeInputStreams(ConcurrentHashMap<String, Integer>) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
removeInputStreams(ConcurrentHashMap<String, Integer>) - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Removes a set of input streams from this dataset.
removeMap(String) - Method in class ds.granules.operation.MapReduceBase
 
removeMap(String) - Method in interface ds.granules.operation.Reduce
Removes a Map from the list of Maps that are registered to this reducer.
removeMapper(Map) - Method in class ds.granules.operation.MapReduceBase
This method is called on a Reduce, once it has been removed from a Map using the Map.removeReduce() method.
removeOutputStream(Topic) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
removeOutputStream(Topic) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
removeOutputStream(Topic) - Method in interface ds.granules.dataset.StreamDataset
Removes an output stream from this dataset.
removeOutputStream(String) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
removeOutputStream(String) - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Removes an output stream from this dataset.
removeOutputStreams(Collection<Topic>) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
removeOutputStreams(Collection<Topic>) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
removeOutputStreams(Collection<Topic>) - Method in interface ds.granules.dataset.StreamDataset
Removes a set of output streams from this dataset.
removeOutputStreams(ConcurrentHashMap<String, Integer>) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
removeOutputStreams(ConcurrentHashMap<String, Integer>) - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
Removes a set of output streams from this dataset.
removeReduce(String) - Method in interface ds.granules.operation.Map
Removes a given reducer from the list of Reducers for a given Map function.
removeReduce(String) - Method in class ds.granules.operation.MapReduceBase
 
removeReducer(Reduce) - Method in class ds.granules.operation.MapReduceBase
This method is called on a Map, once it has been removed from a Reduce using the Reduce.removeMap() method.
replaceLibrary() - Method in interface ds.granules.scheduler.LibraryManager
 
resetOutputTracker() - Method in class ds.granules.operation.MapReduceBase
 
resetOutputTracker() - Method in interface ds.granules.operation.Reduce
This method resets the output tracker associated with the reducer.
resetTrackers() - Method in class ds.granules.operation.InstanceDeployer
Resets the task completion counts maintained by this class.
Resource - Class in ds.granules.scheduler
This is a class which encapsulates the functionality of a computational resource.
RESOURCE_DISCOVERY - Static variable in interface ds.granules.exchange.ExchangeType
 
ResourceDiscovery - Class in ds.granules.exchange
This class encapsulates exchanges related the discovery of resources.
ResourceDiscovery() - Constructor for class ds.granules.exchange.ResourceDiscovery
 
ResourceDiscovery(int, String) - Constructor for class ds.granules.exchange.ResourceDiscovery
 
ResourceDiscovery(int, String, ResourceMetrics, String) - Constructor for class ds.granules.exchange.ResourceDiscovery
 
ResourceMetrics - Class in ds.granules.scheduler
This class encapsulates various metrics associated with the resource.
ResourceMetrics(int, String) - Constructor for class ds.granules.scheduler.ResourceMetrics
 
ResourceMetrics(byte[]) - Constructor for class ds.granules.scheduler.ResourceMetrics
 
ResourceProfile - Interface in ds.granules.scheduler
This is an interface that snapshots the profile of a given resource.
ResultPayload - Class in ds.granules.results
This is a utility class which can be used for marshalling and unmarshalling some of the most commonly used result primitives.
ResultPayload() - Constructor for class ds.granules.results.ResultPayload
 
Results - Interface in ds.granules.results
The results interface allows functions to encapsulate results and other lightweight metadata information that would be associated with them.
ResultsFactory - Class in ds.granules.results
This is a singleton-class that is used for creating and reconstructing Results and the elements that comprise it such as SequencingInfo.
ResultsFactory() - Constructor for class ds.granules.results.ResultsFactory
 
ResultsWidget - Class in ds.granules.results
This class is an implementation of the Results interface.
ResultsWidget(String, String, boolean, boolean) - Constructor for class ds.granules.results.ResultsWidget
 
ResultsWidget(FormatReader) - Constructor for class ds.granules.results.ResultsWidget
Reconstructs the ResultsWidget from a set of bytes
resumeAvailabilityNotifications(DataAvailabilityObserver) - Method in interface ds.granules.dataset.DataAvailabilityNotifier
Resumes data availability notifications for the specified observer
resumeAvailabilityNotifications() - Method in interface ds.granules.dataset.DatasetCollection
Resume data availability notifications for this collection.
resumeAvailabilityNotifications() - Method in class ds.granules.dataset.DatasetCollectionManagement
 
resumeAvailabilityNotifications(DataAvailabilityObserver) - Method in class ds.granules.dataset.DatasetNotifier
 
run() - Method in class ds.granules.communication.direct.nio.client.IOReactor
 
run() - Method in class ds.granules.communication.direct.nio.client.NIOChannelConnector
 
run() - Method in class ds.granules.communication.direct.nio.server.ChannelAcceptor
 
run() - Method in class ds.granules.communication.direct.nio.server.IOReactor
 
run() - Method in class ds.granules.scheduler.ExecutableTask
 

S

SchedulingException - Exception in ds.granules.scheduler
This is an exception that is thrown when there are problems in scheduling tasks for execution.
SchedulingException() - Constructor for exception ds.granules.scheduler.SchedulingException
Constructs an SchedulingException with no detail message.
SchedulingException(String) - Constructor for exception ds.granules.scheduler.SchedulingException
Constructs an SchedulingException with the specified detail message.
SEND_TO_ALL - Static variable in class ds.granules.util.Constants.PartitionSchemes
 
SEND_TO_ONE - Static variable in class ds.granules.util.Constants.PartitionSchemes
 
SEND_TO_RANDOM - Static variable in class ds.granules.util.Constants.PartitionSchemes
 
SendToAllPartitioner - Class in ds.granules.streaming.core.partition.scheme
Replicates the stream across to all the recipients.
SendToAllPartitioner() - Constructor for class ds.granules.streaming.core.partition.scheme.SendToAllPartitioner
 
SendToOnePartitioner - Class in ds.granules.streaming.core.partition.scheme
Send traffic to a single recipient at all times.
SendToOnePartitioner() - Constructor for class ds.granules.streaming.core.partition.scheme.SendToOnePartitioner
 
SendToRandomPartitioner - Class in ds.granules.streaming.core.partition.scheme
Partition the stream data items randomly across all recipients.
SendToRandomPartitioner() - Constructor for class ds.granules.streaming.core.partition.scheme.SendToRandomPartitioner
 
SENT - Static variable in class ds.granules.communication.direct.util.StatCollector
 
SequencingInfo - Interface in ds.granules.results
Some applications often need to include sequencing descriptors along with their results.
SequencingWidget - Class in ds.granules.results
This class is an implementation of the SequencingInfo interface.
SequencingWidget() - Constructor for class ds.granules.results.SequencingWidget
 
SequencingWidget(FormatReader) - Constructor for class ds.granules.results.SequencingWidget
 
ServerHandler - Class in ds.granules.communication.direct.netty.server
 
ServerHandler() - Constructor for class ds.granules.communication.direct.netty.server.ServerHandler
 
setAsExecuteContinuously(String) - Method in class ds.granules.operation.ExecutionProfileSetup
 
setAsExecuteContinuously() - Method in class ds.granules.operation.OperationBase
 
setAsExecuteContinuously() - Method in interface ds.granules.operation.OperationConfiguration
Sets the operation to execute continuously as and when it is scheduled.
setAsExecuteFixedNumberOfTimes(String, int) - Method in class ds.granules.operation.ExecutionProfileSetup
 
setAsExecuteFixedNumberOfTimes(int) - Method in class ds.granules.operation.OperationBase
 
setAsExecuteFixedNumberOfTimes(int) - Method in interface ds.granules.operation.OperationConfiguration
Sets the operation as being executable a fixed number of times.
setAsExecuteOnce(String) - Method in class ds.granules.operation.ExecutionProfileSetup
 
setAsExecuteOnce() - Method in class ds.granules.operation.OperationBase
 
setAsExecuteOnce() - Method in interface ds.granules.operation.OperationConfiguration
Sets the operation as being executable exactly once.
setAsExecutePeriodically(String, long) - Method in class ds.granules.operation.ExecutionProfileSetup
 
setAsExecutePeriodically(long) - Method in class ds.granules.operation.OperationBase
 
setAsExecutePeriodically(long) - Method in interface ds.granules.operation.OperationConfiguration
Sets the operation as being executable periodically at the specified intervals.
setAsExecuteWhenDataAvailable(String) - Method in class ds.granules.operation.ExecutionProfileSetup
 
setAsExecuteWhenDataAvailable() - Method in class ds.granules.operation.OperationBase
 
setAsExecuteWhenDataAvailable() - Method in interface ds.granules.operation.OperationConfiguration
Sets the operation as being executable when data is available
setAsStayAlive(String) - Method in class ds.granules.operation.ExecutionProfileSetup
 
setAsStayAlive() - Method in class ds.granules.operation.OperationBase
 
setAsStayAlive() - Method in interface ds.granules.operation.OperationConfiguration
Sets the operation as being stayAlive.
setConditionFlag(int) - Method in class ds.granules.exchange.Exchange
 
setCurrentMessage(byte[]) - Method in class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
setDataBuffer(ByteBuffer) - Method in class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
setDatasetCollection(DatasetCollection) - Method in class ds.granules.operation.OperationBase
 
setDatasetCollection(DatasetCollection) - Method in interface ds.granules.operation.OperationConfiguration
Establish the dataset needed by the application in question
setDatasetCollectionObserver(DatasetCollectionObserver) - Method in interface ds.granules.dataset.DatasetCollection
Register an observer for the DatasetCollection
setDatasetCollectionObserver(DatasetCollectionObserver) - Method in class ds.granules.dataset.DatasetCollectionManagement
 
setDatasetDescription(String) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
setDatasetDescription(String) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
setDatasetDescription(String) - Method in interface ds.granules.dataset.StreamDataset
Sets the dataset description
setDatasetIdentifier(String) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
setDatasetIdentifier(String) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
setDatasetIdentifier(String) - Method in interface ds.granules.dataset.StreamDataset
Sets the dataset identifier
setDescription(String) - Method in class ds.granules.exchange.Exchange
 
setDomain(String) - Method in class ds.granules.operation.OperationBase
 
setDomain(String) - Method in interface ds.granules.operation.OperationConfiguration
Sets the domain for this operation
setExchangeSubType(int) - Method in class ds.granules.exchange.Exchange
 
setExchangeType(int) - Method in class ds.granules.exchange.Exchange
 
setExecutionStatus(int) - Method in class ds.granules.scheduler.ExecutableTask
Set the execution status for the lifecycle metrics.
setIdentifier(String) - Method in class ds.granules.exchange.Exchange
 
setImmutable() - Method in class ds.granules.results.ResultsWidget
 
setImmutable() - Method in class ds.granules.results.SequencingWidget
 
setInitializationComplete() - Method in class ds.granules.operation.OperationBase
 
setInitializationComplete() - Method in interface ds.granules.operation.OperationConfiguration
Mark the initialization of the application as having completed
setInitializationNeeded(boolean) - Method in class ds.granules.operation.OperationBase
 
setInitializationNeeded(boolean) - Method in interface ds.granules.operation.OperationConfiguration
Set/Unset whether this operation needs initialization.
setInstanceIdentifier(String) - Method in class ds.granules.operation.OperationBase
 
setInstanceIdentifier(String) - Method in interface ds.granules.operation.OperationConfiguration
Sets the instance identifier associated with a given operation.
setMaxSequence(long) - Method in interface ds.granules.results.SequencingInfo
Sets the max-sequence information.
setMaxSequence(long) - Method in class ds.granules.results.SequencingWidget
 
setMessageOffSet(int) - Method in class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
setMessageSize(int) - Method in class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
setNumberOfComputations(int) - Method in class ds.granules.scheduler.ResourceMetrics
 
setOperationIdentifier(String) - Method in class ds.granules.operation.OperationBase
 
setOperationIdentifier(String) - Method in interface ds.granules.operation.OperationConfiguration
This method sets the operation identifier for a given operation
setPosition(String, long) - Method in interface ds.granules.dataset.FileAccess
Deprecated.
Sets the position of filePointer for one of the file in the given dataset.
setPosition(String, long) - Method in interface ds.granules.dataset.FileDataset
Sets the position of filePointer for one of the file in the given dataset.
setPosition(String, long) - Method in class ds.granules.dataset.FileDatasetImpl
 
setPosition(String, long) - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
setProcessingDirectives(Properties) - Method in class ds.granules.operation.OperationBase
 
setProcessingDirectives(Properties) - Method in interface ds.granules.operation.OperationConfiguration
Set the processing directives for the operation
setReadPosition(int) - Method in class ds.granules.communication.direct.nio.server.ChannelReaderDataHolder
 
setReceivedOutputFrom(String) - Method in class ds.granules.operation.MapReduceBase
 
setReceivedOutputFrom(String) - Method in interface ds.granules.operation.Reduce
Mark the receipt of Output from a given Map instance
setRequest() - Method in class ds.granules.exchange.Exchange
Sets this exchange as a request.
setRespondTo(String) - Method in class ds.granules.exchange.Exchange
Set the repondTo field for this exchange.
setRespondTo(String) - Method in interface ds.granules.results.Results
Set the respondTo field for the Results
setRespondTo(String) - Method in class ds.granules.results.ResultsWidget
 
setResponse() - Method in class ds.granules.exchange.Exchange
Sets this exchange as a reponse.
setResultPayload(byte[]) - Method in interface ds.granules.results.Results
Sets the payload for the Results.
setResultPayload(byte[]) - Method in class ds.granules.results.ResultsWidget
 
setResultType(int) - Method in interface ds.granules.results.Results
Set the type of the result encapsulated within the payload.
setResultType(int) - Method in class ds.granules.results.ResultsWidget
 
setSequenceRange(long, long) - Method in interface ds.granules.results.SequencingInfo
Sets the sequence range based on the specified upper and lower-bounds.
setSequenceRange(long, long) - Method in class ds.granules.results.SequencingWidget
 
setSingleSequence(long) - Method in interface ds.granules.results.SequencingInfo
Set the single sequence Information.
setSingleSequence(long) - Method in class ds.granules.results.SequencingWidget
 
setStartTime() - Method in class ds.granules.operation.InstanceDeployer
Resets the start timer which tracks the time at which an application began execution.
setStreamId(String) - Method in class ds.granules.dataset.StreamEvent
 
setTaskCompletionInfo(String) - Method in class ds.granules.scheduler.ExecutableTask
Include some information about the completion of the task.
setTeminationConditionReached() - Method in class ds.granules.operation.OperationBase
 
setTeminationConditionReached() - Method in interface ds.granules.operation.OperationConfiguration
Mark the termination condition of this operation as having reached.
setTimestamp(long) - Method in class ds.granules.exchange.Exchange
Set the timestamp for this exchange.
setValue(String) - Method in class ds.granules.streaming.core.datatype.StreamingString
 
setVersionInformation(long) - Method in class ds.granules.operation.OperationBase
 
setVersionInformation(long) - Method in interface ds.granules.operation.OperationConfiguration
Sets the version information for this operation.
SHORT - Static variable in class ds.granules.results.ResultPayload
 
SHORT_2D_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
SHORT_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
size(String) - Method in interface ds.granules.dataset.FileAccess
Deprecated.
Returns the current size of the file in question
size(String) - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
size() - Method in class ds.granules.util.Matrix
 
sizeOfExternalLibraries() - Method in interface ds.granules.scheduler.LibraryManager
 
startedExecution(String, String, TaskLifecycleMetrics) - Method in class ds.granules.operation.InstanceDeployer
 
startedExecution(String, String, TaskLifecycleMetrics) - Method in interface ds.granules.operation.JobLifecycleObserver
This method is invoked when the first task reports that it has begun execution.
StatCollector - Class in ds.granules.communication.direct.util
 
STATUS - Static variable in class ds.granules.exchange.DeploymentMessage
 
STREAM_DATASET_IMPL - Static variable in class ds.granules.util.Constants
 
STREAM_IDENTIFIER_DELIMITER - Static variable in class ds.granules.util.Constants
 
STREAM_PROP_JOB_ID - Static variable in class ds.granules.util.Constants
 
STREAM_PROP_STREAM_BASE_ID - Static variable in class ds.granules.util.Constants
 
StreamBase - Class in ds.granules.streaming.core
This class is the base class for StreamSource and StreamProcessor.
StreamBase() - Constructor for class ds.granules.streaming.core.StreamBase
 
StreamDataset - Interface in ds.granules.dataset
The interface which augments the Dataset interface to support streaming capabilities.
streamDataset - Variable in class ds.granules.streaming.core.StreamBase
 
StreamDatasetImplLegacy - Class in ds.granules.dataset
Deprecated.
StreamDatasetImplLegacy(String, String) - Constructor for class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
StreamDatasetImplLegacy(FormatReader) - Constructor for class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
StreamEvent - Class in ds.granules.dataset
Every data type used in Granules Streaming should implement this interface.
StreamEvent() - Constructor for class ds.granules.dataset.StreamEvent
 
StreamingAccess - Interface in ds.granules.dataset
Deprecated.
StreamingDatasetException - Exception in ds.granules.streaming.core.exception
 
StreamingDatasetException(String) - Constructor for exception ds.granules.streaming.core.exception.StreamingDatasetException
 
StreamingDatasetException(String, Throwable) - Constructor for exception ds.granules.streaming.core.exception.StreamingDatasetException
 
StreamingGraphConfigurationException - Exception in ds.granules.streaming.core.exception
Thrown if there is a configuration error when defining a stream processing graph
StreamingGraphConfigurationException(String) - Constructor for exception ds.granules.streaming.core.exception.StreamingGraphConfigurationException
 
StreamingGraphConfigurationException(String, Throwable) - Constructor for exception ds.granules.streaming.core.exception.StreamingGraphConfigurationException
 
StreamingService - Class in ds.granules.scheduler
A streaming service class which abstracts minimal operations needed for communications.
StreamingString - Class in ds.granules.streaming.core.datatype
 
StreamingString() - Constructor for class ds.granules.streaming.core.datatype.StreamingString
 
StreamProcessor - Class in ds.granules.streaming.core
Any stream processing element should extend this abstract class.
StreamProcessor() - Constructor for class ds.granules.streaming.core.StreamProcessor
 
StreamPublisher - Class in ds.granules.util
 
StreamPublisher() - Constructor for class ds.granules.util.StreamPublisher
Create a new stream publisher instance.
StreamSource - Class in ds.granules.streaming.core
This class should be extended to implement a stream source.
StreamSource() - Constructor for class ds.granules.streaming.core.StreamSource
 
StreamUtil - Class in ds.granules.streaming.core
Utility methods used in the streaming package.
StreamUtil() - Constructor for class ds.granules.streaming.core.StreamUtil
 
STRING - Static variable in class ds.granules.results.ResultPayload
 
STRING_2D_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
STRING_ARRAY - Static variable in class ds.granules.results.ResultPayload
 
STRING_SYNOPSIS - Static variable in interface ds.granules.dataset.StreamingAccess
Deprecated.
 
submit(Operation, JobLifecycleObserver) - Method in class ds.granules.operation.JobSubmission
Submit the given operation for execution.
submit(Operation, String, JobLifecycleObserver) - Method in class ds.granules.operation.JobSubmission
Submit the given operation for execution.
submit(Operation, String, String, JobLifecycleObserver) - Method in class ds.granules.operation.JobSubmission
This method allows one to group a set of related tasks together in a Job.
SUCCESS - Static variable in interface ds.granules.exchange.ConditionFlag
 
supportsDataAvailabilityNotifications() - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
supportsDataAvailabilityNotifications() - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
supportsDataAvailabilityNotifications() - Method in interface ds.granules.dataset.Dataset
Indicates whether this dataset supports dynamic data availability notifications
supportsDataAvailabilityNotifications() - Method in class ds.granules.dataset.FileDatasetImpl
 
supportsDataAvailabilityNotifications() - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
supportsDataAvailabilityNotifications() - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
SuppressedException - Exception in ds.granules.scheduler
This is a utility exception class that is used when it is not possible to propagated exceptions either within a VM or to a remote VM.
SuppressedException() - Constructor for exception ds.granules.scheduler.SuppressedException
Constructs an SuppressedException with no detail message.
SuppressedException(String) - Constructor for exception ds.granules.scheduler.SuppressedException
Constructs an SuppressedException with the specified detail message.
SystemCommand - Class in ds.granules.util
This is a utility class that allows one to execute native commands from Java.
SystemCommand() - Constructor for class ds.granules.util.SystemCommand
 

T

TAG_VALUE_PAIRS - Static variable in interface ds.granules.dataset.StreamingAccess
Deprecated.
 
TaskLifecycleMetrics - Interface in ds.granules.scheduler
This is an interface that snapshots the lifecyle of a task.
TaskLifecycleMetricsReader - Class in ds.granules.exchange
 
TaskLifecycleMetricsReader(byte[]) - Constructor for class ds.granules.exchange.TaskLifecycleMetricsReader
 
TaskLifecycleObserver - Interface in ds.granules.scheduler
The observer whose method invocation track the lifetime of a task
TaskManagement - Class in ds.granules.scheduler
This is the class that is responsible for managing tasks.
TaskManagement(int, Diagnostics) - Constructor for class ds.granules.scheduler.TaskManagement
 
taskReadyToExecute() - Method in interface ds.granules.scheduler.Controller
 
terminationConditionReached() - Method in interface ds.granules.operation.Operation
This indicates if the operation has completed or not.
terminationConditionReached() - Method in class ds.granules.operation.OperationBase
 
toString() - Method in class ds.granules.dataset.DatasetCollectionManagement
 
toString() - Method in class ds.granules.exchange.DeploymentMessage
 
toString() - Method in class ds.granules.exchange.ExecutionStatus
 
toString() - Method in class ds.granules.exchange.TaskLifecycleMetricsReader
 
toString() - Method in class ds.granules.operation.ExecutionProfileSetup
 
toString() - Method in interface ds.granules.operation.Operation
A summarized String-based representation of the operation
toString() - Method in class ds.granules.operation.OperationBase
 
toString() - Method in class ds.granules.operation.ProgressTrackerWidget
 
toString() - Method in class ds.granules.scheduler.ResourceMetrics
 
triggerCallbacks(String, byte[]) - Method in class ds.granules.communication.direct.ChannelToStreamDeMultiplexer
 
TYPE_DATA - Static variable in class ds.granules.util.Constants
This will differentiate the data traffic from control traffic.

U

unloadClass() - Method in interface ds.granules.scheduler.LibraryManager
 
unloadJarLibrary() - Method in interface ds.granules.scheduler.LibraryManager
 
unloadLibrary() - Method in interface ds.granules.scheduler.Controller
 
unloadNativeLibraries() - Method in interface ds.granules.scheduler.LibraryManager
 
unmarshall(FormatReader) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
unmarshall(FormatReader) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
unmarshall(FormatReader) - Method in enum ds.granules.dataset.Dataset.DatasetType
 
unmarshall(FormatReader) - Method in interface ds.granules.dataset.StreamDataset
 
unmarshall(byte[]) - Method in class ds.granules.dataset.StreamEvent
Populate a StreamTuple object from a byte array.
unmarshall(FormatReader) - Method in class ds.granules.operation.MapReduceBase
 
unmarshall(FormatReader) - Method in enum ds.granules.operation.Operation.OperationType
 
unmarshall(FormatReader) - Method in interface ds.granules.operation.Operation
Unmarshall the operation from a set of marshalled bytes.
unmarshall(FormatReader) - Method in class ds.granules.operation.OperationBase
 
unmarshall(byte[]) - Method in class ds.granules.streaming.core.datatype.AbstractStreamEvent
 
unmarshall(FormatReader) - Method in class ds.granules.streaming.core.StreamBase
 
unmarshallAsBatch(DataInputStream) - Method in class ds.granules.dataset.StreamEvent
 
unmarshallAsBatch(DataInputStream) - Method in class ds.granules.streaming.core.datatype.AbstractStreamEvent
 
unmarshallExchangeSpecificElements(FormatReader) - Method in class ds.granules.exchange.DeploymentMessage
 
unmarshallExchangeSpecificElements(FormatReader) - Method in class ds.granules.exchange.Exchange
This method is utilized by the derived classes to reconstruct elements that are specific to the derived class.
unmarshallExchangeSpecificElements(FormatReader) - Method in class ds.granules.exchange.ExecutionStatus
 
unmarshallExchangeSpecificElements(FormatReader) - Method in class ds.granules.exchange.ResourceDiscovery
 
updateDests(List<OverlayPath>) - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
updateDestVer(long) - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
updatePath(long, int) - Method in class ds.granules.communication.direct.NIOTopicDataEvent
 
updateStatistics(int, long, long) - Method in class ds.granules.communication.direct.util.StatCollector
 
updateTaskExecutionStatus(String, String, TaskLifecycleMetrics, String) - Method in class ds.granules.operation.ProgressTrackerWidget
Updates the task execution status associated with a given task.
UUIDRetriever - Class in ds.granules.util
This class provides a small wrapper around the JUG UUIDGenerator written by Tatu Saloranta, tatu.saloranta@iki.fi.
UUIDRetriever() - Constructor for class ds.granules.util.UUIDRetriever
 

V

valueOf(String) - Static method in enum ds.granules.dataset.Dataset.DatasetType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum ds.granules.operation.Operation.OperationType
Returns the enum constant of this type with the specified name.
values() - Static method in enum ds.granules.dataset.Dataset.DatasetType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum ds.granules.operation.Operation.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
Version - Class in ds.granules.util
This class is a utility class for identifying the version of the GRANULES system.
Version() - Constructor for class ds.granules.util.Version
 

W

WAITING_FOR_DATA - Static variable in interface ds.granules.scheduler.TaskLifecycleMetrics
 
write(String, ByteBuffer) - Method in interface ds.granules.dataset.FileAccess
Deprecated.
Write the specified Buffer to the file corresponding to the specified file.
write(String, byte[]) - Method in interface ds.granules.dataset.FileAccess
Deprecated.
Writes a byte[] to a give file.
write(String, byte[]) - Method in interface ds.granules.dataset.FileDataset
Writes a byte[] to a give file.
write(String, ByteBuffer) - Method in interface ds.granules.dataset.FileDataset
Write the specified Buffer to the file corresponding to the specified file.
write(String, byte[]) - Method in class ds.granules.dataset.FileDatasetImpl
 
write(String, ByteBuffer) - Method in class ds.granules.dataset.FileDatasetImpl
 
write(String, byte[]) - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
write(String, ByteBuffer) - Method in class ds.granules.dataset.FileDatasetImplLegacy
Deprecated.
 
writeData(byte[], boolean) - Method in interface ds.granules.communication.direct.ChannelWriter
 
writeData(byte[], boolean) - Method in class ds.granules.communication.direct.netty.client.NettyChannelWriter
 
writeData(byte[], boolean) - Method in class ds.granules.communication.direct.nio.client.ChannelWriterDataHolder
 
writeIntMatrixColumn(int, int[]) - Method in class ds.granules.util.Matrix
Write a column of the matrix to the underlying file.
writeIntMatrixColumn(int, int[]) - Method in class ds.granules.util.MatrixColumnMajor
 
writeIntMatrixElement(int, int, int) - Method in class ds.granules.util.Matrix
Write a specific matrix element code>[rowId, columnId] to the file.
writeIntMatrixElement(int, int, int) - Method in class ds.granules.util.MatrixColumnMajor
 
writeIntMatrixRow(int, int[]) - Method in class ds.granules.util.Matrix
Write a row of the matrix to the underlying file.
writeIntMatrixRow(int, int[]) - Method in class ds.granules.util.MatrixColumnMajor
 
writeLongMatrixColumn(int, long[]) - Method in class ds.granules.util.Matrix
Write a column of the matrix to the underlying file.
writeLongMatrixColumn(int, long[]) - Method in class ds.granules.util.MatrixColumnMajor
 
writeLongMatrixElement(int, int, long) - Method in class ds.granules.util.Matrix
Write a specific matrix element code>[rowId, columnId] to the file.
writeLongMatrixElement(int, int, long) - Method in class ds.granules.util.MatrixColumnMajor
 
writeLongMatrixRow(int, long[]) - Method in class ds.granules.util.Matrix
Write a row of the matrix to the underlying file.
writeLongMatrixRow(int, long[]) - Method in class ds.granules.util.MatrixColumnMajor
 
writeProperties(DataOutputStream, Properties) - Method in class ds.granules.util.MarshallingUtil
Writes a java.util.Properties object to the underlying DataOutputStream
writeResults(Results) - Method in interface ds.granules.operation.MapReduce
Writes the specified results to the default output stream.
writeResults(Topic, Results) - Method in interface ds.granules.operation.MapReduce
Writes the specified results to a specific output stream.
writeResults(String, Results) - Method in interface ds.granules.operation.MapReduce
Deprecated.
writeResults(int, String, Results) - Method in interface ds.granules.operation.MapReduce
Deprecated.
writeResults(Results) - Method in class ds.granules.operation.MapReduceBase
 
writeResults(Topic, Results) - Method in class ds.granules.operation.MapReduceBase
 
writeResults(String, Results) - Method in class ds.granules.operation.MapReduceBase
Deprecated.
writeResults(int, String, Results) - Method in class ds.granules.operation.MapReduceBase
Deprecated.
writeStreamingData(TopicDataEvent) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
writeStreamingData(Topic, byte[]) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
writeStreamingData(TopicDataEvent) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
writeStreamingData(Topic, byte[]) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
writeStreamingData(TopicDataEvent) - Method in interface ds.granules.dataset.StreamDataset
This method writes data to the output dataset.
writeStreamingData(Topic, byte[]) - Method in interface ds.granules.dataset.StreamDataset
This method writes data to the output dataset.
writeStreamingData(NBEvent) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
writeStreamingData(Object, byte[]) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
writeStreamingData(int, Object, byte[]) - Method in class ds.granules.dataset.StreamDatasetImplLegacy
Deprecated.
 
writeStreamingData(NBEvent) - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
This method writes data to the output dataset.
writeStreamingData(Object, byte[]) - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
This method writes data to the output dataset.
writeStreamingData(int, Object, byte[]) - Method in interface ds.granules.dataset.StreamingAccess
Deprecated.
This method writes data to the output dataset.
writeStreamingDataAsBatch(Topic, StreamEvent) - Method in class ds.granules.communication.direct.DirectCommStreamDatasetImpl
 
writeStreamingDataAsBatch(Topic, StreamEvent) - Method in class ds.granules.communication.funnel.FunnelStreamDatasetImpl
 
writeStreamingDataAsBatch(Topic, StreamEvent) - Method in interface ds.granules.dataset.StreamDataset
 
writeString(DataOutputStream, String) - Method in class ds.granules.util.MarshallingUtil
Writes a String to the underlying DataOutputStream
writeToStream(String, byte[]) - Method in class ds.granules.scheduler.StreamingService
Writes a byte[] payload onto the specified stream
writeToStream(String, int, byte[]) - Method in class ds.granules.scheduler.StreamingService
Writes a byte[] payload onto the specified stream
writeToStream(String, StreamEvent) - Method in class ds.granules.streaming.core.StreamBase
Write a stream data element to a Stream.
writeValues(DataOutputStream) - Method in class ds.granules.streaming.core.datatype.AbstractStreamEvent
Write data type specific values to the output stream.
writeValues(DataOutputStream) - Method in class ds.granules.streaming.core.datatype.StreamingString
 

Z

ZK_ZNODE_GROUP - Static variable in class ds.granules.util.Constants
 
ZK_ZNODE_OP_ASSIGNMENTS - Static variable in class ds.granules.util.Constants
 
ZK_ZNODE_STREAMS - Static variable in class ds.granules.util.Constants
 
ZOOKEEPER_HOSTS - Static variable in class ds.granules.util.Constants
 
ZooKeeperAgent - Class in ds.granules.communication.direct
Holds the ZooKeeper client instance for each Resource.
ZooKeeperUtils - Class in ds.granules.util
 
ZooKeeperUtils() - Constructor for class ds.granules.util.ZooKeeperUtils
 
A C D E F G H I J K L M N O P Q R S T U V W Z 

Copyright © 2015. All rights reserved.