Package | Description |
---|---|
org.apache.twill.api |
Classes in this package provides core functionality of the Twill library.
|
org.apache.twill.discovery |
Classes in this package provides service discovery implementations.
|
org.apache.twill.kafka.client |
This package provides Kafka client interfaces.
|
org.apache.twill.yarn |
Classes in this package implement the Twill API for Apache Hadoop YARN.
|
org.apache.twill.zookeeper |
This package provides functionality for ZooKeeper interactions.
|
Modifier and Type | Method and Description |
---|---|
Cancellable |
ServiceAnnouncer.announce(String serviceName,
int port)
Registers an endpoint that could be discovered by external party.
|
Cancellable |
ServiceAnnouncer.announce(String serviceName,
int port,
byte[] payload)
Registers an endpoint that could be discovered by external party with a payload.
|
Cancellable |
TwillContext.electLeader(String name,
ElectionHandler participantHandler)
Register to participate in a leader election by instances within the same
TwillApplication . |
Cancellable |
TwillRunner.scheduleSecureStoreUpdate(SecureStoreUpdater updater,
long initialDelay,
long delay,
TimeUnit unit)
Deprecated.
|
Cancellable |
TwillRunner.setSecureStoreRenewer(SecureStoreRenewer renewer,
long initialDelay,
long delay,
long retryDelay,
TimeUnit unit)
Sets and schedules a periodic renewal of
SecureStore using a given SecureStoreRenewer . |
Modifier and Type | Method and Description |
---|---|
Cancellable |
InMemoryDiscoveryService.register(Discoverable discoverable) |
Cancellable |
ZKDiscoveryService.register(Discoverable discoverable)
Registers a
Discoverable in zookeeper. |
Cancellable |
DiscoveryService.register(Discoverable discoverable)
Registers a
Discoverable service. |
Cancellable |
ServiceDiscovered.watchChanges(ServiceDiscovered.ChangeListener listener,
Executor executor)
Registers a
ServiceDiscovered.ChangeListener to watch for changes in the discovery list. |
Modifier and Type | Method and Description |
---|---|
Cancellable |
BrokerService.addChangeListener(BrokerService.BrokerChangeListener listener,
Executor executor)
Adds a listener to changes in broker list managed by this service.
|
Cancellable |
KafkaConsumer.Preparer.consume(KafkaConsumer.MessageCallback callback)
Starts the consumption as being configured by this
KafkaConsumer.Preparer . |
Modifier and Type | Method and Description |
---|---|
Cancellable |
YarnTwillRunnerService.scheduleSecureStoreUpdate(SecureStoreUpdater updater,
long initialDelay,
long delay,
TimeUnit unit) |
Cancellable |
YarnTwillRunnerService.setSecureStoreRenewer(SecureStoreRenewer renewer,
long initialDelay,
long delay,
long retryDelay,
TimeUnit unit) |
Modifier and Type | Method and Description |
---|---|
Cancellable |
ForwardingZKClient.addConnectionWatcher(org.apache.zookeeper.Watcher watcher) |
Cancellable |
ZKClient.addConnectionWatcher(org.apache.zookeeper.Watcher watcher)
Adds a
Watcher that will be called whenever connection state change. |
static Cancellable |
ZKOperations.watchChildren(ZKClient zkClient,
String path,
ZKOperations.ChildrenCallback callback) |
static Cancellable |
ZKOperations.watchData(ZKClient zkClient,
String path,
ZKOperations.DataCallback callback)
Watch for data changes of the given path.
|
Copyright © 2013-2016 The Apache Software Foundation. All rights reserved.