本文整理汇总了Java中org.apache.helix.model.Message类的典型用法代码示例。如果您正苦于以下问题:Java Message类的具体用法?Java Message怎么用?Java Message使用的例子?那么恭喜您, 这里精选的类代码示例或许可以为您提供帮助。
Message类属于org.apache.helix.model包,在下文中一共展示了Message类的20个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于我们的系统推荐出更棒的Java代码示例。
示例1: sendShutdownRequest
import org.apache.helix.model.Message; //导入依赖的package包/类
private void sendShutdownRequest() {
Criteria criteria = new Criteria();
criteria.setInstanceName("%");
criteria.setResource("%");
criteria.setPartition("%");
criteria.setPartitionState("%");
criteria.setRecipientInstanceType(InstanceType.CONTROLLER);
criteria.setSessionSpecific(true);
Message shutdownRequest = new Message(Message.MessageType.SHUTDOWN,
HelixMessageSubTypes.APPLICATION_MASTER_SHUTDOWN.toString().toLowerCase() + UUID.randomUUID().toString());
shutdownRequest.setMsgSubType(HelixMessageSubTypes.APPLICATION_MASTER_SHUTDOWN.toString());
shutdownRequest.setMsgState(Message.MessageState.NEW);
shutdownRequest.setTgtSessionId("*");
int messagesSent = this.helixManager.getMessagingService().send(criteria, shutdownRequest);
if (messagesSent == 0) {
LOGGER.error(String.format("Failed to send the %s message to the controller", shutdownRequest.getMsgSubType()));
}
}
开发者ID:Hanmourang,项目名称:Gobblin,代码行数:21,代码来源:GobblinYarnAppLauncher.java
示例2: sendTokenFileUpdatedMessage
import org.apache.helix.model.Message; //导入依赖的package包/类
private void sendTokenFileUpdatedMessage(InstanceType instanceType) {
Criteria criteria = new Criteria();
criteria.setInstanceName("%");
criteria.setResource("%");
criteria.setPartition("%");
criteria.setPartitionState("%");
criteria.setRecipientInstanceType(instanceType);
if (instanceType == InstanceType.PARTICIPANT) {
criteria.setDataSource(Criteria.DataSource.LIVEINSTANCES);
}
criteria.setSessionSpecific(true);
Message tokenFileUpdatedMessage = new Message(Message.MessageType.USER_DEFINE_MSG,
HelixMessageSubTypes.TOKEN_FILE_UPDATED.toString().toLowerCase() + UUID.randomUUID().toString());
tokenFileUpdatedMessage.setMsgSubType(HelixMessageSubTypes.TOKEN_FILE_UPDATED.toString());
tokenFileUpdatedMessage.setMsgState(Message.MessageState.NEW);
if (instanceType == InstanceType.CONTROLLER) {
tokenFileUpdatedMessage.setTgtSessionId("*");
}
int messagesSent = this.helixManager.getMessagingService().send(criteria, tokenFileUpdatedMessage);
LOGGER.info(String.format("Sent %d token file updated message(s) to the %s", messagesSent, instanceType));
}
开发者ID:Hanmourang,项目名称:Gobblin,代码行数:24,代码来源:YarnAppSecurityManager.java
示例3: sendShutdownRequest
import org.apache.helix.model.Message; //导入依赖的package包/类
private void sendShutdownRequest() {
Criteria criteria = new Criteria();
criteria.setInstanceName("%");
criteria.setResource("%");
criteria.setPartition("%");
criteria.setPartitionState("%");
criteria.setRecipientInstanceType(InstanceType.PARTICIPANT);
criteria.setDataSource(Criteria.DataSource.LIVEINSTANCES);
criteria.setSessionSpecific(true);
Message shutdownRequest = new Message(Message.MessageType.SHUTDOWN,
HelixMessageSubTypes.WORK_UNIT_RUNNER_SHUTDOWN.toString().toLowerCase() + UUID.randomUUID().toString());
shutdownRequest.setMsgSubType(HelixMessageSubTypes.WORK_UNIT_RUNNER_SHUTDOWN.toString());
shutdownRequest.setMsgState(Message.MessageState.NEW);
int messagesSent = this.helixManager.getMessagingService().send(criteria, shutdownRequest);
if (messagesSent == 0) {
LOGGER.error(String.format("Failed to send the %s message to the participants", shutdownRequest.getMsgSubType()));
}
}
开发者ID:Hanmourang,项目名称:Gobblin,代码行数:21,代码来源:GobblinApplicationMaster.java
示例4: handleMessage
import org.apache.helix.model.Message; //导入依赖的package包/类
@Override
public HelixTaskResult handleMessage() throws InterruptedException {
String messageSubType = this._message.getMsgSubType();
if (messageSubType.equalsIgnoreCase(HelixMessageSubTypes.TOKEN_FILE_UPDATED.toString())) {
LOGGER.info("Handling message " + HelixMessageSubTypes.TOKEN_FILE_UPDATED.toString());
eventBus.post(new DelegationTokenUpdatedEvent());
HelixTaskResult helixTaskResult = new HelixTaskResult();
helixTaskResult.setSuccess(true);
return helixTaskResult;
}
throw new IllegalArgumentException(String.format("Unknown %s message subtype: %s",
Message.MessageType.USER_DEFINE_MSG.toString(), messageSubType));
}
开发者ID:Hanmourang,项目名称:Gobblin,代码行数:17,代码来源:GobblinApplicationMaster.java
示例5: onBecomeOnlineFromOffline
import org.apache.helix.model.Message; //导入依赖的package包/类
@Transition(from = "OFFLINE", to = "ONLINE")
public void onBecomeOnlineFromOffline(Message message,
NotificationContext context) {
Pair<String, String> hdfsPathAndPartition = getHdfsPathAndPartitionNum(message);
String hdfsPath = hdfsPathAndPartition.getLeft();
LOG.info("Opening " + hdfsPath);
try {
// TODO(varun): Maybe retry here.
HColumnDescriptor family = new HColumnDescriptor(Constants.HFILE_COLUMN_FAMILY);
family.setBlockCacheEnabled(isBlockCacheEnabled);
Reader r = readerFactory.createHFileReader(hdfsPath, new CacheConfig(conf, family));
resourcePartitionMap.addReader(
message.getResourceName(), hdfsPathAndPartition.getRight(), r);
} catch (IOException e) {
throw new RuntimeException(e);
}
}
开发者ID:pinterest-attic,项目名称:terrapin,代码行数:18,代码来源:OnlineOfflineStateModelFactory.java
示例6: onBecomeOnlineFromOffline
import org.apache.helix.model.Message; //导入依赖的package包/类
@Transition(from = "OFFLINE", to = "ONLINE")
public void onBecomeOnlineFromOffline(Message message, NotificationContext context) {
try {
LOGGER.info("BrokerResourceOnlineOfflineStateModel.onBecomeOnlineFromOffline() : " + message);
Builder keyBuilder = _helixManager.getHelixDataAccessor().keyBuilder();
String resourceName = message.getPartitionName();
HelixDataAccessor helixDataAccessor = _helixManager.getHelixDataAccessor();
List<InstanceConfig> instanceConfigList = helixDataAccessor.getChildValues(keyBuilder.instanceConfigs());
_helixExternalViewBasedRouting.markDataResourceOnline(
resourceName,
HelixHelper.getExternalViewForResouce(_helixManager.getClusterManagmentTool(),
_helixManager.getClusterName(), resourceName), instanceConfigList);
} catch (Exception e) {
LOGGER.error("Caught exception during OFFLINE -> ONLINE transition", e);
Utils.rethrowException(e);
throw new AssertionError("Should not reach this");
}
}
开发者ID:Hanmourang,项目名称:Pinot,代码行数:21,代码来源:BrokerResourceOnlineOfflineStateModelFactory.java
示例7: onBecomeOnlineFromOffline
import org.apache.helix.model.Message; //导入依赖的package包/类
@Transition(from = "OFFLINE", to = "ONLINE")
public void onBecomeOnlineFromOffline(Message message, NotificationContext context) {
LOGGER.debug("SegmentOnlineOfflineStateModel.onBecomeOnlineFromOffline() : " + message);
final TableType tableType = TableNameBuilder.getTableTypeFromTableName(message.getResourceName());
try {
switch (tableType) {
case OFFLINE:
onBecomeOnlineFromOfflineForOfflineSegment(message, context);
break;
case REALTIME:
onBecomeOnlineFromOfflineForRealtimeSegment(message, context);
break;
default:
throw new RuntimeException("Not supported table Type for onBecomeOnlineFromOffline message: " + message);
}
} catch (Exception e) {
if (LOGGER.isErrorEnabled()) {
LOGGER.error(
"Caught exception in state transition for OFFLINE -> ONLINE for partition" + message.getPartitionName()
+ " of table " + message.getResourceName(), e);
}
Utils.rethrowException(e);
}
}
开发者ID:Hanmourang,项目名称:Pinot,代码行数:26,代码来源:SegmentOnlineOfflineStateModelFactory.java
示例8: handleMessage
import org.apache.helix.model.Message; //导入依赖的package包/类
@Override
public HelixTaskResult handleMessage() throws InterruptedException {
String messageSubType = this._message.getMsgSubType();
if (messageSubType.equalsIgnoreCase(org.apache.gobblin.cluster.HelixMessageSubTypes.TOKEN_FILE_UPDATED.toString())) {
LOGGER.info("Handling message " + org.apache.gobblin.cluster.HelixMessageSubTypes.TOKEN_FILE_UPDATED.toString());
eventBus.post(new DelegationTokenUpdatedEvent());
HelixTaskResult helixTaskResult = new HelixTaskResult();
helixTaskResult.setSuccess(true);
return helixTaskResult;
}
throw new IllegalArgumentException(String
.format("Unknown %s message subtype: %s", Message.MessageType.USER_DEFINE_MSG.toString(), messageSubType));
}
开发者ID:apache,项目名称:incubator-gobblin,代码行数:17,代码来源:GobblinYarnTaskRunner.java
示例9: createMessageLogRecord
import org.apache.helix.model.Message; //导入依赖的package包/类
/**
* Create a ZNRecord for a message, which stores the content of the message (stored in
* simple fields) into the ZNRecord mapFields. In this way, the message update can be
* merged with the previous status update record in the zookeeper. See ZNRecord.merge()
* for more details.
*/
ZNRecord createMessageLogRecord(Message message) {
ZNRecord result = new ZNRecord(getStatusUpdateRecordName(message));
String mapFieldKey = "MESSAGE " + message.getMsgId();
result.setMapField(mapFieldKey, new TreeMap<String, String>());
// Store all the simple fields of the message in the new ZNRecord's map
// field.
for (String simpleFieldKey : message.getRecord().getSimpleFields().keySet()) {
result.getMapField(mapFieldKey).put(simpleFieldKey,
message.getRecord().getSimpleField(simpleFieldKey));
}
if (message.getResultMap() != null) {
result.setMapField("MessageResult", message.getResultMap());
}
return result;
}
开发者ID:apache,项目名称:helix,代码行数:23,代码来源:StatusUpdateUtil.java
示例10: onBecomeTimedOutFromRunning
import org.apache.helix.model.Message; //导入依赖的package包/类
@Transition(to = "TIMED_OUT", from = "RUNNING")
public String onBecomeTimedOutFromRunning(Message msg, NotificationContext context) {
String taskPartition = msg.getPartitionName();
if (_taskRunner == null) {
throw new IllegalStateException(String.format(
"Invalid state transition. There is no running task for partition %s.", taskPartition));
}
TaskResult r = _taskRunner.waitTillDone();
if (r.getStatus() != TaskResult.Status.CANCELED) {
throw new IllegalStateException(String.format(
"Partition %s received a state transition to %s but the result status code is %s.",
msg.getPartitionName(), msg.getToState(), r.getStatus()));
}
timeout_task.cancel(false);
return r.getInfo();
}
开发者ID:apache,项目名称:helix,代码行数:20,代码来源:TaskStateModel.java
示例11: reportProcessedMessage
import org.apache.helix.model.Message; //导入依赖的package包/类
public synchronized void reportProcessedMessage(Message message,
ParticipantMessageMonitor.ProcessedMessageState processedMessageState) {
if (_messageMonitor != null) { // is participant
switch (processedMessageState) {
case DISCARDED:
_messageMonitor.incrementDiscardedMessages(1);
_messageMonitor.decrementPendingMessages(1);
break;
case FAILED:
_messageMonitor.incrementFailedMessages(1);
_messageMonitor.decrementPendingMessages(1);
break;
case COMPLETED:
_messageMonitor.incrementCompletedMessages(1);
_messageMonitor.decrementPendingMessages(1);
break;
}
}
}
开发者ID:apache,项目名称:helix,代码行数:20,代码来源:ParticipantStatusMonitor.java
示例12: onBecomeCompletedFromOffline
import org.apache.helix.model.Message; //导入依赖的package包/类
@Transition(to = "COMPLETED", from = "OFFLINE")
public void onBecomeCompletedFromOffline(Message message, NotificationContext context)
throws InterruptedException {
logger.info(_partitionKey + " onBecomeCompletedFromOffline");
// Construct the inner task message from the mapfields of scheduledTaskQueue resource group
Map<String, String> messageInfo =
message.getRecord().getMapField(Message.Attributes.INNER_MESSAGE.toString());
ZNRecord record = new ZNRecord(_partitionKey);
record.getSimpleFields().putAll(messageInfo);
Message taskMessage = new Message(record);
if (logger.isDebugEnabled()) {
logger.debug(taskMessage.getRecord().getSimpleFields().toString());
}
MessageHandler handler =
_executor.createMessageHandler(taskMessage, new NotificationContext(null));
if (handler == null) {
throw new HelixException("Task message " + taskMessage.getMsgType()
+ " handler not found, task id " + _partitionKey);
}
// Invoke the internal handler to complete the task
handler.handleMessage();
logger.info(_partitionKey + " onBecomeCompletedFromOffline completed");
}
开发者ID:apache,项目名称:helix,代码行数:25,代码来源:ScheduledTaskStateModel.java
示例13: createMessageHandler
import org.apache.helix.model.Message; //导入依赖的package包/类
public MessageHandler createMessageHandler(Message message, NotificationContext changeContext) {
String msgType = message.getMsgType().toString();
MsgHandlerFactoryRegistryItem item = _hdlrFtyRegistry.get(msgType);
// Fail to find a MessageHandlerFactory for the message
// we will keep the message and the message will be handled when
// the corresponding MessageHandlerFactory is registered
if (item == null) {
LOG.warn("Fail to find message handler factory for type: " + msgType + " msgId: "
+ message.getMsgId());
return null;
}
MessageHandlerFactory handlerFactory = item.factory();
// pass the executor to msg-handler since batch-msg-handler needs task-executor to schedule
// sub-msgs
changeContext.add(MapKey.TASK_EXECUTOR.toString(), this);
return handlerFactory.createHandler(message, changeContext);
}
开发者ID:apache,项目名称:helix,代码行数:21,代码来源:HelixTaskExecutor.java
示例14: newMessage
import org.apache.helix.model.Message; //导入依赖的package包/类
private Message newMessage(String resourceName, String partitionName, String instanceName,
String fromState, String toState) {
String uuid = UUID.randomUUID().toString();
Message message = new Message(MessageType.STATE_TRANSITION, uuid);
message.setSrcName("controller");
message.setTgtName(instanceName);
message.setMsgState(MessageState.NEW);
message.setResourceName(resourceName);
message.setPartitionName(partitionName);
message.setFromState(fromState);
message.setToState(toState);
message.setTgtSessionId("sessionId");
message.setSrcSessionId("sessionId");
message.setStateModelDef("MasterSlave");
message.setStateModelFactoryName("DEFAULT");
message.setBucketSize(0);
return message;
}
开发者ID:apache,项目名称:helix,代码行数:19,代码来源:TestMsgSelectionStage.java
示例15: onBecomeOfflineFromOnline
import org.apache.helix.model.Message; //导入依赖的package包/类
public void onBecomeOfflineFromOnline(Message message, NotificationContext context) {
MockProcess.sleep(_transDelay);
logger.info(
"MockStateModel.onBecomeOfflineFromOnline(), resource " + message.getResourceName()
+ ", partition"
+ message.getPartitionName() + ", targetName: " + message.getTgtName());
try {
Thread.sleep(1);
} catch (InterruptedException e) {
e.printStackTrace();
}
verifyMessage(message);
}
开发者ID:apache,项目名称:helix,代码行数:17,代码来源:TestResourceGroupEndtoEnd.java
示例16: start
import org.apache.helix.model.Message; //导入依赖的package包/类
/**
* Start the ApplicationMaster.
*/
public void start() {
LOGGER.info("Starting the Gobblin Yarn ApplicationMaster");
// Add a shutdown hook so the task scheduler gets properly shutdown
addShutdownHook();
this.eventBus.register(this);
try {
this.helixManager.connect();
this.helixManager.addLiveInstanceChangeListener(new GobblinLiveInstanceChangeListener());
this.helixManager.getMessagingService().registerMessageHandlerFactory(
Message.MessageType.SHUTDOWN.toString(), new ControllerShutdownMessageHandlerFactory());
this.helixManager.getMessagingService().registerMessageHandlerFactory(
Message.MessageType.USER_DEFINE_MSG.toString(), new ControllerUserDefinedMessageHandlerFactory()
);
} catch (Exception e) {
LOGGER.error("HelixManager failed to connect", e);
throw Throwables.propagate(e);
}
// Register JVM metrics to collect and report
registerJvmMetrics();
// Start metric reporting
this.jmxReporter.start();
// Start all the services running in the ApplicationMaster
this.serviceManager.startAsync();
this.serviceManager.awaitHealthy();
}
开发者ID:Hanmourang,项目名称:Gobblin,代码行数:35,代码来源:GobblinApplicationMaster.java
示例17: start
import org.apache.helix.model.Message; //导入依赖的package包/类
/**
* Start this {@link GobblinWorkUnitRunner} instance.
*/
public void start() {
LOGGER.info(String.format("Starting %s in container %s",
GobblinWorkUnitRunner.class.getSimpleName(), this.containerId));
// Add a shutdown hook so the task scheduler gets properly shutdown
addShutdownHook();
try {
this.helixManager.connect();
this.helixManager.getMessagingService().registerMessageHandlerFactory(
Message.MessageType.SHUTDOWN.toString(), new ParticipantShutdownMessageHandlerFactory());
this.helixManager.getMessagingService().registerMessageHandlerFactory(
Message.MessageType.USER_DEFINE_MSG.toString(), new ParticipantUserDefinedMessageHandlerFactory());
} catch (Exception e) {
LOGGER.error("HelixManager failed to connect", e);
throw Throwables.propagate(e);
}
// Register JVM metrics to collect and report
registerJvmMetrics();
// Start metric reporting
this.jmxReporter.start();
this.serviceManager.startAsync();
this.serviceManager.awaitStopped();
}
开发者ID:Hanmourang,项目名称:Gobblin,代码行数:30,代码来源:GobblinWorkUnitRunner.java
示例18: getHdfsPathAndPartitionNum
import org.apache.helix.model.Message; //导入依赖的package包/类
static Pair<String, String> getHdfsPathAndPartitionNum(Message message) {
// Since the partition names in helix are of the form resource$120 etc., we need to
// strip out the resource from partition name.
String partitionNum = message.getPartitionName().substring(
message.getResourceName().length() + 1);
String partitionName = TerrapinUtil.formatPartitionName(Integer.parseInt(partitionNum));
String hdfsPath = TerrapinUtil.helixResourceToHdfsDir(message.getResourceName()) +
"/" + partitionName;
return new ImmutablePair(hdfsPath, partitionNum);
}
开发者ID:pinterest-attic,项目名称:terrapin,代码行数:12,代码来源:OnlineOfflineStateModelFactory.java
示例19: onBecomeOfflineFromOnline
import org.apache.helix.model.Message; //导入依赖的package包/类
@Transition(from = "ONLINE", to = "OFFLINE")
public void onBecomeOfflineFromOnline(Message message,
NotificationContext context) {
Pair<String, String> hdfsPathAndPartition = getHdfsPathAndPartitionNum(message);
String hdfsPath = hdfsPathAndPartition.getLeft();
LOG.info("Closing " + hdfsPath);
try {
Reader r = resourcePartitionMap.removeReader(message.getResourceName(),
hdfsPathAndPartition.getRight());
r.close();
} catch (Exception e) {
LOG.warn("Could not close reader for " + hdfsPath, e);
}
}
开发者ID:pinterest-attic,项目名称:terrapin,代码行数:15,代码来源:OnlineOfflineStateModelFactory.java
示例20: onBecomeOfflineFromOnline
import org.apache.helix.model.Message; //导入依赖的package包/类
@Transition(from = "ONLINE", to = "OFFLINE")
public void onBecomeOfflineFromOnline(Message message, NotificationContext context) {
try {
LOGGER.info("BrokerResourceOnlineOfflineStateModel.onBecomeOfflineFromOnline() : " + message);
String resourceName = message.getResourceName();
_helixExternalViewBasedRouting.markDataResourceOffline(resourceName);
} catch (Exception e) {
LOGGER.error("Caught exception during ONLINE -> OFFLINE transition", e);
Utils.rethrowException(e);
throw new AssertionError("Should not reach this");
}
}
开发者ID:Hanmourang,项目名称:Pinot,代码行数:13,代码来源:BrokerResourceOnlineOfflineStateModelFactory.java
注:本文中的org.apache.helix.model.Message类示例整理自Github/MSDocs等源码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。 |
请发表评论