|
||||||||||
上一个 下一个 | 框架 无框架 |
com.taobao.metamorphosis.client 中 MetaClientException 的使用 |
---|
抛出 MetaClientException 的 com.taobao.metamorphosis.client 中的方法 | |
---|---|
void |
Shutdownable.shutdown()
|
void |
MetaTopicBrowser.shutdown()
|
void |
MetaMessageSessionFactory.shutdown()
|
void |
MessageSessionFactory.shutdown()
关闭工厂 |
抛出 MetaClientException 的 com.taobao.metamorphosis.client 中的构造方法 | |
---|---|
MetaMessageSessionFactory(MetaClientConfig metaClientConfig)
|
|
XAMetaMessageSessionFactory(MetaClientConfig metaClientConfig)
|
com.taobao.metamorphosis.client.consumer 中 MetaClientException 的使用 |
---|
抛出 MetaClientException 的 com.taobao.metamorphosis.client.consumer 中的方法 | |
---|---|
void |
SimpleMessageConsumer.completeSubscribe()
|
void |
MessageConsumer.completeSubscribe()
使得已经订阅的topic生效,此方法仅能调用一次,再次调用无效并将抛出异常 |
MessageIterator |
SimpleMessageConsumer.fetch(FetchRequest fetchRequest,
long timeout,
TimeUnit timeUnit)
|
MessageIterator |
InnerConsumer.fetch(FetchRequest fetchRequest,
long timeout,
TimeUnit timeUnit)
抓取消息 |
MessageIterator |
SimpleMessageConsumer.get(String topic,
Partition partition,
long offset,
int maxSize)
|
MessageIterator |
MessageConsumer.get(String topic,
Partition partition,
long offset,
int maxSize)
获取指定topic和分区下面的消息,默认超时10秒 |
MessageIterator |
SimpleMessageConsumer.get(String topic,
Partition partition,
long offset,
int maxSize,
long timeout,
TimeUnit timeUnit)
|
MessageIterator |
MessageConsumer.get(String topic,
Partition partition,
long offset,
int maxSize,
long timeout,
TimeUnit timeUnit)
获取指定topic和分区下面的消息,在指定时间内没有返回则抛出异常 |
MessageListener |
SubscribeInfoManager.getMessageListener(String topic,
String group)
|
long |
SimpleMessageConsumer.offset(FetchRequest fetchRequest)
|
long |
InnerConsumer.offset(FetchRequest fetchRequest)
查询offset |
void |
SimpleMessageConsumer.setSubscriptions(Collection<com.taobao.metamorphosis.client.consumer.Subscription> subscriptions)
|
void |
MessageConsumer.setSubscriptions(Collection<com.taobao.metamorphosis.client.consumer.Subscription> subscriptions)
批量订阅消息,请注意,调用此方法并不会使订阅关系立即生效,只有在调用complete方法后才生效。 |
void |
SimpleMessageConsumer.shutdown()
|
void |
MessageConsumer.shutdown()
停止消费者 |
MessageConsumer |
SimpleMessageConsumer.subscribe(String topic,
int maxSize,
MessageListener messageListener)
|
MessageConsumer |
MessageConsumer.subscribe(String topic,
int maxSize,
MessageListener messageListener)
订阅指定的消息,传入MessageListener,当有消息达到的时候主动通知MessageListener,请注意, 调用此方法并不会使订阅关系立即生效, 只有在调用complete方法后才生效,此方法可做链式调用 |
MessageConsumer |
SimpleMessageConsumer.subscribe(String topic,
int maxSize,
MessageListener messageListener,
ConsumerMessageFilter filter)
|
MessageConsumer |
MessageConsumer.subscribe(String topic,
int maxSize,
MessageListener messageListener,
ConsumerMessageFilter consumerMessageFilter)
订阅指定的消息,传入MessageListener和ConsumerMessageFilter, 当有消息到达并且ConsumerMessageFilter #accept返回true的时候,主动通知MessageListener该条消息,请注意, 调用此方法并不会使订阅关系立即生效, 只有在调用complete方法后才生效,此方法可做链式调用 |
void |
SubscribeInfoManager.subscribe(String topic,
String group,
int maxSize,
MessageListener messageListener,
ConsumerMessageFilter consumerMessageFilter)
|
com.taobao.metamorphosis.client.extension 中 MetaClientException 的使用 |
---|
抛出 MetaClientException 的 com.taobao.metamorphosis.client.extension 中的方法 | |
---|---|
void |
OrderedMetaMessageSessionFactory.shutdown()
|
抛出 MetaClientException 的 com.taobao.metamorphosis.client.extension 中的构造方法 | |
---|---|
AsyncMetaMessageSessionFactory(MetaClientConfig metaClientConfig)
|
|
ExtMetaMessageSessionFactory(MetaClientConfig metaClientConfig)
|
|
MetaBroadcastMessageSessionFactory(MetaClientConfig metaClientConfig)
|
|
OrderedMetaMessageSessionFactory(MetaClientConfig metaClientConfig)
|
com.taobao.metamorphosis.client.extension.consumer 中 MetaClientException 的使用 |
---|
抛出 MetaClientException 的 com.taobao.metamorphosis.client.extension.consumer 中的方法 | |
---|---|
void |
RecoverNotifyManager.shutdown()
|
com.taobao.metamorphosis.client.extension.producer 中 MetaClientException 的使用 |
---|
com.taobao.metamorphosis.client.extension.producer 中 MetaClientException 的子类 | |
---|---|
class |
AvailablePartitionNumException
表示某topic当前可用的分区个数不正确,比如跟期望的总数不一致等 |
抛出 MetaClientException 的 com.taobao.metamorphosis.client.extension.producer 中的方法 | |
---|---|
Partition |
OrderedMessagePartitionSelector.getPartition(String topic,
List<Partition> partitions,
Message message)
|
SendResult |
OrderedMessageProducer.sendMessage(Message message,
long timeout,
TimeUnit unit)
|
com.taobao.metamorphosis.client.extension.spring 中 MetaClientException 的使用 |
---|
抛出 MetaClientException 的 com.taobao.metamorphosis.client.extension.spring 中的方法 | |
---|---|
T |
MessageBodyConverter.fromByteArray(byte[] bs)
Convert a byte array to message object. |
Serializable |
JavaSerializationMessageBodyConverter.fromByteArray(byte[] bs)
|
protected MessageConsumer |
MessageListenerContainer.getMessageConsumer(MetaqTopic topic)
|
byte[] |
JavaSerializationMessageBodyConverter.toByteArray(Serializable body)
|
byte[] |
MessageBodyConverter.toByteArray(T body)
Convert a message object to byte array. |
com.taobao.metamorphosis.client.producer 中 MetaClientException 的使用 |
---|
抛出 MetaClientException 的 com.taobao.metamorphosis.client.producer 中的方法 | |
---|---|
protected void |
SimpleMessageProducer.beforeSendMessageFirstTime(String serverUrl)
在第一次发送前开始事务 |
void |
SimpleMessageProducer.beginTransaction()
开启一个事务并关联到当前线程 |
void |
MessageProducer.beginTransaction()
开启一个事务并关联到当前线程,在事务内发送的消息将作为一个单元提交给服务器,要么全部发送成功,要么全部失败 |
protected void |
SimpleMessageProducer.checkMessage(Message message)
|
void |
SimpleMessageProducer.commit()
提交事务,将事务内发送的消息持久化,此方法仅能在beginTransaction之后调用 |
void |
MessageProducer.commit()
提交当前事务,将事务内发送的消息持久化,此方法仅能在beginTransaction之后调用 |
Partition |
PartitionSelector.getPartition(String topic,
List<Partition> partitions,
Message message)
根据topic、message从partitions列表中选择分区 |
Partition |
AbstractPartitionSelector.getPartition(String topic,
List<Partition> partitions,
Message message)
|
Partition |
RoundRobinPartitionSelector.getPartition0(String topic,
List<Partition> partitions,
Message message)
|
Partition |
RandomPartitionSelector.getPartition0(String topic,
List<Partition> partitions,
Message message)
|
abstract Partition |
AbstractPartitionSelector.getPartition0(String topic,
List<Partition> partitions,
Message message)
|
protected TransactionId |
SimpleMessageProducer.getTransactionId()
返回事务id |
int |
SimpleMessageProducer.getTransactionTimeout()
|
int |
MessageProducer.getTransactionTimeout()
返回当前设置的事务超时时间,默认为0,表示永不超时 |
XAResource |
XAMessageProducer.getXAResource()
返回一个XAResource对象。 |
XAResource |
SimpleXAMessageProducer.getXAResource()
|
void |
SimpleMessageProducer.rollback()
回滚事务内所发送的任何消息,此方法仅能在beginTransaction之后调用 |
void |
MessageProducer.rollback()
回滚当前事务内所发送的任何消息,此方法仅能在beginTransaction之后调用 |
Partition |
ProducerZooKeeper.selectPartition(String topic,
Message message,
PartitionSelector partitionSelector)
根据topic和message选择分区 |
SendResult |
SimpleMessageProducer.sendMessage(Message message)
|
SendResult |
MessageProducer.sendMessage(Message message)
发送消息 |
SendResult |
SimpleMessageProducer.sendMessage(Message message,
long timeout,
TimeUnit unit)
|
SendResult |
MessageProducer.sendMessage(Message message,
long timeout,
TimeUnit unit)
发送消息,如果超出指定的时间内没有返回,则抛出异常 |
protected SendResult |
SimpleMessageProducer.sendMessageToServer(Message message,
long timeout,
TimeUnit unit)
正常的消息发送到服务器 |
void |
SimpleMessageProducer.setTransactionTimeout(int seconds)
|
void |
MessageProducer.setTransactionTimeout(int seconds)
设置事务超时时间,从事务开始计时,如果超过设定时间还没有提交或者回滚,则服务端将无条件回滚该事务。 |
void |
SimpleXAMessageProducer.shutdown()
|
void |
SimpleMessageProducer.shutdown()
|
void |
MessageProducer.shutdown()
关闭生产者,释放资源 |
com.taobao.metamorphosis.client.transaction 中 MetaClientException 的使用 |
---|
抛出 MetaClientException 的 com.taobao.metamorphosis.client.transaction 中的方法 | |
---|---|
void |
TransactionContext.begin()
下列方法为本地事务实现,begin,commit和rollback |
void |
TransactionContext.commit()
|
void |
TransactionContext.rollback()
|
com.taobao.metamorphosis.exception 中 MetaClientException 的使用 |
---|
com.taobao.metamorphosis.exception 中 MetaClientException 的子类 | |
---|---|
class |
InvalidMessageException
|
class |
MetaOpeartionTimeoutException
|
class |
NetworkException
|
class |
TransactionInProgressException
事务进行中异常 |
com.taobao.metamorphosis.metaslave 中 MetaClientException 的使用 |
---|
抛出 MetaClientException 的 com.taobao.metamorphosis.metaslave 中的方法 | |
---|---|
static SlaveMetaMessageSessionFactory |
SlaveMetaMessageSessionFactory.create(MetaClientConfig metaClientConfig,
int brokerId)
|
抛出 MetaClientException 的 com.taobao.metamorphosis.metaslave 中的构造方法 | |
---|---|
SubscribeHandler(MetaMorphosisBroker broker)
|
com.taobao.metamorphosis.tools.monitor.core 中 MetaClientException 的使用 |
---|
抛出 MetaClientException 的 com.taobao.metamorphosis.tools.monitor.core 中的构造方法 | |
---|---|
MsgReceiver(String serverUrl,
MonitorConfig monitorConfig)
|
|
MsgSender(String serverUrl,
String topicString,
MonitorConfig monitorConfig)
|
|
||||||||||
上一个 下一个 | 框架 无框架 |