- abort() - Static method in class org.apache.twill.api.EventHandler.TimeoutAction
-
- aborted() - Method in class org.apache.twill.api.EventHandler
-
Invoked by the application when the application is aborted because of timeout.
- AbstractTwillRunnable - Class in org.apache.twill.api
-
This abstract class provides default implementation of the
TwillRunnable
.
- AbstractTwillRunnable() - Constructor for class org.apache.twill.api.AbstractTwillRunnable
-
- AbstractTwillRunnable(Map<String, String>) - Constructor for class org.apache.twill.api.AbstractTwillRunnable
-
- AbstractZKClient - Class in org.apache.twill.zookeeper
-
An abstract base implementation of
ZKClient
that simplifies implementation by providing forwarding for
methods that are meant to be delegated to other methods.
- AbstractZKClient() - Constructor for class org.apache.twill.zookeeper.AbstractZKClient
-
- accept(String, URL, URL) - Method in class org.apache.twill.api.ClassAcceptor
-
Invoked to determine if class can be accepted.
- ACLData - Interface in org.apache.twill.zookeeper
-
- add(String, File) - Method in interface org.apache.twill.api.TwillSpecification.Builder.LocalFileAdder
-
- add(String, URI) - Method in interface org.apache.twill.api.TwillSpecification.Builder.LocalFileAdder
-
- add(String, File, boolean) - Method in interface org.apache.twill.api.TwillSpecification.Builder.LocalFileAdder
-
- add(String, URI, boolean) - Method in interface org.apache.twill.api.TwillSpecification.Builder.LocalFileAdder
-
- add(String, File, String) - Method in interface org.apache.twill.api.TwillSpecification.Builder.LocalFileAdder
-
- add(String, URI, String) - Method in interface org.apache.twill.api.TwillSpecification.Builder.LocalFileAdder
-
- add(String, File) - Method in class org.apache.twill.api.TwillSpecification.Builder.MoreFile
-
- add(String, URI) - Method in class org.apache.twill.api.TwillSpecification.Builder.MoreFile
-
- add(String, File, boolean) - Method in class org.apache.twill.api.TwillSpecification.Builder.MoreFile
-
- add(String, URI, boolean) - Method in class org.apache.twill.api.TwillSpecification.Builder.MoreFile
-
- add(String, File, String) - Method in class org.apache.twill.api.TwillSpecification.Builder.MoreFile
-
- add(String, URI, String) - Method in class org.apache.twill.api.TwillSpecification.Builder.MoreFile
-
- add(Hosts, String, String...) - Method in interface org.apache.twill.api.TwillSpecification.Builder.MorePlacementPolicies
-
Specify hosts for a list of runnables.
- add(Racks, String, String...) - Method in interface org.apache.twill.api.TwillSpecification.Builder.MorePlacementPolicies
-
Specify racks for a list of runnables.
- add(Hosts, Racks, String, String...) - Method in interface org.apache.twill.api.TwillSpecification.Builder.MorePlacementPolicies
-
Specify hosts and racks for a list of runnables.
- add(TwillSpecification.PlacementPolicy.Type, String, String...) - Method in interface org.apache.twill.api.TwillSpecification.Builder.MorePlacementPolicies
-
Specify a placement policy for a list of runnables.
- add(TwillRunnable) - Method in interface org.apache.twill.api.TwillSpecification.Builder.MoreRunnable
-
- add(TwillRunnable, ResourceSpecification) - Method in interface org.apache.twill.api.TwillSpecification.Builder.MoreRunnable
-
- add(String, TwillRunnable) - Method in interface org.apache.twill.api.TwillSpecification.Builder.MoreRunnable
-
- add(String, TwillRunnable, ResourceSpecification) - Method in interface org.apache.twill.api.TwillSpecification.Builder.MoreRunnable
-
- add(Hosts, String, String...) - Method in class org.apache.twill.api.TwillSpecification.Builder.PlacementPolicySetter
-
- add(Racks, String, String...) - Method in class org.apache.twill.api.TwillSpecification.Builder.PlacementPolicySetter
-
- add(Hosts, Racks, String, String...) - Method in class org.apache.twill.api.TwillSpecification.Builder.PlacementPolicySetter
-
- add(TwillSpecification.PlacementPolicy.Type, String, String...) - Method in class org.apache.twill.api.TwillSpecification.Builder.PlacementPolicySetter
-
- add(TwillRunnable) - Method in class org.apache.twill.api.TwillSpecification.Builder.RunnableSetter
-
- add(TwillRunnable, ResourceSpecification) - Method in class org.apache.twill.api.TwillSpecification.Builder.RunnableSetter
-
- add(String, TwillRunnable) - Method in class org.apache.twill.api.TwillSpecification.Builder.RunnableSetter
-
- add(String, TwillRunnable, ResourceSpecification) - Method in class org.apache.twill.api.TwillSpecification.Builder.RunnableSetter
-
- add(String, int, long) - Method in interface org.apache.twill.kafka.client.KafkaConsumer.Preparer
-
Consumes messages from a given offset.
- add(ByteBuffer, Object) - Method in interface org.apache.twill.kafka.client.KafkaPublisher.Preparer
-
Adds the given message to the message set, partitioned with the given partition key.
- addAuthInfo(String, byte[]) - Method in class org.apache.twill.zookeeper.ZKClientService.Builder
-
Adds an authorization information.
- addChangeListener(BrokerService.BrokerChangeListener, Executor) - Method in interface org.apache.twill.kafka.client.BrokerService
-
Adds a listener to changes in broker list managed by this service.
- addConnectionWatcher(Watcher) - Method in class org.apache.twill.zookeeper.ForwardingZKClient
-
- addConnectionWatcher(Watcher) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Adds a Watcher
that will be called whenever connection state change.
- addFromBeginning(String, int) - Method in interface org.apache.twill.kafka.client.KafkaConsumer.Preparer
-
Consumes messages from the earliest message available.
- addJVMOptions(String) - Method in interface org.apache.twill.api.TwillPreparer
-
This methods adds extra JVM options that will be passed to the java command line for every runnable
of the application started through this
TwillPreparer
instance.
- addLatest(String, int) - Method in interface org.apache.twill.kafka.client.KafkaConsumer.Preparer
-
Consumes messages from the latest message.
- addListener(Service.Listener, Executor) - Method in class org.apache.twill.zookeeper.ForwardingZKClientService
-
- addLogHandler(LogHandler) - Method in interface org.apache.twill.api.TwillController
-
- addLogHandler(LogHandler) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds a
LogHandler
for receiving an application log.
- addOption(String, String) - Method in class org.apache.twill.api.Command.Builder
-
- addOptions(Map<String, String>) - Method in class org.apache.twill.api.Command.Builder
-
- addSecureStore(SecureStore) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds security credentials for the runtime environment to gives application access to resources.
- AfterConfigs() - Constructor for class org.apache.twill.api.TwillRunnableSpecification.Builder.AfterConfigs
-
- AfterInstances() - Constructor for class org.apache.twill.api.ResourceSpecification.Builder.AfterInstances
-
- AfterMemory() - Constructor for class org.apache.twill.api.ResourceSpecification.Builder.AfterMemory
-
- AfterName() - Constructor for class org.apache.twill.api.TwillRunnableSpecification.Builder.AfterName
-
- AfterName() - Constructor for class org.apache.twill.api.TwillSpecification.Builder.AfterName
-
- AfterUplink() - Constructor for class org.apache.twill.api.ResourceSpecification.Builder.AfterUplink
-
- announce(String, int) - Method in interface org.apache.twill.api.ServiceAnnouncer
-
Registers an endpoint that could be discovered by external party.
- announce(String, int, byte[]) - Method in interface org.apache.twill.api.ServiceAnnouncer
-
Registers an endpoint that could be discovered by external party with a payload.
- anyOrder() - Method in interface org.apache.twill.api.TwillSpecification.Builder.AfterPlacementPolicy
-
No particular execution order is needed.
- anyOrder() - Method in interface org.apache.twill.api.TwillSpecification.Builder.AfterRunnable
-
- anyOrder() - Method in class org.apache.twill.api.TwillSpecification.Builder.PlacementPolicySetter
-
- anyOrder() - Method in class org.apache.twill.api.TwillSpecification.Builder.RunnableSetter
-
- append(String) - Method in interface org.apache.twill.filesystem.Location
-
Appends the child to the current
Location
.
- apply() - Method in class org.apache.twill.api.TwillSpecification.Builder.MoreFile
-
- Arguments(String, String, String, String[]) - Constructor for class org.apache.twill.ext.BundledJarRunner.Arguments
-
- awaitTerminated() - Method in interface org.apache.twill.api.ServiceController
-
Waits for termination of the remote service.
- awaitTerminated(long, TimeUnit) - Method in interface org.apache.twill.api.ServiceController
-
Waits for termination of the remote service for no more than the given timeout limit.
- cancel() - Method in interface org.apache.twill.common.Cancellable
-
Attempts to cancel execution of this task.
- Cancellable - Interface in org.apache.twill.common
-
Something, usually a task, that can be cancelled.
- changed(BrokerService) - Method in class org.apache.twill.kafka.client.BrokerService.BrokerChangeListener
-
Invoked when there is a change in the broker list.
- changeInstances(String, int) - Method in interface org.apache.twill.api.TwillController
-
Changes the number of running instances of a given runnable.
- ClassAcceptor - Class in org.apache.twill.api
-
Class that can be used to determine if class can be accepted.
- ClassAcceptor() - Constructor for class org.apache.twill.api.ClassAcceptor
-
- close() - Method in class org.apache.twill.discovery.ZKDiscoveryService
-
- Command - Interface in org.apache.twill.api
-
Represents command objects.
- Command.Builder - Class in org.apache.twill.api
-
Builder for creating
Command
object.
- completed() - Method in class org.apache.twill.api.EventHandler
-
Invoked by the application when all containers complete.
- Compression - Enum in org.apache.twill.kafka.client
-
An Enum representing different compression codec options for publishing messages.
- Configs - Class in org.apache.twill.api
-
Defines keys and default values constants being used for configuration.
- Configs.Defaults - Class in org.apache.twill.api
-
Defines default configuration values.
- Configs.Keys - Class in org.apache.twill.api
-
Defines keys being used in configuration.
- configure() - Method in class org.apache.twill.api.AbstractTwillRunnable
-
- configure() - Method in class org.apache.twill.api.EventHandler
-
- configure() - Method in interface org.apache.twill.api.TwillApplication
-
Invoked when launching the application on the client side.
- configure() - Method in interface org.apache.twill.api.TwillRunnable
-
Called at submission time.
- configure() - Method in class org.apache.twill.ext.BundledJarRunnable
-
- consume(KafkaConsumer.MessageCallback) - Method in interface org.apache.twill.kafka.client.KafkaConsumer.Preparer
-
- containerLaunched(String, int, String) - Method in class org.apache.twill.api.EventHandler
-
Invoked by the application when new container is launched for a
TwillRunnable
.
- containerStopped(String, int, String, int) - Method in class org.apache.twill.api.EventHandler
-
Invoked by the application when the container allocated for a
TwillRunnable
is stopped.
- contains(Discoverable) - Method in interface org.apache.twill.discovery.ServiceDiscovered
-
Checks if the given discoverable contains in the current discovery list.
- context - Variable in class org.apache.twill.api.EventHandler
-
- CoreSetter() - Constructor for class org.apache.twill.api.ResourceSpecification.Builder.CoreSetter
-
- create(String) - Method in class org.apache.twill.filesystem.FileContextLocationFactory
-
- create(URI) - Method in class org.apache.twill.filesystem.FileContextLocationFactory
-
- create(String) - Method in class org.apache.twill.filesystem.LocalLocationFactory
-
- create(URI) - Method in class org.apache.twill.filesystem.LocalLocationFactory
-
- create(String) - Method in interface org.apache.twill.filesystem.LocationFactory
-
Creates an instance of
Location
of the given path.
- create(URI) - Method in interface org.apache.twill.filesystem.LocationFactory
-
- create(Credentials) - Static method in class org.apache.twill.yarn.YarnSecureStore
-
- create(String, byte[], CreateMode) - Method in class org.apache.twill.zookeeper.AbstractZKClient
-
- create(String, byte[], CreateMode, boolean) - Method in class org.apache.twill.zookeeper.AbstractZKClient
-
- create(String, byte[], CreateMode, Iterable<ACL>) - Method in class org.apache.twill.zookeeper.AbstractZKClient
-
- create(String, byte[], CreateMode, boolean, Iterable<ACL>) - Method in class org.apache.twill.zookeeper.ForwardingZKClient
-
- create(String, byte[], CreateMode) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Creates a path in zookeeper.
- create(String, byte[], CreateMode, boolean) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Creates a path in zookeeper.
- create(String, byte[], CreateMode, Iterable<ACL>) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Creates a path in zookeeper.
- create(String, byte[], CreateMode, boolean, Iterable<ACL>) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Creates a path in zookeeper, with given data and create mode.
- createArguments() - Method in class org.apache.twill.ext.BundledJarRunner.Arguments.Builder
-
- createDaemonThreadFactory(String) - Static method in class org.apache.twill.common.Threads
-
Handy method to create
ThreadFactory
that creates daemon threads with the given name format.
- createDeleteIfExists(ZKClient, String, byte[], CreateMode, boolean, ACL...) - Static method in class org.apache.twill.zookeeper.ZKOperations
-
Creates a ZK node of the given path.
- createLock(String) - Method in interface org.apache.twill.api.TwillContext
-
- createNew() - Method in interface org.apache.twill.filesystem.Location
-
Atomically creates a new, empty file named by this abstract pathname if and only if a file with this name
does not yet exist.
- createNew(String) - Method in interface org.apache.twill.filesystem.Location
-
Atomically creates a new, empty file named by this abstract pathname if and only if a file with this name
does not yet exist.
- get() - Method in class org.apache.twill.api.Hosts
-
Get the list of hosts.
- get() - Method in class org.apache.twill.api.Racks
-
Get the list of racks.
- getAck() - Method in enum org.apache.twill.kafka.client.KafkaPublisher.Ack
-
Returns the numerical ack number as understand by Kafka server.
- getACL() - Method in interface org.apache.twill.zookeeper.ACLData
-
- getACL(String) - Method in class org.apache.twill.zookeeper.ForwardingZKClient
-
- getACL(String) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Retrieves the Stat and ACL being set at the given path.
- getActualInstances() - Method in class org.apache.twill.api.EventHandler.TimeoutEvent
-
- getApplicationArguments() - Method in interface org.apache.twill.api.TwillContext
-
- getApplicationId() - Method in interface org.apache.twill.api.ResourceReport
-
Get the id of the application master.
- getApplicationName() - Method in interface org.apache.twill.api.EventHandlerContext
-
- getApplicationName() - Method in interface org.apache.twill.api.TwillRunner.LiveInfo
-
Returns name of the application.
- getApplicationRunId() - Method in interface org.apache.twill.api.TwillContext
-
Returns the
RunId
of this running application.
- getAppMasterResources() - Method in interface org.apache.twill.api.ResourceReport
-
Get the resources application master is using.
- getArgument(String) - Method in class org.apache.twill.api.AbstractTwillRunnable
-
- getArguments() - Method in class org.apache.twill.api.AbstractTwillRunnable
-
- getArguments() - Method in interface org.apache.twill.api.TwillContext
-
Returns the runtime arguments that are passed to the
TwillRunnable
.
- getArguments() - Method in class org.apache.twill.ext.BundledJarRunnable
-
- getBrokerList() - Method in interface org.apache.twill.kafka.client.BrokerService
-
Returns a comma separate string of all current brokers.
- getBrokers() - Method in interface org.apache.twill.kafka.client.BrokerService
-
Returns a live iterable that gives information for all the known brokers.
- getCause() - Method in interface org.apache.twill.api.logging.LogThrowable
-
- getChildren(String) - Method in class org.apache.twill.zookeeper.AbstractZKClient
-
- getChildren(String, Watcher) - Method in class org.apache.twill.zookeeper.ForwardingZKClient
-
- getChildren() - Method in interface org.apache.twill.zookeeper.NodeChildren
-
- getChildren(String) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Gets the list of children nodes under the given path.
- getChildren(String, Watcher) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Gets the list of children nodes under the given path and leave a watcher on the node for watching node
deletion and children nodes creation/deletion.
- getClassName() - Method in interface org.apache.twill.api.EventHandlerSpecification
-
- getClassName() - Method in interface org.apache.twill.api.logging.LogThrowable
-
Returns the name of the Throwable class.
- getClassName() - Method in interface org.apache.twill.api.TwillRunnableSpecification
-
- getCodec() - Method in enum org.apache.twill.kafka.client.Compression
-
- getCommand() - Method in interface org.apache.twill.api.Command
-
- getConfigs() - Method in class org.apache.twill.api.EventHandler
-
Returns set of configurations available at runtime for access.
- getConfigs() - Method in interface org.apache.twill.api.EventHandlerSpecification
-
- getConfigs() - Method in interface org.apache.twill.api.TwillRunnableSpecification
-
- getConfiguration() - Method in class org.apache.twill.filesystem.FileContextLocationFactory
-
- getConnectString() - Method in class org.apache.twill.zookeeper.ForwardingZKClient
-
- getConnectString() - Method in interface org.apache.twill.zookeeper.ZKClient
-
Returns the connection string used for connecting to Zookeeper.
- getConsumer() - Method in interface org.apache.twill.kafka.client.KafkaClient
-
- getContainerId() - Method in interface org.apache.twill.api.TwillRunResources
-
- getContext() - Method in class org.apache.twill.api.AbstractTwillRunnable
-
- getControllers() - Method in interface org.apache.twill.api.TwillRunner.LiveInfo
-
- getCores() - Method in interface org.apache.twill.api.ResourceSpecification
-
Deprecated.
- getData(String) - Method in class org.apache.twill.zookeeper.AbstractZKClient
-
- getData(String, Watcher) - Method in class org.apache.twill.zookeeper.ForwardingZKClient
-
- getData() - Method in interface org.apache.twill.zookeeper.NodeData
-
- getData(String) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Gets the data stored in the given path.
- getData(String, Watcher) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Gets the data stored in the given path and leave a watcher on the node for watching deletion/data changes on
the node.
- getDebugPort() - Method in interface org.apache.twill.api.TwillRunResources
-
- getDelegate() - Method in class org.apache.twill.filesystem.ForwardingLocationFactory
-
- getDelegate() - Method in class org.apache.twill.zookeeper.ForwardingZKClient
-
- getDownlink() - Method in interface org.apache.twill.api.ResourceSpecification
-
Returns the downlink bandwidth in Mbps.
- getEventHandler() - Method in interface org.apache.twill.api.TwillSpecification
-
- getExpectedInstances() - Method in class org.apache.twill.api.EventHandler.TimeoutEvent
-
- getFileContext() - Method in class org.apache.twill.filesystem.FileContextLocationFactory
-
Returns the FileContext
for the current user based on UserGroupInformation.getCurrentUser()
.
- getFileName() - Method in interface org.apache.twill.api.logging.LogEntry
-
Returns the source file name where the log emitted.
- getGroup() - Method in interface org.apache.twill.filesystem.Location
-
Returns the group of the location.
- getHomeLocation() - Method in class org.apache.twill.filesystem.FileContextLocationFactory
-
- getHomeLocation() - Method in class org.apache.twill.filesystem.LocalLocationFactory
-
- getHomeLocation() - Method in interface org.apache.twill.filesystem.LocationFactory
-
Returns the home location.
- getHost() - Method in interface org.apache.twill.api.logging.LogEntry
-
Returns hostname of where the log emitted.
- getHost() - Method in interface org.apache.twill.api.TwillContext
-
Returns the hostname that the runnable is running on.
- getHost() - Method in interface org.apache.twill.api.TwillRunResources
-
- getHost() - Method in class org.apache.twill.kafka.client.BrokerInfo
-
- getHosts() - Method in interface org.apache.twill.api.TwillSpecification.PlacementPolicy
-
- getId() - Method in interface org.apache.twill.api.RunId
-
- getInputStream() - Method in interface org.apache.twill.filesystem.Location
-
- getInstanceCount() - Method in interface org.apache.twill.api.TwillContext
-
Returns the number of running instances assigned for this
TwillRunnable
.
- getInstanceId() - Method in interface org.apache.twill.api.TwillContext
-
Returns an integer id from 0 to (instanceCount - 1).
- getInstanceId() - Method in interface org.apache.twill.api.TwillRunResources
-
- getInstances() - Method in interface org.apache.twill.api.ResourceSpecification
-
Returns number of execution instances.
- getJarFileName() - Method in class org.apache.twill.ext.BundledJarRunner.Arguments
-
- getJVMOptions() - Method in class org.apache.twill.yarn.YarnTwillRunnerService
-
Returns any extra JVM options that have been set.
- getLastModified() - Method in interface org.apache.twill.api.LocalFile
-
Returns the the last modified time of the file or -1
if unknown.
- getLeader(String, int) - Method in interface org.apache.twill.kafka.client.BrokerService
-
Returns the broker information of the current leader of the given topic and partition.
- getLibFolder() - Method in class org.apache.twill.ext.BundledJarRunner.Arguments
-
- getLineNumber() - Method in interface org.apache.twill.api.logging.LogEntry
-
Returns the line number in the source file where the log emitted.
- getLocalFiles() - Method in interface org.apache.twill.api.RuntimeSpecification
-
- getLocationFactory() - Method in interface org.apache.twill.filesystem.Location
-
Returns the location factory used to create this instance.
- getLoggerName() - Method in interface org.apache.twill.api.logging.LogEntry
-
Returns name of the logger.
- getLogLevel() - Method in interface org.apache.twill.api.logging.LogEntry
-
- getLogLevel() - Method in interface org.apache.twill.api.TwillRunResources
-
- getLogLevels() - Method in interface org.apache.twill.api.TwillRunResources
-
- getMainArgs() - Method in class org.apache.twill.ext.BundledJarRunner.Arguments
-
- getMainClassName() - Method in class org.apache.twill.ext.BundledJarRunner.Arguments
-
- getMaxHeapMemoryMB() - Method in interface org.apache.twill.api.TwillRunResources
-
- getMaxMemoryMB() - Method in interface org.apache.twill.api.TwillContext
-
Returns the amount of memory in MB the runnable is allowed to use.
- getMemoryMB() - Method in interface org.apache.twill.api.TwillRunResources
-
- getMemorySize() - Method in interface org.apache.twill.api.ResourceSpecification
-
Returns the memory size in MB.
- getMessage() - Method in interface org.apache.twill.api.logging.LogEntry
-
Returns the log message.
- getMessage() - Method in interface org.apache.twill.api.logging.LogThrowable
-
Returns the message contained inside the Throwable.
- getName() - Method in interface org.apache.twill.api.LocalFile
-
- getName() - Method in interface org.apache.twill.api.RuntimeSpecification
-
- getName() - Method in interface org.apache.twill.api.TwillRunnableSpecification
-
- getName() - Method in interface org.apache.twill.api.TwillSpecification
-
- getName() - Method in class org.apache.twill.discovery.Discoverable
-
- getName() - Method in interface org.apache.twill.discovery.ServiceDiscovered
-
Returns the name of the service being discovered.
- getName() - Method in interface org.apache.twill.filesystem.Location
-
- getNames() - Method in interface org.apache.twill.api.TwillSpecification.Order
-
- getNames() - Method in interface org.apache.twill.api.TwillSpecification.PlacementPolicy
-
- getNextOffset() - Method in interface org.apache.twill.kafka.client.FetchedMessage
-
Returns the offset for the next message to be read.
- getOffset() - Method in interface org.apache.twill.kafka.client.FetchedMessage
-
Returns the offset for the current message.
- getOptions() - Method in interface org.apache.twill.api.Command
-
- getOrders() - Method in interface org.apache.twill.api.TwillSpecification
-
- getOutputStream() - Method in interface org.apache.twill.filesystem.Location
-
- getOutputStream(String) - Method in interface org.apache.twill.filesystem.Location
-
Creates an
OutputStream
for this location with the given permission.
- getOwner() - Method in interface org.apache.twill.filesystem.Location
-
Returns the owner of the location.
- getPartition() - Method in class org.apache.twill.kafka.client.TopicPartition
-
- getPattern() - Method in interface org.apache.twill.api.LocalFile
-
- getPayload() - Method in class org.apache.twill.discovery.Discoverable
-
- getPayload() - Method in interface org.apache.twill.kafka.client.FetchedMessage
-
- getPermissions() - Method in interface org.apache.twill.filesystem.Location
-
Returns the permissions of this
Location
.
- getPlacementPolicies() - Method in interface org.apache.twill.api.TwillSpecification
-
- getPort() - Method in class org.apache.twill.kafka.client.BrokerInfo
-
- getPublisher(KafkaPublisher.Ack, Compression) - Method in interface org.apache.twill.kafka.client.KafkaClient
-
- getRacks() - Method in interface org.apache.twill.api.TwillSpecification.PlacementPolicy
-
- getRequestPath() - Method in interface org.apache.twill.zookeeper.OperationFuture
-
- getRequestTime() - Method in class org.apache.twill.api.EventHandler.TimeoutEvent
-
- getResourceReport() - Method in interface org.apache.twill.api.TwillController
-
Get a snapshot of the resources used by the application, broken down by each runnable.
- getResources() - Method in interface org.apache.twill.api.ResourceReport
-
Get all the run resources being used across all runnables.
- getResourceSpecification() - Method in interface org.apache.twill.api.RuntimeSpecification
-
- getRunId() - Method in interface org.apache.twill.api.EventHandlerContext
-
- getRunId() - Method in interface org.apache.twill.api.ServiceController
-
Returns the
RunId
of the running application.
- getRunId() - Method in interface org.apache.twill.api.TwillContext
-
- getRunnableName() - Method in class org.apache.twill.api.EventHandler.TimeoutEvent
-
- getRunnableName() - Method in interface org.apache.twill.api.logging.LogEntry
-
Returns the runnable name.
- getRunnableResources(String) - Method in interface org.apache.twill.api.ResourceReport
-
Get all the run resources being used by all instances of the specified runnable.
- getRunnables() - Method in interface org.apache.twill.api.TwillSpecification
-
- getRunnableSpecification() - Method in interface org.apache.twill.api.RuntimeSpecification
-
- getServices() - Method in interface org.apache.twill.api.ResourceReport
-
Get the list of services of the application master.
- getSessionId() - Method in class org.apache.twill.zookeeper.ForwardingZKClient
-
- getSessionId() - Method in interface org.apache.twill.zookeeper.ZKClient
-
Returns the current Zookeeper session ID of this client.
- getSize() - Method in interface org.apache.twill.api.LocalFile
-
Returns the size of the file or -1
if unknown.
- getSocketAddress() - Method in class org.apache.twill.discovery.Discoverable
-
- getSourceClassName() - Method in interface org.apache.twill.api.logging.LogEntry
-
Returns the class name where the log emitted.
- getSourceMethodName() - Method in interface org.apache.twill.api.logging.LogEntry
-
Returns the method name where the log emitted.
- getSpecification() - Method in interface org.apache.twill.api.EventHandlerContext
-
- getSpecification() - Method in interface org.apache.twill.api.TwillContext
-
- getStackTraces() - Method in interface org.apache.twill.api.logging.LogEntry
-
- getStackTraces() - Method in interface org.apache.twill.api.logging.LogThrowable
-
Returns the stack trace of the Throwable.
- getStat() - Method in interface org.apache.twill.zookeeper.ACLData
-
- getStat() - Method in interface org.apache.twill.zookeeper.NodeChildren
-
- getStat() - Method in interface org.apache.twill.zookeeper.NodeData
-
- getStore() - Method in interface org.apache.twill.api.SecureStore
-
- getStore() - Method in class org.apache.twill.yarn.YarnSecureStore
-
- getTempFile(String) - Method in interface org.apache.twill.filesystem.Location
-
Returns unique location for temporary file to be placed near this location.
- getTerminationStatus() - Method in interface org.apache.twill.api.ServiceController
-
Gets the termination status of the application represented by this controller.
- getThreadName() - Method in interface org.apache.twill.api.logging.LogEntry
-
Returns the name of the thread where the log emitted.
- getThrowable() - Method in interface org.apache.twill.api.logging.LogEntry
-
Returns the
Throwable
information emitted with the log.
- getTimeout() - Method in class org.apache.twill.api.EventHandler.TimeoutAction
-
Returns timeout in milliseconds or -1
if to abort the application.
- getTimestamp() - Method in interface org.apache.twill.api.logging.LogEntry
-
Returns timestamp of the log.
- getTopic() - Method in class org.apache.twill.kafka.client.TopicPartition
-
- getTopicPartition() - Method in interface org.apache.twill.kafka.client.FetchedMessage
-
- getType() - Method in interface org.apache.twill.api.TwillSpecification.Order
-
- getType() - Method in interface org.apache.twill.api.TwillSpecification.PlacementPolicy
-
- getUplink() - Method in interface org.apache.twill.api.ResourceSpecification
-
Returns the uplink bandwidth in Mbps.
- getURI() - Method in interface org.apache.twill.api.LocalFile
-
- getVirtualCores() - Method in interface org.apache.twill.api.ResourceSpecification
-
Returns the number of virtual CPU cores.
- getVirtualCores() - Method in interface org.apache.twill.api.TwillContext
-
Returns the number of virtual cores the runnable is allowed to use.
- getVirtualCores() - Method in interface org.apache.twill.api.TwillRunResources
-
- getZooKeeperSupplier() - Method in class org.apache.twill.zookeeper.ForwardingZKClientService
-
- getZooKeeperSupplier() - Method in interface org.apache.twill.zookeeper.ZKClientService
-
Returns a Supplier
of ZooKeeper
that gives the current ZooKeeper
in use at the moment
when Supplier.get()
get called.
- lastModified() - Method in interface org.apache.twill.filesystem.Location
-
- launchTimeout(Iterable<EventHandler.TimeoutEvent>) - Method in class org.apache.twill.api.EventHandler
-
Invoked when the number of expected instances doesn't match with number of actual instances.
- leader() - Method in interface org.apache.twill.api.ElectionHandler
-
This method will get invoked when a participant becomes a leader in a
leader election process.
- length() - Method in interface org.apache.twill.filesystem.Location
-
- limit(int, RetryStrategy) - Static method in class org.apache.twill.zookeeper.RetryStrategies
-
Creates a
RetryStrategy
that retries maximum given number of times, with the actual
delay behavior delegated to another
RetryStrategy
.
- list() - Method in interface org.apache.twill.filesystem.Location
-
List the locations under this location.
- load() - Method in class org.apache.twill.ext.BundledJarRunner
-
- load(ClassLoader) - Method in class org.apache.twill.ext.BundledJarRunner
-
- LOCAL_STAGING_DIRECTORY - Static variable in class org.apache.twill.api.Configs.Defaults
-
Default use the system temp directory for local staging files.
- LOCAL_STAGING_DIRECTORY - Static variable in class org.apache.twill.api.Configs.Keys
-
Specifies the local directory for twill to store files generated at runtime.
- LocalFile - Interface in org.apache.twill.api
-
This interface represents a local file that will be available for the container running a
TwillRunnable
.
- LocalLocationFactory - Class in org.apache.twill.filesystem
-
- LocalLocationFactory() - Constructor for class org.apache.twill.filesystem.LocalLocationFactory
-
Constructs a LocalLocationFactory that Location created will be relative to system root.
- LocalLocationFactory(File) - Constructor for class org.apache.twill.filesystem.LocalLocationFactory
-
- Location - Interface in org.apache.twill.filesystem
-
This interface defines the location and operations of a resource on the filesystem.
- LOCATION_CACHE_ANTIQUE_EXPIRY_MS - Static variable in class org.apache.twill.api.Configs.Defaults
-
Default expiration is five minutes for location cache created by different twill runner.
- LOCATION_CACHE_ANTIQUE_EXPIRY_MS - Static variable in class org.apache.twill.api.Configs.Keys
-
Setting the expiration time in milliseconds of unused files created by older runs in the location cache.
- LOCATION_CACHE_DIR - Static variable in class org.apache.twill.api.Configs.Keys
-
Setting caching directory name for location cache.
- LOCATION_CACHE_EXPIRY_MS - Static variable in class org.apache.twill.api.Configs.Defaults
-
Default expiration is one day for location cache.
- LOCATION_CACHE_EXPIRY_MS - Static variable in class org.apache.twill.api.Configs.Keys
-
Setting the expiration time in milliseconds of unused files in the location cache.
- LocationFactories - Class in org.apache.twill.filesystem
-
- LocationFactory - Interface in org.apache.twill.filesystem
-
Factory for creating instance of
Location
.
- LOG_COLLECTION_ENABLED - Static variable in class org.apache.twill.api.Configs.Defaults
-
Default to enable log collection.
- LOG_COLLECTION_ENABLED - Static variable in class org.apache.twill.api.Configs.Keys
-
Setting for enabling log collection.
- LogEntry - Interface in org.apache.twill.api.logging
-
Represents a log entry emitted by application.
- LogEntry.Level - Enum in org.apache.twill.api.logging
-
Log level.
- LogHandler - Interface in org.apache.twill.api.logging
-
Represents class that can receive logs from the application.
- LogThrowable - Interface in org.apache.twill.api.logging
-
- lookup(String, RunId) - Method in interface org.apache.twill.api.TwillRunner
-
- lookup(String) - Method in interface org.apache.twill.api.TwillRunner
-
- lookup(String, RunId) - Method in class org.apache.twill.yarn.YarnTwillRunnerService
-
- lookup(String) - Method in class org.apache.twill.yarn.YarnTwillRunnerService
-
- lookupLive() - Method in interface org.apache.twill.api.TwillRunner
-
- lookupLive() - Method in class org.apache.twill.yarn.YarnTwillRunnerService
-
- SAME_THREAD_EXECUTOR - Static variable in class org.apache.twill.common.Threads
-
A executor that execute task from the submitter thread.
- scheduleSecureStoreUpdate(SecureStoreUpdater, long, long, TimeUnit) - Method in interface org.apache.twill.api.TwillRunner
-
- scheduleSecureStoreUpdate(SecureStoreUpdater, long, long, TimeUnit) - Method in class org.apache.twill.yarn.YarnTwillRunnerService
-
- SECURE_STORE_UPDATE_LOCATION_ENABLED - Static variable in class org.apache.twill.api.Configs.Keys
-
Set this to false to disable the secure store updates done by default.
- SecureStore - Interface in org.apache.twill.api
-
Represents storage of secure tokens.
- SecureStoreRenewer - Class in org.apache.twill.api.security
-
This class is responsible for renewing the secure store used by application.
- SecureStoreRenewer() - Constructor for class org.apache.twill.api.security.SecureStoreRenewer
-
- SecureStoreUpdater - Interface in org.apache.twill.api
-
- SecureStoreWriter - Interface in org.apache.twill.api.security
-
- send() - Method in interface org.apache.twill.kafka.client.KafkaPublisher.Preparer
-
- sendCommand(Command) - Method in interface org.apache.twill.api.ServiceController
-
Sends a user command to the running application.
- sendCommand(String, Command) - Method in interface org.apache.twill.api.ServiceController
-
Sends a user command to the given runnable of the running application.
- ServiceAnnouncer - Interface in org.apache.twill.api
-
This interface provides a way to announce the availability of a service.
- ServiceController - Interface in org.apache.twill.api
-
This interface is for controlling a remote running service.
- ServiceController.TerminationStatus - Enum in org.apache.twill.api
-
Enum to represent termination status of the application when it completed.
- ServiceDiscovered - Interface in org.apache.twill.discovery
-
Represents the result of service discovery.
- ServiceDiscovered.ChangeListener - Interface in org.apache.twill.discovery
-
Represents a callback for watching changes in the discovery list.
- setACL(String, Iterable<ACL>) - Method in class org.apache.twill.zookeeper.AbstractZKClient
-
- setACL(String, Iterable<ACL>, int) - Method in class org.apache.twill.zookeeper.ForwardingZKClient
-
- setACL(String, Iterable<ACL>) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Sets the ACL of the given path if the path exists.
- setACL(String, Iterable<ACL>, int) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Sets the ACL of the given path if the path exists and version matched.
- setClassLoader(String) - Method in interface org.apache.twill.api.TwillPreparer
-
Sets the class name of the
ClassLoader
to be used for loading twill and application classes for
all containers.
- setConnectionWatcher(Watcher) - Method in class org.apache.twill.zookeeper.ZKClientService.Builder
-
Sets a Watcher
that will be called whenever connection state change.
- setCores(int) - Method in class org.apache.twill.api.ResourceSpecification.Builder.CoreSetter
-
Deprecated.
- setData(String, byte[]) - Method in class org.apache.twill.zookeeper.AbstractZKClient
-
- setData(String, byte[], int) - Method in class org.apache.twill.zookeeper.ForwardingZKClient
-
- setData(String, byte[]) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Sets the data for the given path without matching version.
- setData(String, byte[], int) - Method in interface org.apache.twill.zookeeper.ZKClient
-
Sets the data for the given path that match the given version.
- setDownlink(int, ResourceSpecification.SizeUnit) - Method in class org.apache.twill.api.ResourceSpecification.Builder.AfterUplink
-
- setGroup(String) - Method in interface org.apache.twill.filesystem.Location
-
Sets the group of the location.
- setInstances(int) - Method in class org.apache.twill.api.ResourceSpecification.Builder.AfterMemory
-
- setJarFileName(String) - Method in class org.apache.twill.ext.BundledJarRunner.Arguments.Builder
-
- setJVMOptions(String) - Method in interface org.apache.twill.api.TwillPreparer
-
This methods sets the extra JVM options that will be passed to the java command line for every runnable
of the application started through this
TwillPreparer
instance.
- setJVMOptions(String, String) - Method in interface org.apache.twill.api.TwillPreparer
-
This methods sets the extra JVM options that will be passed to the java command line for the given runnable
of the application started through this
TwillPreparer
instance.
- setJVMOptions(String) - Method in class org.apache.twill.yarn.YarnTwillRunnerService
-
This methods sets the extra JVM options that will be passed to the java command line for every application
started through this
YarnTwillRunnerService
instance.
- setLibFolder(String) - Method in class org.apache.twill.ext.BundledJarRunner.Arguments.Builder
-
- setLogLevel(LogEntry.Level) - Method in interface org.apache.twill.api.TwillPreparer
-
- setLogLevels(Map<String, LogEntry.Level>) - Method in interface org.apache.twill.api.TwillPreparer
-
Set the log levels for requested logger names for Twill applications running in a container.
- setLogLevels(String, Map<String, LogEntry.Level>) - Method in interface org.apache.twill.api.TwillPreparer
-
Set the log levels for requested logger names for a
TwillRunnable
.
- setMainArgs(String[]) - Method in class org.apache.twill.ext.BundledJarRunnable
-
- setMainArgs(String) - Method in class org.apache.twill.ext.BundledJarRunnable
-
- setMainArgs(String[]) - Method in class org.apache.twill.ext.BundledJarRunner.Arguments.Builder
-
- setMainClassName(String) - Method in class org.apache.twill.ext.BundledJarRunner.Arguments.Builder
-
- setMemory(int, ResourceSpecification.SizeUnit) - Method in class org.apache.twill.api.ResourceSpecification.Builder.MemorySetter
-
- setName(String) - Method in class org.apache.twill.api.TwillRunnableSpecification.Builder.NameSetter
-
- setName(String) - Method in class org.apache.twill.api.TwillSpecification.Builder.NameSetter
-
- setPermissions(String) - Method in interface org.apache.twill.filesystem.Location
-
Sets the permissions on this location.
- setSchedulerQueue(String) - Method in interface org.apache.twill.api.TwillPreparer
-
Sets the name of the scheduler queue to use.
- setSecureStoreRenewer(SecureStoreRenewer, long, long, long, TimeUnit) - Method in interface org.apache.twill.api.TwillRunner
-
- setSecureStoreRenewer(SecureStoreRenewer, long, long, long, TimeUnit) - Method in class org.apache.twill.yarn.YarnTwillRunnerService
-
- setSessionTimeout(int) - Method in class org.apache.twill.zookeeper.ZKClientService.Builder
-
Sets the client timeout to the give milliseconds.
- setUplink(int, ResourceSpecification.SizeUnit) - Method in class org.apache.twill.api.ResourceSpecification.Builder.AfterInstances
-
- setUser(String) - Method in interface org.apache.twill.api.TwillPreparer
-
- setVirtualCores(int) - Method in class org.apache.twill.api.ResourceSpecification.Builder.CoreSetter
-
- start() - Method in interface org.apache.twill.api.TwillPreparer
-
Starts the application.
- start(long, TimeUnit) - Method in interface org.apache.twill.api.TwillPreparer
-
Starts the application.
- start() - Method in interface org.apache.twill.api.TwillRunnerService
-
Starts the service.
- start() - Method in class org.apache.twill.yarn.YarnTwillRunnerService
-
- start() - Method in class org.apache.twill.zookeeper.ForwardingZKClientService
-
- startAndWait() - Method in class org.apache.twill.zookeeper.ForwardingZKClientService
-
- started() - Method in class org.apache.twill.api.EventHandler
-
Invoked by the application when it starts.
- state() - Method in class org.apache.twill.zookeeper.ForwardingZKClientService
-
- stop() - Method in class org.apache.twill.api.AbstractTwillRunnable
-
- stop() - Method in interface org.apache.twill.api.TwillRunnable
-
Requests to stop the running service.
- stop() - Method in interface org.apache.twill.api.TwillRunnerService
-
Stops the service.
- stop() - Method in class org.apache.twill.ext.BundledJarRunnable
-
- stop() - Method in class org.apache.twill.yarn.YarnTwillRunnerService
-
- stop() - Method in class org.apache.twill.zookeeper.ForwardingZKClientService
-
- stopAndWait() - Method in class org.apache.twill.zookeeper.ForwardingZKClientService
-
- valueOf(String) - Static method in enum org.apache.twill.api.logging.LogEntry.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.twill.api.ResourceSpecification.SizeUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.twill.api.ServiceController.TerminationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.twill.api.TwillSpecification.Order.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.twill.api.TwillSpecification.PlacementPolicy.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.twill.kafka.client.Compression
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.twill.kafka.client.KafkaPublisher.Ack
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.twill.zookeeper.RetryStrategy.OperationType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.twill.api.logging.LogEntry.Level
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.twill.api.ResourceSpecification.SizeUnit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.twill.api.ServiceController.TerminationStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.twill.api.TwillSpecification.Order.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.twill.api.TwillSpecification.PlacementPolicy.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.twill.kafka.client.Compression
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.twill.kafka.client.KafkaPublisher.Ack
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.twill.zookeeper.RetryStrategy.OperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- watchChanges(ServiceDiscovered.ChangeListener, Executor) - Method in interface org.apache.twill.discovery.ServiceDiscovered
-
- watchChildren(ZKClient, String, ZKOperations.ChildrenCallback) - Static method in class org.apache.twill.zookeeper.ZKOperations
-
- watchData(ZKClient, String, ZKOperations.DataCallback) - Static method in class org.apache.twill.zookeeper.ZKOperations
-
Watch for data changes of the given path.
- watchDeleted(ZKClient, String) - Static method in class org.apache.twill.zookeeper.ZKOperations
-
- watchDeleted(ZKClient, String, SettableFuture<String>) - Static method in class org.apache.twill.zookeeper.ZKOperations
-
- with() - Static method in class org.apache.twill.api.ResourceSpecification.Builder
-
- with() - Static method in class org.apache.twill.api.TwillRunnableSpecification.Builder
-
- with() - Static method in class org.apache.twill.api.TwillSpecification.Builder
-
- withApplicationArguments(String...) - Method in interface org.apache.twill.api.TwillPreparer
-
Sets the list of arguments that will be passed to the application.
- withApplicationArguments(Iterable<String>) - Method in interface org.apache.twill.api.TwillPreparer
-
Sets the list of arguments that will be passed to the application.
- withApplicationClassPaths(String...) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds the set of paths to the classpath on the target machine for ApplicationMaster and all runnables.
- withApplicationClassPaths(Iterable<String>) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds the set of paths to the classpath on the target machine for ApplicationMaster and all runnables.
- withArguments(String, String...) - Method in interface org.apache.twill.api.TwillPreparer
-
Sets the list of arguments that will be passed to the
TwillRunnable
identified by the given name.
- withArguments(String, Iterable<String>) - Method in interface org.apache.twill.api.TwillPreparer
-
Sets the list of arguments that will be passed to the
TwillRunnable
identified by the given name.
- withBundlerClassAcceptor(ClassAcceptor) - Method in interface org.apache.twill.api.TwillPreparer
-
Uses
ClassAcceptor
to determine the classes to include in the bundle jar for
ApplicationMaster and all runnables.
- withClassPaths(String...) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds the set of paths to the classpath on the target machine for all runnables.
- withClassPaths(Iterable<String>) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds the set of paths to the classpath on the target machine for all runnables.
- withConfigs(Map<String, String>) - Method in class org.apache.twill.api.TwillRunnableSpecification.Builder.AfterName
-
- withConfiguration(Map<String, String>) - Method in interface org.apache.twill.api.TwillPreparer
-
Overrides the default configuration with the given set of configurations.
- withConfiguration(String, Map<String, String>) - Method in interface org.apache.twill.api.TwillPreparer
-
Overrides the default configuration with the given set of configurations for the given runnable only.
- withDependencies(Class<?>...) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds extra classes that the application is dependent on and is not traceable from the application itself.
- withDependencies(Iterable<Class<?>>) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds extra classes that the application is dependent on and is not traceable from the application itself.
- withEnv(Map<String, String>) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds the set of environment variables that will be set as container environment variables for all runnables.
- withEnv(String, Map<String, String>) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds the set of environment variables that will be set as container environment variables for the given runnable.
- withEventHandler(EventHandler) - Method in interface org.apache.twill.api.TwillSpecification.Builder.AfterOrder
-
- withEventHandler(EventHandler) - Method in class org.apache.twill.api.TwillSpecification.Builder.OrderSetter
-
- withLocalFiles() - Method in class org.apache.twill.api.TwillSpecification.Builder.RuntimeSpecificationAdder
-
- withMaxRetries(String, int) - Method in interface org.apache.twill.api.TwillPreparer
-
Sets the maximum number of times (per instance) a runnable will be retried if it exits without success.
- withOrder() - Method in interface org.apache.twill.api.TwillSpecification.Builder.AfterPlacementPolicy
-
Start defining execution order.
- withOrder() - Method in interface org.apache.twill.api.TwillSpecification.Builder.AfterRunnable
-
- withOrder() - Method in class org.apache.twill.api.TwillSpecification.Builder.PlacementPolicySetter
-
- withOrder() - Method in class org.apache.twill.api.TwillSpecification.Builder.RunnableSetter
-
- withPlacementPolicy() - Method in interface org.apache.twill.api.TwillSpecification.Builder.AfterRunnable
-
- withPlacementPolicy() - Method in class org.apache.twill.api.TwillSpecification.Builder.RunnableSetter
-
- withResources(URI...) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds resources that will be available through the ClassLoader of the
runnables
.
- withResources(Iterable<URI>) - Method in interface org.apache.twill.api.TwillPreparer
-
Adds resources that will be available through the ClassLoader of the
runnables
.
- withRunnable() - Method in class org.apache.twill.api.TwillSpecification.Builder.AfterName
-
- write(SecureStore) - Method in interface org.apache.twill.api.security.SecureStoreWriter
-