org.slf4j.Logger.info()方法的使用及代码示例

x33g5p2x  于2022-01-16 转载在 其他  
字(9.7k)|赞(0)|评价(0)|浏览(517)

本文整理了Java中org.slf4j.Logger.info()方法的一些代码示例,展示了Logger.info()的具体用法。这些代码示例主要来源于Github/Stackoverflow/Maven等平台,是从一些精选项目中提取出来的代码,具有较强的参考意义,能在一定程度帮忙到你。Logger.info()方法的具体详情如下:
包路径:org.slf4j.Logger
类名称:Logger
方法名:info

Logger.info介绍

[英]Log a message at the INFO level.
[中]

代码示例

代码示例来源:origin: apache/kafka

public void updateFailed(Throwable exception) {
  // We depend on pending calls to request another metadata update
  this.state = State.QUIESCENT;
  if (exception instanceof AuthenticationException) {
    log.warn("Metadata update failed due to authentication error", exception);
    this.authException = (AuthenticationException) exception;
  } else {
    log.info("Metadata update failed", exception);
  }
}

代码示例来源:origin: iluwatar/java-design-patterns

/**
 * Stops logging clients. This is a blocking call.
 */
public void stop() {
 service.shutdown();
 if (!service.isTerminated()) {
  service.shutdownNow();
  try {
   service.awaitTermination(1000, TimeUnit.SECONDS);
  } catch (InterruptedException e) {
   LOGGER.error("exception awaiting termination", e);
  }
 }
 LOGGER.info("Logging clients stopped");
}

代码示例来源:origin: Activiti/Activiti

protected void logException() {
  if (exception instanceof JobNotFoundException || exception instanceof ActivitiTaskAlreadyClaimedException) {
    // reduce log level, because this may have been caused because of job deletion due to cancelActiviti="true"
    log.info("Error while closing command context",
         exception);
  } else if (exception instanceof ActivitiOptimisticLockingException) {
    // reduce log level, as normally we're not interested in logging this exception
    log.debug("Optimistic locking exception : " + exception);
  } else {
    log.error("Error while closing command context",
         exception);
  }
}

代码示例来源:origin: apache/storm

private void print(List<List<Object>> keys, List<ValueUpdater> updaters) {
  for (int i = 0; i < keys.size(); i++) {
    ValueUpdater valueUpdater = updaters.get(i);
    Object arg = ((CombinerValueUpdater) valueUpdater).getArg();
    LOG.info("updateCount = {}, keys = {} => updaterArgs = {}", updateCount, keys.get(i), arg);
  }
}

代码示例来源:origin: thinkaurelius/titan

private static IResultsConsumer[] getConsumersUnsafe(IResultsConsumer... additional) throws IOException {
  List<IResultsConsumer> consumers = new ArrayList<IResultsConsumer>();
  consumers.add(new XMLConsumer(new File("jub." + Math.abs(System.nanoTime()) + ".xml")));
  consumers.add(new WriterConsumer()); // defaults to System.out
  consumers.add(new CsvConsumer("target/jub.csv"));
  if (null != System.getenv(ENV_EFFORT_GENERATE)) {
    String file = getEffortFilePath();
    Writer writer = new FileWriter(file, true);
    log.info("Opened " + file + " for appending");
    consumers.add(new TimeScaleConsumer(writer));
  }
  for (IResultsConsumer c : additional) {
    consumers.add(c);
  }
  return consumers.toArray(new IResultsConsumer[consumers.size()]);
}

代码示例来源:origin: ctripcorp/apollo

@Override
public void handleMessage(ReleaseMessage message, String channel) {
 logger.info("message received - channel: {}, message: {}", channel, message);
 String releaseMessage = message.getMessage();
 if (!Topics.APOLLO_RELEASE_TOPIC.equals(channel) || Strings.isNullOrEmpty(releaseMessage)) {
  return;
 }
 List<String> keys = STRING_SPLITTER.splitToList(releaseMessage);
 //message should be appId+cluster+namespace
 if (keys.size() != 3) {
  logger.error("message format invalid - {}", releaseMessage);
  return;
 }
 String appId = keys.get(0);
 String cluster = keys.get(1);
 String namespace = keys.get(2);
 List<GrayReleaseRule> rules = grayReleaseRuleRepository
   .findByAppIdAndClusterNameAndNamespaceName(appId, cluster, namespace);
 mergeGrayReleaseRules(rules);
}

代码示例来源:origin: opentripplanner/OpenTripPlanner

/** Output this entire chain of rides. */
public void dumpRideChain() {
  List<Ride> rides = Lists.newLinkedList();
  Ride ride = this;
  while (ride != null) {
    rides.add(0, ride);
    ride = ride.previous;
  }
  LOG.info("Path from {} to {}", rides.get(0).from, rides.get(rides.size() - 1).to);
  for (Ride r : rides) LOG.info("  {}", r.toString());
}

代码示例来源:origin: apache/storm

protected List<String> calculateParititionIdsToOwn() {
    List<String> taskPartitions = new ArrayList<String>();
    for (int i = this.taskIndex; i < config.getPartitionCount(); i += this.totalTasks) {
      taskPartitions.add(Integer.toString(i));
      logger.info(String.format("taskIndex %d owns partitionId %d.", this.taskIndex, i));
    }

    return taskPartitions;
  }
}

代码示例来源:origin: apache/flink

@Override
  public void log (int level, String category, String message, Throwable ex) {
    final String logString = "[KRYO " + category + "] " + message;
    switch (level) {
      case Log.LEVEL_ERROR:
        log.error(logString, ex);
        break;
      case Log.LEVEL_WARN:
        log.warn(logString, ex);
        break;
      case Log.LEVEL_INFO:
        log.info(logString, ex);
        break;
      case Log.LEVEL_DEBUG:
        log.debug(logString, ex);
        break;
      case Log.LEVEL_TRACE:
        log.trace(logString, ex);
        break;
    }
  }
}

代码示例来源:origin: ch.qos.logback/logback-classic

public void close() {
  closed = true;
  if (serverSocket != null) {
    try {
      serverSocket.close();
    } catch (IOException e) {
      logger.error("Failed to close serverSocket", e);
    } finally {
      serverSocket = null;
    }
  }
  logger.info("closing this server");
  synchronized (socketNodeList) {
    for (SocketNode sn : socketNodeList) {
      sn.close();
    }
  }
  if (socketNodeList.size() != 0) {
    logger.warn("Was expecting a 0-sized socketNodeList after server shutdown");
  }
}

代码示例来源:origin: alibaba/canal

private void notifyStart(File instanceDir, String destination, File[] instanceConfigs) {
  try {
    defaultAction.start(destination);
    actions.put(destination, defaultAction);
    // 启动成功后记录配置文件信息
    InstanceConfigFiles lastFile = lastFiles.get(destination);
    List<FileInfo> newFileInfo = new ArrayList<FileInfo>();
    for (File instanceConfig : instanceConfigs) {
      newFileInfo.add(new FileInfo(instanceConfig.getName(), instanceConfig.lastModified()));
    }
    lastFile.setInstanceFiles(newFileInfo);
    logger.info("auto notify start {} successful.", destination);
  } catch (Throwable e) {
    logger.error(String.format("scan add found[%s] but start failed", destination), e);
  }
}

代码示例来源:origin: Atmosphere/atmosphere

public static void interceptorsForHandler(AtmosphereFramework framework, List<Class<? extends AtmosphereInterceptor>> interceptors, List<AtmosphereInterceptor> l) {
  for (Class<? extends AtmosphereInterceptor> i : interceptors) {
    if (!framework.excludedInterceptors().contains(i.getName())
        && (!AtmosphereFramework.DEFAULT_ATMOSPHERE_INTERCEPTORS.contains(i))) {
      try {
        logger.info("Adding {}", i);
        l.add(framework.newClassInstance(AtmosphereInterceptor.class, i));
      } catch (Throwable e) {
        logger.warn("", e);
      }
    }
  }
}

代码示例来源:origin: apache/flink

@Override
public void initializeState(StateInitializationContext context) throws Exception {
  super.initializeState(context);
  checkState(checkpointedState == null,    "The reader state has already been initialized.");
  checkpointedState = context.getOperatorStateStore().getSerializableListState("splits");
  int subtaskIdx = getRuntimeContext().getIndexOfThisSubtask();
  if (context.isRestored()) {
    LOG.info("Restoring state for the {} (taskIdx={}).", getClass().getSimpleName(), subtaskIdx);
    // this may not be null in case we migrate from a previous Flink version.
    if (restoredReaderState == null) {
      restoredReaderState = new ArrayList<>();
      for (TimestampedFileInputSplit split : checkpointedState.get()) {
        restoredReaderState.add(split);
      }
      if (LOG.isDebugEnabled()) {
        LOG.debug("{} (taskIdx={}) restored {}.", getClass().getSimpleName(), subtaskIdx, restoredReaderState);
      }
    }
  } else {
    LOG.info("No state to restore for the {} (taskIdx={}).", getClass().getSimpleName(), subtaskIdx);
  }
}

代码示例来源:origin: apache/hive

static void logException(String msg, Exception e) {
 if (LOG.isDebugEnabled()) {
  LOG.debug(msg, e);
 } else {
  LOG.info(msg + ": " + e.getMessage());
 }
}

代码示例来源:origin: apache/hbase

TableDescriptor[] getTableDescriptors(List<TableName> tableNames) {
  LOG.info("getTableDescriptors == tableNames => " + tableNames);
 try (Connection conn = ConnectionFactory.createConnection(getConf());
   Admin admin = conn.getAdmin()) {
  List<TableDescriptor> tds = admin.listTableDescriptors(tableNames);
  return tds.toArray(new TableDescriptor[tds.size()]);
 } catch (IOException e) {
  LOG.debug("Exception getting table descriptors", e);
 }
 return new TableDescriptor[0];
}

代码示例来源:origin: eirslett/frontend-maven-plugin

@Override
  protected void processLine(final String line, final int logLevel) {
    if (logLevel == 0) {
      logger.info(line);
    } else {
      if (line.startsWith("npm WARN ")) {
        logger.warn(line);
      } else {
        logger.error(line);
      }
    }
  }
}

代码示例来源:origin: apache/storm

protected void rotateOutputFile(Writer writer) throws IOException {
  LOG.info("Rotating output file...");
  long start = System.currentTimeMillis();
  synchronized (this.writeLock) {
    writer.close();
    LOG.info("Performing {} file rotation actions.", this.rotationActions.size());
    for (RotationAction action : this.rotationActions) {
      action.execute(this.fs, writer.getFilePath());
    }
  }
  long time = System.currentTimeMillis() - start;
  LOG.info("File rotation took {} ms.", time);
}

代码示例来源:origin: apache/kafka

private boolean threadShouldExit(long now, long curHardShutdownTimeMs) {
  if (!hasActiveExternalCalls()) {
    log.trace("All work has been completed, and the I/O thread is now exiting.");
    return true;
  }
  if (now >= curHardShutdownTimeMs) {
    log.info("Forcing a hard I/O thread shutdown. Requests in progress will be aborted.");
    return true;
  }
  log.debug("Hard shutdown in {} ms.", curHardShutdownTimeMs - now);
  return false;
}

代码示例来源:origin: apache/hbase

@Override
 public void run() {
  try {
   LOG.info("Hook closing fs=" + this.fs);
   this.fs.close();
  } catch (NullPointerException npe) {
   LOG.debug("Need to fix these: " + npe.toString());
  } catch (IOException e) {
   LOG.warn("Running hook", e);
  }
 }
}

代码示例来源:origin: apache/geode

@Override
protected void rebalanceCache() {
 try {
  getLogger().info("Rebalancing: " + this.cache);
  RebalanceResults results = RegionHelper.rebalanceCache(this.cache);
  if (getLogger().isDebugEnabled()) {
   getLogger().debug("Done rebalancing: " + this.cache);
   getLogger().debug(RegionHelper.getRebalanceResultsMessage(results));
  }
 } catch (Exception e) {
  getLogger().warn("Rebalance failed because of the following exception:", e);
 }
}

相关文章