在Windows下面运行hadoop的MapReduce程序的方法:

1.下载hadoop的安装包,这里使用的是"hadoop-2.6.4.tar.gz":

2.将安装包直接解压到D盘根目录:

3.配置环境变量:

4.下载hadoop的eclipse插件,并将插件放到eclipse的plugins目录下:

5.打开Eclipse,选择菜单"Window"-->"Preferences",在左侧找到"Hadoop Map/Reduce",

  在右侧选择hadoop的目录:

6.打开菜单"Window"中的"Show View"窗口,选择"Map/Reduce Locations":

7:在打开的"Map/Reduce Locations"面板中,点击小象图标,打开新建配置窗口:

8.按照下图所示,填写hadoop集群的主机地址和端口:

9.新创建的hadoop集群连接配置,右上角的齿轮可以修改配置信息:

10.打开菜单"Window"中的"Show View"窗口,找到"Project Explorer":

11.在"Project Explorer"面板中找到"DFS Locations",展开下面的菜单就可以连接上HDFS,

可以直接看到HDFS中的目录和文件:

12.在"Project Explorer"面板中点击鼠标右键,选择新建,就可以创建"Map/Reduce"项目了:

13.下面我们创建了一个名为"hadoop-test"的项目,可以看到它自动帮我们导入了很多的jar包:

14.在项目的src下面创建log4j.properties文件,内容如下:

log4j.rootLogger=debug,stdout,R
log4j.appender.stdout=org.apache.log4j.ConsoleAppender
log4j.appender.stdout.layout=org.apache.log4j.PatternLayout
log4j.appender.stdout.layout.ConversionPattern=%5p - %m%n
log4j.appender.R=org.apache.log4j.RollingFileAppender
log4j.appender.R.File=mapreduce_test.log
log4j.appender.R.MaxFileSize=1MB
log4j.appender.R.MaxBackupIndex=
log4j.appender.R.layout=org.apache.log4j.PatternLayout
log4j.appender.R.layout.ConversionPattern=%p %t %c - %m%n
log4j.logger.com.codefutures=DEBUG

15.在src下面创建org.apache.hadoop.io.nativeio包,并将hadoop源码中的NativeIO.java类拷贝到该包下(这一步是从网上看的,不知道有什么用)。

NativeIO.java类所在路径为:hadoop-2.6.4-src\hadoop-common-project\hadoop-common\src\main\java\org\apache\hadoop\io\nativeio

16.修改NativeIO.java类中的如下部分,返回"true"即可:

17.下面来写一个hadoop的MapReduce程序,经典的wordcount(单词计数)程序,代码如下(共3个java类):

(1)WordCountDriver.java类:

 package com.xuebusi.hadoop.mr.windows;

 import org.apache.hadoop.conf.Configuration;
import org.apache.hadoop.fs.Path;
import org.apache.hadoop.io.IntWritable;
import org.apache.hadoop.io.Text;
import org.apache.hadoop.mapreduce.Job;
import org.apache.hadoop.mapreduce.lib.input.FileInputFormat;
import org.apache.hadoop.mapreduce.lib.input.TextInputFormat;
import org.apache.hadoop.mapreduce.lib.output.FileOutputFormat; public class WordCountDriver { public static void main(String[] args) throws Exception { Configuration conf = new Configuration();
Job job = Job.getInstance(conf); job.setJarByClass(WordCountDriver.class); job.setMapperClass(WordCountMapper.class);
job.setReducerClass(WordCountReducer.class); job.setMapOutputKeyClass(Text.class);
job.setMapOutputValueClass(IntWritable.class); job.setOutputKeyClass(Text.class);
job.setOutputValueClass(IntWritable.class); job.setInputFormatClass(TextInputFormat.class); FileInputFormat.setInputPaths(job, new Path("c:/wordcount/input"));
FileOutputFormat.setOutputPath(job, new Path("c:/wordcount/output")); boolean res = job.waitForCompletion(true);
System.exit(res ? 0 : 1); } }

(2)WordCountMapper.java类:

 package com.xuebusi.hadoop.mr.windows;

 import java.io.IOException;

 import org.apache.hadoop.io.IntWritable;
import org.apache.hadoop.io.LongWritable;
import org.apache.hadoop.io.Text;
import org.apache.hadoop.mapreduce.Mapper; public class WordCountMapper extends Mapper<LongWritable, Text, Text, IntWritable> { @Override
protected void map(LongWritable key, Text value, Context context)
throws IOException, InterruptedException {
// TODO Auto-generated method stub
//super.map(key, value, context); String line = value.toString();
String[] words = line.split(" "); for (String word : words) {
context.write(new Text(word), new IntWritable(1));
}
}
}

(3)WordCountReducer.java类:

 package com.xuebusi.hadoop.mr.windows;

 import java.io.IOException;

 import org.apache.hadoop.io.IntWritable;
import org.apache.hadoop.io.Text;
import org.apache.hadoop.mapreduce.Reducer; public class WordCountReducer extends Reducer<Text, IntWritable, Text, IntWritable> { @Override
protected void reduce(Text key, Iterable<IntWritable> values, Context context)
throws IOException, InterruptedException {
// TODO Auto-generated method stub
// super.reduce(arg0, arg1, arg2); int count = 0;
for (IntWritable value : values) {
count += value.get();
} context.write(new Text(key), new IntWritable(count));
} }

18.准备点数据,在"c:/wordcount/input"目录下面创建"words.txt"文件,输入一些文本,并用空格隔开:

18.在Eclipse中,运行WordCountDriver类中的main方法(右键Run As-->Java Application),可以在控制台看到如下日志信息:

 DEBUG - Handling deprecation for dfs.image.compression.codec
DEBUG - Handling deprecation for mapreduce.job.reduces
DEBUG - Handling deprecation for mapreduce.job.complete.cancel.delegation.tokens
DEBUG - Handling deprecation for mapreduce.jobhistory.recovery.store.class
DEBUG - Handling deprecation for hadoop.security.group.mapping.ldap.search.filter.user
DEBUG - Handling deprecation for dfs.namenode.enable.retrycache
DEBUG - Handling deprecation for yarn.nodemanager.sleep-delay-before-sigkill.ms
DEBUG - Handling deprecation for mapreduce.jobhistory.joblist.cache.size
DEBUG - Handling deprecation for mapreduce.tasktracker.healthchecker.interval
DEBUG - Handling deprecation for mapreduce.jobtracker.heartbeats.in.second
DEBUG - Handling deprecation for mapreduce.jobtracker.persist.jobstatus.dir
DEBUG - Handling deprecation for dfs.namenode.backup.http-address
DEBUG - Handling deprecation for hadoop.rpc.protection
DEBUG - Handling deprecation for dfs.client.mmap.enabled
DEBUG - Handling deprecation for yarn.app.mapreduce.am.container.log.backups
DEBUG - Handling deprecation for ftp.stream-buffer-size
DEBUG - Handling deprecation for dfs.namenode.https-address
DEBUG - Handling deprecation for yarn.timeline-service.address
DEBUG - Handling deprecation for dfs.ha.log-roll.period
DEBUG - Handling deprecation for yarn.nodemanager.recovery.enabled
DEBUG - Handling deprecation for mapreduce.input.fileinputformat.numinputfiles
DEBUG - Handling deprecation for hadoop.security.groups.negative-cache.secs
DEBUG - Handling deprecation for yarn.resourcemanager.admin.client.thread-count
DEBUG - Handling deprecation for dfs.datanode.fsdatasetcache.max.threads.per.volume
DEBUG - Handling deprecation for file.client-write-packet-size
DEBUG - Handling deprecation for hadoop.http.authentication.simple.anonymous.allowed
DEBUG - Handling deprecation for yarn.timeline-service.leveldb-timeline-store.path
DEBUG - Handling deprecation for yarn.resourcemanager.proxy-user-privileges.enabled
DEBUG - Handling deprecation for dfs.datanode.drop.cache.behind.reads
DEBUG - Handling deprecation for yarn.nodemanager.log.retain-seconds
DEBUG - Handling deprecation for dfs.image.transfer.bandwidthPerSec
DEBUG - Handling deprecation for yarn.resourcemanager.work-preserving-recovery.scheduling-wait-ms
DEBUG - Handling deprecation for hadoop.registry.zk.session.timeout.ms
DEBUG - Handling deprecation for dfs.datanode.slow.io.warning.threshold.ms
DEBUG - Handling deprecation for mapreduce.tasktracker.instrumentation
DEBUG - Handling deprecation for ha.failover-controller.cli-check.rpc-timeout.ms
DEBUG - Handling deprecation for yarn.nodemanager.linux-container-executor.cgroups.hierarchy
DEBUG - Handling deprecation for dfs.namenode.write.stale.datanode.ratio
DEBUG - Handling deprecation for hadoop.security.groups.cache.warn.after.ms
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.fetch.retry.timeout-ms
DEBUG - Handling deprecation for mapreduce.jobhistory.client.thread-count
DEBUG - Handling deprecation for io.mapfile.bloom.size
DEBUG - Handling deprecation for yarn.nodemanager.docker-container-executor.exec-name
DEBUG - Handling deprecation for yarn.resourcemanager.work-preserving-recovery.enabled
DEBUG - Handling deprecation for dfs.ha.fencing.ssh.connect-timeout
DEBUG - Handling deprecation for yarn.resourcemanager.zk-num-retries
DEBUG - Handling deprecation for hadoop.registry.zk.root
DEBUG - Handling deprecation for s3.bytes-per-checksum
DEBUG - Handling deprecation for yarn.app.mapreduce.am.container.log.limit.kb
DEBUG - Handling deprecation for dfs.namenode.edit.log.autoroll.check.interval.ms
DEBUG - Handling deprecation for fs.automatic.close
DEBUG - Handling deprecation for fs.trash.interval
DEBUG - Handling deprecation for dfs.journalnode.https-address
DEBUG - Handling deprecation for yarn.timeline-service.ttl-ms
DEBUG - Handling deprecation for hadoop.security.authentication
DEBUG - Handling deprecation for fs.defaultFS
DEBUG - Handling deprecation for nfs.rtmax
DEBUG - Handling deprecation for hadoop.ssl.server.conf
DEBUG - Handling deprecation for ipc.client.connect.max.retries
DEBUG - Handling deprecation for yarn.resourcemanager.delayed.delegation-token.removal-interval-ms
DEBUG - Handling deprecation for dfs.journalnode.http-address
DEBUG - Handling deprecation for dfs.namenode.xattrs.enabled
DEBUG - Handling deprecation for dfs.datanode.shared.file.descriptor.paths
DEBUG - Handling deprecation for mapreduce.jobtracker.taskscheduler
DEBUG - Handling deprecation for mapreduce.job.speculative.speculativecap
DEBUG - Handling deprecation for yarn.timeline-service.store-class
DEBUG - Handling deprecation for yarn.am.liveness-monitor.expiry-interval-ms
DEBUG - Handling deprecation for mapreduce.output.fileoutputformat.compress
DEBUG - Handling deprecation for dfs.user.home.dir.prefix
DEBUG - Handling deprecation for net.topology.node.switch.mapping.impl
DEBUG - Handling deprecation for dfs.namenode.replication.considerLoad
DEBUG - Handling deprecation for dfs.namenode.fs-limits.min-block-size
DEBUG - Handling deprecation for fs.swift.impl
DEBUG - Handling deprecation for dfs.namenode.audit.loggers
DEBUG - Handling deprecation for mapreduce.job.max.split.locations
DEBUG - Handling deprecation for yarn.resourcemanager.address
DEBUG - Handling deprecation for mapreduce.job.counters.max
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.fetch.retry.enabled
DEBUG - Handling deprecation for dfs.client.block.write.retries
DEBUG - Handling deprecation for dfs.short.circuit.shared.memory.watcher.interrupt.check.ms
DEBUG - Handling deprecation for dfs.namenode.resource.checked.volumes.minimum
DEBUG - Handling deprecation for io.map.index.interval
DEBUG - Handling deprecation for mapred.child.java.opts
DEBUG - Handling deprecation for mapreduce.tasktracker.local.dir.minspacestart
DEBUG - Handling deprecation for mapreduce.client.progressmonitor.pollinterval
DEBUG - Handling deprecation for dfs.client.https.keystore.resource
DEBUG - Handling deprecation for mapreduce.task.profile.map.params
DEBUG - Handling deprecation for mapreduce.jobtracker.tasktracker.maxblacklists
DEBUG - Handling deprecation for mapreduce.job.queuename
DEBUG - Handling deprecation for hadoop.registry.zk.quorum
DEBUG - Handling deprecation for yarn.app.mapreduce.client-am.ipc.max-retries-on-timeouts
DEBUG - Handling deprecation for yarn.nodemanager.localizer.address
DEBUG - Handling deprecation for io.mapfile.bloom.error.rate
DEBUG - Handling deprecation for yarn.nodemanager.delete.thread-count
DEBUG - Handling deprecation for mapreduce.job.split.metainfo.maxsize
DEBUG - Handling deprecation for yarn.scheduler.maximum-allocation-vcores
DEBUG - Handling deprecation for mapred.mapper.new-api
DEBUG - Handling deprecation for mapreduce.job.dir
DEBUG - Handling deprecation for yarn.app.mapreduce.am.resource.mb
DEBUG - Handling deprecation for dfs.datanode.dns.nameserver
DEBUG - Handling deprecation for dfs.client.slow.io.warning.threshold.ms
DEBUG - Handling deprecation for mapreduce.job.reducer.preempt.delay.sec
DEBUG - Handling deprecation for yarn.nodemanager.disk-health-checker.min-free-space-per-disk-mb
DEBUG - Handling deprecation for mapreduce.map.output.compress.codec
DEBUG - Handling deprecation for dfs.namenode.accesstime.precision
DEBUG - Handling deprecation for fs.s3a.connection.maximum
DEBUG - Handling deprecation for mapreduce.map.log.level
DEBUG - Handling deprecation for io.seqfile.compress.blocksize
DEBUG - Handling deprecation for ipc.client.ping
DEBUG - Handling deprecation for mapreduce.tasktracker.taskcontroller
DEBUG - Handling deprecation for hadoop.security.groups.cache.secs
DEBUG - Handling deprecation for dfs.datanode.cache.revocation.timeout.ms
DEBUG - Handling deprecation for dfs.client.context
DEBUG - Handling deprecation for mapreduce.input.lineinputformat.linespermap
DEBUG - Handling deprecation for mapreduce.job.end-notification.max.attempts
DEBUG - Handling deprecation for yarn.nodemanager.linux-container-executor.nonsecure-mode.local-user
DEBUG - Handling deprecation for yarn.nodemanager.webapp.address
DEBUG - Handling deprecation for mapreduce.job.submithostname
DEBUG - Handling deprecation for mapreduce.jobhistory.recovery.enable
DEBUG - Handling deprecation for mapreduce.jobtracker.expire.trackers.interval
DEBUG - Handling deprecation for yarn.resourcemanager.webapp.address
DEBUG - Handling deprecation for hadoop.security.kms.client.encrypted.key.cache.num.refill.threads
DEBUG - Handling deprecation for yarn.nodemanager.health-checker.interval-ms
DEBUG - Handling deprecation for mapreduce.jobhistory.loadedjobs.cache.size
DEBUG - Handling deprecation for hadoop.security.authorization
DEBUG - Handling deprecation for mapreduce.job.map.output.collector.class
DEBUG - Handling deprecation for mapreduce.am.max-attempts
DEBUG - Handling deprecation for fs.ftp.host
DEBUG - Handling deprecation for fs.s3a.attempts.maximum
DEBUG - Handling deprecation for yarn.app.mapreduce.am.scheduler.heartbeat.interval-ms
DEBUG - Handling deprecation for mapreduce.ifile.readahead
DEBUG - Handling deprecation for yarn.resourcemanager.scheduler.monitor.enable
DEBUG - Handling deprecation for yarn.resourcemanager.zk-retry-interval-ms
DEBUG - Handling deprecation for ha.zookeeper.session-timeout.ms
DEBUG - Handling deprecation for mapreduce.tasktracker.taskmemorymanager.monitoringinterval
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.parallelcopies
DEBUG - Handling deprecation for dfs.client.mmap.retry.timeout.ms
DEBUG - Handling deprecation for mapreduce.map.skip.maxrecords
DEBUG - Handling deprecation for mapreduce.job.output.value.class
DEBUG - Handling deprecation for dfs.namenode.avoid.read.stale.datanode
DEBUG - Handling deprecation for dfs.https.enable
DEBUG - Handling deprecation for yarn.timeline-service.webapp.https.address
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.read.timeout
DEBUG - Handling deprecation for dfs.namenode.list.encryption.zones.num.responses
DEBUG - Handling deprecation for yarn.nodemanager.remote-app-log-dir-suffix
DEBUG - Handling deprecation for mapreduce.output.fileoutputformat.compress.codec
DEBUG - Handling deprecation for mapreduce.jobtracker.instrumentation
DEBUG - Handling deprecation for dfs.blockreport.intervalMsec
DEBUG - Handling deprecation for ipc.client.connect.retry.interval
DEBUG - Handling deprecation for mapreduce.reduce.speculative
DEBUG - Handling deprecation for mapreduce.jobhistory.keytab
DEBUG - Handling deprecation for mapreduce.jobhistory.datestring.cache.size
DEBUG - Handling deprecation for dfs.datanode.balance.bandwidthPerSec
DEBUG - Handling deprecation for file.blocksize
DEBUG - Handling deprecation for yarn.resourcemanager.admin.address
DEBUG - Handling deprecation for mapreduce.map.cpu.vcores
DEBUG - Handling deprecation for yarn.nodemanager.container-monitor.procfs-tree.smaps-based-rss.enabled
DEBUG - Handling deprecation for yarn.resourcemanager.configuration.provider-class
DEBUG - Handling deprecation for yarn.resourcemanager.resource-tracker.address
DEBUG - Handling deprecation for mapreduce.tasktracker.local.dir.minspacekill
DEBUG - Handling deprecation for mapreduce.jobtracker.staging.root.dir
DEBUG - Handling deprecation for mapreduce.jobtracker.retiredjobs.cache.size
DEBUG - Handling deprecation for hadoop.registry.rm.enabled
DEBUG - Handling deprecation for ipc.client.connect.max.retries.on.timeouts
DEBUG - Handling deprecation for ha.zookeeper.acl
DEBUG - Handling deprecation for hadoop.security.crypto.codec.classes.aes.ctr.nopadding
DEBUG - Handling deprecation for yarn.nodemanager.local-dirs
DEBUG - Handling deprecation for mapreduce.app-submission.cross-platform
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.connect.timeout
DEBUG - Handling deprecation for dfs.block.access.key.update.interval
DEBUG - Handling deprecation for rpc.metrics.quantile.enable
DEBUG - Handling deprecation for dfs.block.access.token.lifetime
DEBUG - Handling deprecation for mapreduce.job.end-notification.retry.attempts
DEBUG - Handling deprecation for dfs.namenode.fs-limits.max-xattrs-per-inode
DEBUG - Handling deprecation for mapreduce.jobtracker.system.dir
DEBUG - Handling deprecation for dfs.client.file-block-storage-locations.timeout.millis
DEBUG - Handling deprecation for yarn.nodemanager.admin-env
DEBUG - Handling deprecation for mapreduce.jobtracker.jobhistory.block.size
DEBUG - Handling deprecation for yarn.log-aggregation.retain-seconds
DEBUG - Handling deprecation for mapreduce.tasktracker.indexcache.mb
DEBUG - Handling deprecation for yarn.timeline-service.handler-thread-count
DEBUG - Handling deprecation for dfs.namenode.checkpoint.check.period
DEBUG - Handling deprecation for yarn.resourcemanager.hostname
DEBUG - Handling deprecation for dfs.client.block.write.replace-datanode-on-failure.enable
DEBUG - Handling deprecation for net.topology.impl
DEBUG - Handling deprecation for dfs.datanode.directoryscan.interval
DEBUG - Handling deprecation for fs.s3a.multipart.purge.age
DEBUG - Handling deprecation for hadoop.security.java.secure.random.algorithm
DEBUG - Handling deprecation for yarn.nodemanager.container-monitor.interval-ms
DEBUG - Handling deprecation for dfs.default.chunk.view.size
DEBUG - Handling deprecation for fs.s3a.multipart.threshold
DEBUG - Handling deprecation for mapreduce.job.speculative.slownodethreshold
DEBUG - Handling deprecation for mapreduce.job.reduce.slowstart.completedmaps
DEBUG - Handling deprecation for mapred.reducer.new-api
DEBUG - Handling deprecation for hadoop.security.instrumentation.requires.admin
DEBUG - Handling deprecation for io.compression.codec.bzip2.library
DEBUG - Handling deprecation for hadoop.http.authentication.signature.secret.file
DEBUG - Handling deprecation for hadoop.registry.secure
DEBUG - Handling deprecation for dfs.namenode.safemode.min.datanodes
DEBUG - Handling deprecation for yarn.nodemanager.localizer.cache.target-size-mb
DEBUG - Handling deprecation for mapreduce.input.fileinputformat.inputdir
DEBUG - Handling deprecation for mapreduce.reduce.maxattempts
DEBUG - Handling deprecation for dfs.datanode.https.address
DEBUG - Handling deprecation for s3native.replication
DEBUG - Handling deprecation for dfs.namenode.inotify.max.events.per.rpc
DEBUG - Handling deprecation for dfs.namenode.path.based.cache.retry.interval.ms
DEBUG - Handling deprecation for mapreduce.reduce.skip.proc.count.autoincr
DEBUG - Handling deprecation for dfs.datanode.cache.revocation.polling.ms
DEBUG - Handling deprecation for mapreduce.jobhistory.cleaner.interval-ms
DEBUG - Handling deprecation for file.replication
DEBUG - Handling deprecation for hadoop.hdfs.configuration.version
DEBUG - Handling deprecation for ipc.client.idlethreshold
DEBUG - Handling deprecation for hadoop.tmp.dir
DEBUG - Handling deprecation for yarn.resourcemanager.store.class
DEBUG - Handling deprecation for mapreduce.jobhistory.address
DEBUG - Handling deprecation for mapreduce.jobtracker.restart.recover
DEBUG - Handling deprecation for mapreduce.cluster.local.dir
DEBUG - Handling deprecation for yarn.client.nodemanager-client-async.thread-pool-max-size
DEBUG - Handling deprecation for dfs.namenode.decommission.nodes.per.interval
DEBUG - Handling deprecation for mapreduce.job.inputformat.class
DEBUG - Handling deprecation for yarn.nodemanager.resource.cpu-vcores
DEBUG - Handling deprecation for dfs.namenode.reject-unresolved-dn-topology-mapping
DEBUG - Handling deprecation for dfs.namenode.delegation.key.update-interval
DEBUG - Handling deprecation for fs.s3.buffer.dir
DEBUG - Handling deprecation for dfs.client.read.shortcircuit.streams.cache.expiry.ms
DEBUG - Handling deprecation for dfs.namenode.support.allow.format
DEBUG - Handling deprecation for yarn.nodemanager.remote-app-log-dir
DEBUG - Handling deprecation for mapreduce.map.memory.mb
DEBUG - Handling deprecation for dfs.namenode.edit.log.autoroll.multiplier.threshold
DEBUG - Handling deprecation for hadoop.work.around.non.threadsafe.getpwuid
DEBUG - Handling deprecation for mapreduce.task.profile.reduce.params
DEBUG - Handling deprecation for yarn.timeline-service.client.max-retries
DEBUG - Handling deprecation for dfs.ha.automatic-failover.enabled
DEBUG - Handling deprecation for dfs.namenode.edits.noeditlogchannelflush
DEBUG - Handling deprecation for dfs.namenode.stale.datanode.interval
DEBUG - Handling deprecation for mapreduce.shuffle.transfer.buffer.size
DEBUG - Handling deprecation for mapreduce.jobtracker.persist.jobstatus.active
DEBUG - Handling deprecation for dfs.namenode.logging.level
DEBUG - Handling deprecation for yarn.resourcemanager.am-rm-tokens.master-key-rolling-interval-secs
DEBUG - Handling deprecation for yarn.nodemanager.log-dirs
DEBUG - Handling deprecation for ha.health-monitor.sleep-after-disconnect.ms
DEBUG - Handling deprecation for yarn.resourcemanager.fs.state-store.uri
DEBUG - Handling deprecation for dfs.namenode.checkpoint.edits.dir
DEBUG - Handling deprecation for yarn.resourcemanager.keytab
DEBUG - Handling deprecation for hadoop.rpc.socket.factory.class.default
DEBUG - Handling deprecation for yarn.resourcemanager.fail-fast
DEBUG - Handling deprecation for dfs.datanode.http.address
DEBUG - Handling deprecation for mapreduce.task.profile
DEBUG - Handling deprecation for mapreduce.jobhistory.move.interval-ms
DEBUG - Handling deprecation for dfs.namenode.edits.dir
DEBUG - Handling deprecation for dfs.storage.policy.enabled
DEBUG - Handling deprecation for hadoop.security.kms.client.encrypted.key.cache.size
DEBUG - Handling deprecation for hadoop.fuse.timer.period
DEBUG - Handling deprecation for mapreduce.jobhistory.http.policy
DEBUG - Handling deprecation for mapreduce.jobhistory.intermediate-done-dir
DEBUG - Handling deprecation for mapreduce.map.skip.proc.count.autoincr
DEBUG - Handling deprecation for fs.AbstractFileSystem.viewfs.impl
DEBUG - Handling deprecation for mapreduce.job.speculative.slowtaskthreshold
DEBUG - Handling deprecation for yarn.resourcemanager.webapp.delegation-token-auth-filter.enabled
DEBUG - Handling deprecation for s3native.stream-buffer-size
DEBUG - Handling deprecation for yarn.nodemanager.delete.debug-delay-sec
DEBUG - Handling deprecation for dfs.secondary.namenode.kerberos.internal.spnego.principal
DEBUG - Handling deprecation for dfs.datanode.available-space-volume-choosing-policy.balanced-space-threshold
DEBUG - Handling deprecation for fs.s3n.multipart.uploads.block.size
DEBUG - Handling deprecation for dfs.namenode.safemode.threshold-pct
DEBUG - Handling deprecation for mapreduce.ifile.readahead.bytes
DEBUG - Handling deprecation for yarn.scheduler.maximum-allocation-mb
DEBUG - Handling deprecation for ipc.client.fallback-to-simple-auth-allowed
DEBUG - Handling deprecation for fs.har.impl.disable.cache
DEBUG - Handling deprecation for yarn.timeline-service.leveldb-timeline-store.read-cache-size
DEBUG - Handling deprecation for yarn.timeline-service.hostname
DEBUG - Handling deprecation for s3native.bytes-per-checksum
DEBUG - Handling deprecation for mapreduce.job.committer.setup.cleanup.needed
DEBUG - Handling deprecation for yarn.timeline-service.leveldb-timeline-store.ttl-interval-ms
DEBUG - Handling deprecation for fs.s3a.paging.maximum
DEBUG - Handling deprecation for yarn.client.nodemanager-connect.retry-interval-ms
DEBUG - Handling deprecation for yarn.nodemanager.log-aggregation.compression-type
DEBUG - Handling deprecation for yarn.app.mapreduce.am.job.committer.commit-window
DEBUG - Handling deprecation for hadoop.http.authentication.type
DEBUG - Handling deprecation for dfs.client.failover.sleep.base.millis
DEBUG - Handling deprecation for mapreduce.job.submithostaddress
DEBUG - Handling deprecation for yarn.nodemanager.vmem-check-enabled
DEBUG - Handling deprecation for hadoop.jetty.logs.serve.aliases
DEBUG - Handling deprecation for ha.failover-controller.graceful-fence.rpc-timeout.ms
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.input.buffer.percent
DEBUG - Handling deprecation for dfs.datanode.max.transfer.threads
DEBUG - Handling deprecation for mapreduce.reduce.merge.inmem.threshold
DEBUG - Handling deprecation for mapreduce.task.io.sort.mb
DEBUG - Handling deprecation for dfs.namenode.acls.enabled
DEBUG - Handling deprecation for yarn.client.application-client-protocol.poll-interval-ms
DEBUG - Handling deprecation for hadoop.security.kms.client.authentication.retry-count
DEBUG - Handling deprecation for dfs.namenode.handler.count
DEBUG - Handling deprecation for yarn.resourcemanager.connect.max-wait.ms
DEBUG - Handling deprecation for dfs.namenode.retrycache.heap.percent
DEBUG - Handling deprecation for yarn.timeline-service.enabled
DEBUG - Handling deprecation for yarn.nodemanager.linux-container-executor.nonsecure-mode.limit-users
DEBUG - Handling deprecation for hadoop.ssl.client.conf
DEBUG - Handling deprecation for yarn.resourcemanager.container.liveness-monitor.interval-ms
DEBUG - Handling deprecation for yarn.nodemanager.vmem-pmem-ratio
DEBUG - Handling deprecation for mapreduce.client.completion.pollinterval
DEBUG - Handling deprecation for yarn.app.mapreduce.client.max-retries
DEBUG - Handling deprecation for hadoop.ssl.enabled
DEBUG - Handling deprecation for fs.client.resolve.remote.symlinks
DEBUG - Handling deprecation for fs.AbstractFileSystem.hdfs.impl
DEBUG - Handling deprecation for mapreduce.tasktracker.reduce.tasks.maximum
DEBUG - Handling deprecation for yarn.nodemanager.hostname
DEBUG - Handling deprecation for mapreduce.reduce.input.buffer.percent
DEBUG - Handling deprecation for fs.s3a.multipart.purge
DEBUG - Handling deprecation for yarn.app.mapreduce.am.command-opts
DEBUG - Handling deprecation for dfs.namenode.invalidate.work.pct.per.iteration
DEBUG - Handling deprecation for dfs.bytes-per-checksum
DEBUG - Handling deprecation for yarn.resourcemanager.webapp.https.address
DEBUG - Handling deprecation for dfs.replication
DEBUG - Handling deprecation for dfs.datanode.block.id.layout.upgrade.threads
DEBUG - Handling deprecation for mapreduce.shuffle.ssl.file.buffer.size
DEBUG - Handling deprecation for dfs.namenode.list.cache.directives.num.responses
DEBUG - Handling deprecation for dfs.permissions.enabled
DEBUG - Handling deprecation for mapreduce.jobtracker.maxtasks.perjob
DEBUG - Handling deprecation for dfs.datanode.use.datanode.hostname
DEBUG - Handling deprecation for mapreduce.task.userlog.limit.kb
DEBUG - Handling deprecation for dfs.namenode.fs-limits.max-directory-items
DEBUG - Handling deprecation for hadoop.security.kms.client.encrypted.key.cache.low-watermark
DEBUG - Handling deprecation for fs.s3a.buffer.dir
DEBUG - Handling deprecation for s3.client-write-packet-size
DEBUG - Handling deprecation for hadoop.user.group.static.mapping.overrides
DEBUG - Handling deprecation for mapreduce.shuffle.max.threads
DEBUG - Handling deprecation for hadoop.security.kms.client.encrypted.key.cache.expiry
DEBUG - Handling deprecation for dfs.client.failover.sleep.max.millis
DEBUG - Handling deprecation for mapreduce.job.maps
DEBUG - Handling deprecation for dfs.namenode.fs-limits.max-component-length
DEBUG - Handling deprecation for yarn.fail-fast
DEBUG - Handling deprecation for hadoop.ssl.enabled.protocols
DEBUG - Handling deprecation for s3.blocksize
DEBUG - Handling deprecation for mapreduce.map.output.compress
DEBUG - Handling deprecation for dfs.namenode.edits.journal-plugin.qjournal
DEBUG - Handling deprecation for dfs.namenode.datanode.registration.ip-hostname-check
DEBUG - Handling deprecation for yarn.nodemanager.pmem-check-enabled
DEBUG - Handling deprecation for dfs.client.short.circuit.replica.stale.threshold.ms
DEBUG - Handling deprecation for dfs.client.https.need-auth
DEBUG - Handling deprecation for yarn.scheduler.minimum-allocation-mb
DEBUG - Handling deprecation for mapreduce.jobhistory.max-age-ms
DEBUG - Handling deprecation for yarn.timeline-service.http-authentication.type
DEBUG - Handling deprecation for ftp.replication
DEBUG - Handling deprecation for dfs.namenode.secondary.https-address
DEBUG - Handling deprecation for dfs.blockreport.split.threshold
DEBUG - Handling deprecation for mapreduce.input.fileinputformat.split.minsize
DEBUG - Handling deprecation for fs.s3n.block.size
DEBUG - Handling deprecation for mapreduce.job.token.tracking.ids.enabled
DEBUG - Handling deprecation for yarn.ipc.rpc.class
DEBUG - Handling deprecation for dfs.namenode.num.extra.edits.retained
DEBUG - Handling deprecation for yarn.nodemanager.localizer.cache.cleanup.interval-ms
DEBUG - Handling deprecation for hadoop.http.staticuser.user
DEBUG - Handling deprecation for mapreduce.jobhistory.move.thread-count
DEBUG - Handling deprecation for fs.s3a.multipart.size
DEBUG - Handling deprecation for mapreduce.job.jvm.numtasks
DEBUG - Handling deprecation for mapreduce.task.profile.maps
DEBUG - Handling deprecation for dfs.datanode.max.locked.memory
DEBUG - Handling deprecation for dfs.cachereport.intervalMsec
DEBUG - Handling deprecation for mapreduce.shuffle.port
DEBUG - Handling deprecation for yarn.resourcemanager.nodemanager.minimum.version
DEBUG - Handling deprecation for mapreduce.shuffle.connection-keep-alive.timeout
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.merge.percent
DEBUG - Handling deprecation for mapreduce.jobtracker.http.address
DEBUG - Handling deprecation for mapreduce.task.skip.start.attempts
DEBUG - Handling deprecation for yarn.resourcemanager.connect.retry-interval.ms
DEBUG - Handling deprecation for yarn.scheduler.minimum-allocation-vcores
DEBUG - Handling deprecation for mapreduce.task.io.sort.factor
DEBUG - Handling deprecation for dfs.namenode.checkpoint.dir
DEBUG - Handling deprecation for nfs.exports.allowed.hosts
DEBUG - Handling deprecation for tfile.fs.input.buffer.size
DEBUG - Handling deprecation for fs.s3.block.size
DEBUG - Handling deprecation for tfile.io.chunk.size
DEBUG - Handling deprecation for fs.s3n.multipart.copy.block.size
DEBUG - Handling deprecation for io.serializations
DEBUG - Handling deprecation for yarn.resourcemanager.max-completed-applications
DEBUG - Handling deprecation for mapreduce.jobhistory.principal
DEBUG - Handling deprecation for mapreduce.output.fileoutputformat.outputdir
DEBUG - Handling deprecation for yarn.resourcemanager.ha.automatic-failover.zk-base-path
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.fetch.retry.interval-ms
DEBUG - Handling deprecation for mapreduce.job.end-notification.retry.interval
DEBUG - Handling deprecation for dfs.namenode.backup.address
DEBUG - Handling deprecation for fs.s3n.multipart.uploads.enabled
DEBUG - Handling deprecation for io.seqfile.sorter.recordlimit
DEBUG - Handling deprecation for dfs.block.access.token.enable
DEBUG - Handling deprecation for s3native.client-write-packet-size
DEBUG - Handling deprecation for dfs.namenode.fs-limits.max-xattr-size
DEBUG - Handling deprecation for ftp.bytes-per-checksum
DEBUG - Handling deprecation for hadoop.security.group.mapping
DEBUG - Handling deprecation for dfs.client.domain.socket.data.traffic
DEBUG - Handling deprecation for dfs.client.read.shortcircuit.streams.cache.size
DEBUG - Handling deprecation for fs.s3a.connection.timeout
DEBUG - Handling deprecation for mapreduce.job.end-notification.max.retry.interval
DEBUG - Handling deprecation for yarn.acl.enable
DEBUG - Handling deprecation for yarn.nm.liveness-monitor.expiry-interval-ms
DEBUG - Handling deprecation for mapreduce.input.fileinputformat.list-status.num-threads
DEBUG - Handling deprecation for dfs.client.mmap.cache.size
DEBUG - Handling deprecation for mapreduce.tasktracker.map.tasks.maximum
DEBUG - Handling deprecation for yarn.timeline-service.ttl-enable
DEBUG - Handling deprecation for yarn.nodemanager.linux-container-executor.resources-handler.class
DEBUG - Handling deprecation for dfs.namenode.max.objects
DEBUG - Handling deprecation for yarn.resourcemanager.state-store.max-completed-applications
DEBUG - Handling deprecation for dfs.namenode.delegation.token.max-lifetime
DEBUG - Handling deprecation for mapreduce.job.classloader
DEBUG - Handling deprecation for yarn.timeline-service.leveldb-timeline-store.start-time-write-cache-size
DEBUG - Handling deprecation for mapreduce.job.hdfs-servers
DEBUG - Handling deprecation for dfs.datanode.hdfs-blocks-metadata.enabled
DEBUG - Handling deprecation for mapreduce.tasktracker.dns.nameserver
DEBUG - Handling deprecation for dfs.datanode.readahead.bytes
DEBUG - Handling deprecation for dfs.datanode.bp-ready.timeout
DEBUG - Handling deprecation for mapreduce.job.ubertask.maxreduces
DEBUG - Handling deprecation for dfs.image.compress
DEBUG - Handling deprecation for mapreduce.shuffle.ssl.enabled
DEBUG - Handling deprecation for yarn.log-aggregation-enable
DEBUG - Handling deprecation for mapreduce.tasktracker.report.address
DEBUG - Handling deprecation for mapreduce.tasktracker.http.threads
DEBUG - Handling deprecation for dfs.stream-buffer-size
DEBUG - Handling deprecation for tfile.fs.output.buffer.size
DEBUG - Handling deprecation for fs.permissions.umask-mode
DEBUG - Handling deprecation for dfs.client.datanode-restart.timeout
DEBUG - Handling deprecation for dfs.namenode.resource.du.reserved
DEBUG - Handling deprecation for yarn.resourcemanager.am.max-attempts
DEBUG - Handling deprecation for yarn.nodemanager.resource.percentage-physical-cpu-limit
DEBUG - Handling deprecation for ha.failover-controller.graceful-fence.connection.retries
DEBUG - Handling deprecation for dfs.datanode.drop.cache.behind.writes
DEBUG - Handling deprecation for mapreduce.map.output.value.class
DEBUG - Handling deprecation for hadoop.common.configuration.version
DEBUG - Handling deprecation for mapreduce.job.ubertask.enable
DEBUG - Handling deprecation for yarn.app.mapreduce.am.resource.cpu-vcores
DEBUG - Handling deprecation for dfs.namenode.replication.work.multiplier.per.iteration
DEBUG - Handling deprecation for mapreduce.job.acl-modify-job
DEBUG - Handling deprecation for io.seqfile.local.dir
DEBUG - Handling deprecation for yarn.resourcemanager.system-metrics-publisher.enabled
DEBUG - Handling deprecation for fs.s3.sleepTimeSeconds
DEBUG - Handling deprecation for mapreduce.client.output.filter
INFO - Submitting tokens for job: job_local1553403857_0001
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.fs.FileContext.getAbstractFileSystem(FileContext.java:)
DEBUG - Handling deprecation for all properties in config...
DEBUG - Handling deprecation for dfs.datanode.data.dir
DEBUG - Handling deprecation for dfs.namenode.checkpoint.txns
DEBUG - Handling deprecation for s3.replication
DEBUG - Handling deprecation for mapreduce.output.fileoutputformat.compress.type
DEBUG - Handling deprecation for mapreduce.jobtracker.jobhistory.lru.cache.size
DEBUG - Handling deprecation for dfs.datanode.failed.volumes.tolerated
DEBUG - Handling deprecation for hadoop.http.filter.initializers
DEBUG - Handling deprecation for mapreduce.cluster.temp.dir
DEBUG - Handling deprecation for yarn.nodemanager.keytab
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.memory.limit.percent
DEBUG - Handling deprecation for dfs.namenode.checkpoint.max-retries
DEBUG - Handling deprecation for nfs.mountd.port
DEBUG - Handling deprecation for hadoop.registry.zk.retry.times
DEBUG - Handling deprecation for yarn.resourcemanager.zk-acl
DEBUG - Handling deprecation for mapreduce.reduce.skip.maxgroups
DEBUG - Handling deprecation for ipc.ping.interval
DEBUG - Handling deprecation for dfs.https.server.keystore.resource
DEBUG - Handling deprecation for yarn.app.mapreduce.task.container.log.backups
DEBUG - Handling deprecation for hadoop.http.authentication.kerberos.keytab
DEBUG - Handling deprecation for yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage
DEBUG - Handling deprecation for dfs.client.block.write.replace-datanode-on-failure.best-effort
DEBUG - Handling deprecation for yarn.nodemanager.localizer.client.thread-count
DEBUG - Handling deprecation for mapreduce.jobhistory.done-dir
DEBUG - Handling deprecation for mapreduce.framework.name
DEBUG - Handling deprecation for ha.failover-controller.new-active.rpc-timeout.ms
DEBUG - Handling deprecation for ha.health-monitor.check-interval.ms
DEBUG - Handling deprecation for io.file.buffer.size
DEBUG - Handling deprecation for mapreduce.shuffle.max.connections
DEBUG - Handling deprecation for dfs.namenode.resource.check.interval
DEBUG - Handling deprecation for dfs.namenode.path.based.cache.block.map.allocation.percent
DEBUG - Handling deprecation for mapreduce.task.tmp.dir
DEBUG - Handling deprecation for dfs.namenode.checkpoint.period
DEBUG - Handling deprecation for dfs.client.mmap.cache.timeout.ms
DEBUG - Handling deprecation for ipc.client.kill.max
DEBUG - Handling deprecation for yarn.resourcemanager.scheduler.class
DEBUG - Handling deprecation for mapreduce.jobtracker.taskcache.levels
DEBUG - Handling deprecation for s3.stream-buffer-size
DEBUG - Handling deprecation for dfs.namenode.secondary.http-address
DEBUG - Handling deprecation for yarn.client.nodemanager-connect.max-wait-ms
DEBUG - Handling deprecation for dfs.namenode.decommission.interval
DEBUG - Handling deprecation for dfs.namenode.http-address
DEBUG - Handling deprecation for mapreduce.task.files.preserve.failedtasks
DEBUG - Handling deprecation for dfs.encrypt.data.transfer
DEBUG - Handling deprecation for yarn.resourcemanager.ha.enabled
DEBUG - Handling deprecation for dfs.datanode.address
DEBUG - Handling deprecation for dfs.namenode.avoid.write.stale.datanode
DEBUG - Handling deprecation for hadoop.http.authentication.token.validity
DEBUG - Handling deprecation for hadoop.security.group.mapping.ldap.search.filter.group
DEBUG - Handling deprecation for dfs.client.failover.max.attempts
DEBUG - Handling deprecation for yarn.resourcemanager.scheduler.monitor.policies
DEBUG - Handling deprecation for hadoop.registry.zk.connection.timeout.ms
DEBUG - Handling deprecation for hadoop.security.crypto.cipher.suite
DEBUG - Handling deprecation for yarn.timeline-service.http-authentication.simple.anonymous.allowed
DEBUG - Handling deprecation for mapreduce.task.profile.params
DEBUG - Handling deprecation for yarn.resourcemanager.fs.state-store.retry-policy-spec
DEBUG - Handling deprecation for yarn.admin.acl
DEBUG - Handling deprecation for yarn.nodemanager.local-cache.max-files-per-directory
DEBUG - Handling deprecation for yarn.client.failover-retries-on-socket-timeouts
DEBUG - Handling deprecation for dfs.namenode.retrycache.expirytime.millis
DEBUG - Handling deprecation for yarn.resourcemanager.nodemanagers.heartbeat-interval-ms
DEBUG - Handling deprecation for dfs.client.failover.connection.retries.on.timeouts
DEBUG - Handling deprecation for yarn.client.failover-proxy-provider
DEBUG - Handling deprecation for mapreduce.map.sort.spill.percent
DEBUG - Handling deprecation for file.stream-buffer-size
DEBUG - Handling deprecation for dfs.webhdfs.enabled
DEBUG - Handling deprecation for ipc.client.connection.maxidletime
DEBUG - Handling deprecation for mapreduce.task.combine.progress.records
DEBUG - Handling deprecation for mapreduce.job.output.key.class
DEBUG - Handling deprecation for mapreduce.jobtracker.persist.jobstatus.hours
DEBUG - Handling deprecation for dfs.image.transfer.chunksize
DEBUG - Handling deprecation for yarn.nodemanager.address
DEBUG - Handling deprecation for dfs.datanode.ipc.address
DEBUG - Handling deprecation for yarn.resourcemanager.ha.automatic-failover.embedded
DEBUG - Handling deprecation for mapreduce.jobhistory.recovery.store.fs.uri
DEBUG - Handling deprecation for yarn.resourcemanager.zk-state-store.parent-path
DEBUG - Handling deprecation for yarn.app.mapreduce.am.job.task.listener.thread-count
DEBUG - Handling deprecation for nfs.dump.dir
DEBUG - Handling deprecation for dfs.namenode.list.cache.pools.num.responses
DEBUG - Handling deprecation for dfs.client.read.shortcircuit
DEBUG - Handling deprecation for dfs.namenode.safemode.extension
DEBUG - Handling deprecation for ha.zookeeper.parent-znode
DEBUG - Handling deprecation for yarn.nodemanager.container-executor.class
DEBUG - Handling deprecation for io.skip.checksum.errors
DEBUG - Handling deprecation for dfs.namenode.path.based.cache.refresh.interval.ms
DEBUG - Handling deprecation for dfs.encrypt.data.transfer.cipher.key.bitlength
DEBUG - Handling deprecation for mapreduce.job.user.name
DEBUG - Handling deprecation for yarn.resourcemanager.scheduler.client.thread-count
DEBUG - Handling deprecation for yarn.nodemanager.recovery.dir
DEBUG - Handling deprecation for mapreduce.job.emit-timeline-data
DEBUG - Handling deprecation for hadoop.http.authentication.kerberos.principal
DEBUG - Handling deprecation for mapreduce.reduce.log.level
DEBUG - Handling deprecation for yarn.nodemanager.linux-container-executor.nonsecure-mode.user-pattern
DEBUG - Handling deprecation for fs.s3.maxRetries
DEBUG - Handling deprecation for yarn.nodemanager.resourcemanager.minimum.version
DEBUG - Handling deprecation for ipc.client.rpc-timeout.ms
DEBUG - Handling deprecation for hadoop.kerberos.kinit.command
DEBUG - Handling deprecation for yarn.log-aggregation.retain-check-interval-seconds
DEBUG - Handling deprecation for yarn.nodemanager.process-kill-wait.ms
DEBUG - Handling deprecation for yarn.nodemanager.linux-container-executor.cgroups.mount
DEBUG - Handling deprecation for mapreduce.map.output.key.class
DEBUG - Handling deprecation for mapreduce.job.working.dir
DEBUG - Handling deprecation for dfs.namenode.name.dir.restore
DEBUG - Handling deprecation for mapreduce.jobtracker.handler.count
DEBUG - Handling deprecation for mapreduce.jobhistory.admin.address
DEBUG - Handling deprecation for yarn.app.mapreduce.client-am.ipc.max-retries
DEBUG - Handling deprecation for dfs.client.use.datanode.hostname
DEBUG - Handling deprecation for hadoop.util.hash.type
DEBUG - Handling deprecation for dfs.datanode.available-space-volume-choosing-policy.balanced-space-preference-fraction
DEBUG - Handling deprecation for dfs.datanode.dns.interface
DEBUG - Handling deprecation for io.seqfile.lazydecompress
DEBUG - Handling deprecation for dfs.namenode.lazypersist.file.scrub.interval.sec
DEBUG - Handling deprecation for yarn.nodemanager.disk-health-checker.min-healthy-disks
DEBUG - Handling deprecation for yarn.client.max-cached-nodemanagers-proxies
DEBUG - Handling deprecation for mapreduce.job.maxtaskfailures.per.tracker
DEBUG - Handling deprecation for mapreduce.tasktracker.healthchecker.script.timeout
DEBUG - Handling deprecation for hadoop.security.group.mapping.ldap.search.attr.group.name
DEBUG - Handling deprecation for fs.df.interval
DEBUG - Handling deprecation for hadoop.security.crypto.buffer.size
DEBUG - Handling deprecation for dfs.namenode.kerberos.internal.spnego.principal
DEBUG - Handling deprecation for dfs.client.cached.conn.retry
DEBUG - Handling deprecation for mapreduce.job.reduce.class
DEBUG - Handling deprecation for mapreduce.job.map.class
DEBUG - Handling deprecation for mapreduce.job.reduce.shuffle.consumer.plugin.class
DEBUG - Handling deprecation for mapreduce.jobtracker.address
DEBUG - Handling deprecation for mapreduce.tasktracker.tasks.sleeptimebeforesigkill
DEBUG - Handling deprecation for dfs.journalnode.rpc-address
DEBUG - Handling deprecation for dfs.namenode.fs-limits.max-blocks-per-file
DEBUG - Handling deprecation for mapreduce.job.acl-view-job
DEBUG - Handling deprecation for yarn.app.mapreduce.am.job.committer.cancel-timeout
DEBUG - Handling deprecation for dfs.client.block.write.replace-datanode-on-failure.policy
DEBUG - Handling deprecation for mapreduce.shuffle.connection-keep-alive.enable
DEBUG - Handling deprecation for dfs.namenode.replication.interval
DEBUG - Handling deprecation for mapreduce.jobhistory.minicluster.fixed.ports
DEBUG - Handling deprecation for dfs.namenode.num.checkpoints.retained
DEBUG - Handling deprecation for yarn.resourcemanager.scheduler.address
DEBUG - Handling deprecation for mapreduce.tasktracker.http.address
DEBUG - Handling deprecation for mapreduce.jobhistory.admin.acl
DEBUG - Handling deprecation for dfs.datanode.directoryscan.threads
DEBUG - Handling deprecation for mapreduce.reduce.memory.mb
DEBUG - Handling deprecation for hadoop.security.group.mapping.ldap.ssl
DEBUG - Handling deprecation for dfs.http.policy
DEBUG - Handling deprecation for mapreduce.task.merge.progress.records
DEBUG - Handling deprecation for dfs.heartbeat.interval
DEBUG - Handling deprecation for yarn.resourcemanager.system-metrics-publisher.dispatcher.pool-size
DEBUG - Handling deprecation for yarn.resourcemanager.recovery.enabled
DEBUG - Handling deprecation for net.topology.script.number.args
DEBUG - Handling deprecation for mapreduce.local.clientfactory.class.name
DEBUG - Handling deprecation for dfs.client-write-packet-size
DEBUG - Handling deprecation for yarn.dispatcher.drain-events.timeout
DEBUG - Handling deprecation for hadoop.security.group.mapping.ldap.directory.search.timeout
DEBUG - Handling deprecation for io.native.lib.available
DEBUG - Handling deprecation for dfs.client.failover.connection.retries
DEBUG - Handling deprecation for yarn.nodemanager.disk-health-checker.interval-ms
DEBUG - Handling deprecation for dfs.blocksize
DEBUG - Handling deprecation for dfs.client.use.legacy.blockreader.local
DEBUG - Handling deprecation for yarn.resourcemanager.container-tokens.master-key-rolling-interval-secs
DEBUG - Handling deprecation for fs.s3a.connection.ssl.enabled
DEBUG - Handling deprecation for mapreduce.jobhistory.webapp.address
DEBUG - Handling deprecation for yarn.resourcemanager.resource-tracker.client.thread-count
DEBUG - Handling deprecation for yarn.client.failover-retries
DEBUG - Handling deprecation for hadoop.registry.jaas.context
DEBUG - Handling deprecation for dfs.blockreport.initialDelay
DEBUG - Handling deprecation for yarn.nodemanager.aux-services.mapreduce_shuffle.class
DEBUG - Handling deprecation for ha.health-monitor.rpc-timeout.ms
DEBUG - Handling deprecation for yarn.resourcemanager.zk-timeout-ms
DEBUG - Handling deprecation for mapreduce.reduce.markreset.buffer.percent
DEBUG - Handling deprecation for yarn.timeline-service.leveldb-timeline-store.start-time-read-cache-size
DEBUG - Handling deprecation for dfs.ha.tail-edits.period
DEBUG - Handling deprecation for yarn.resourcemanager.client.thread-count
DEBUG - Handling deprecation for yarn.nodemanager.health-checker.script.timeout-ms
DEBUG - Handling deprecation for file.bytes-per-checksum
DEBUG - Handling deprecation for dfs.replication.max
DEBUG - Handling deprecation for dfs.namenode.max.extra.edits.segments.retained
DEBUG - Handling deprecation for io.map.index.skip
DEBUG - Handling deprecation for yarn.timeline-service.client.retry-interval-ms
DEBUG - Handling deprecation for mapreduce.task.timeout
DEBUG - Handling deprecation for dfs.datanode.du.reserved
DEBUG - Handling deprecation for mapreduce.reduce.cpu.vcores
DEBUG - Handling deprecation for dfs.support.append
DEBUG - Handling deprecation for dfs.client.file-block-storage-locations.num-threads
DEBUG - Handling deprecation for ftp.blocksize
DEBUG - Handling deprecation for yarn.nodemanager.container-manager.thread-count
DEBUG - Handling deprecation for ipc.server.listen.queue.size
DEBUG - Handling deprecation for yarn.resourcemanager.ha.automatic-failover.enabled
DEBUG - Handling deprecation for hadoop.ssl.hostname.verifier
DEBUG - Handling deprecation for nfs.server.port
DEBUG - Handling deprecation for mapreduce.tasktracker.dns.interface
DEBUG - Handling deprecation for hadoop.security.group.mapping.ldap.search.attr.member
DEBUG - Handling deprecation for mapreduce.job.userlog.retain.hours
DEBUG - Handling deprecation for mapreduce.tasktracker.outofband.heartbeat
DEBUG - Handling deprecation for fs.s3a.impl
DEBUG - Handling deprecation for hadoop.registry.system.acls
DEBUG - Handling deprecation for yarn.nodemanager.resource.memory-mb
DEBUG - Handling deprecation for yarn.nodemanager.log-aggregation.roll-monitoring-interval-seconds
DEBUG - Handling deprecation for dfs.webhdfs.user.provider.user.pattern
DEBUG - Handling deprecation for dfs.namenode.delegation.token.renew-interval
DEBUG - Handling deprecation for hadoop.ssl.keystores.factory.class
DEBUG - Handling deprecation for hadoop.registry.zk.retry.ceiling.ms
DEBUG - Handling deprecation for yarn.http.policy
DEBUG - Handling deprecation for dfs.datanode.sync.behind.writes
DEBUG - Handling deprecation for nfs.wtmax
DEBUG - Handling deprecation for fs.AbstractFileSystem.har.impl
DEBUG - Handling deprecation for dfs.client.read.shortcircuit.skip.checksum
DEBUG - Handling deprecation for hadoop.security.random.device.file.path
DEBUG - Handling deprecation for mapreduce.map.maxattempts
DEBUG - Handling deprecation for yarn.timeline-service.webapp.address
DEBUG - Handling deprecation for dfs.datanode.handler.count
DEBUG - Handling deprecation for hadoop.ssl.require.client.cert
DEBUG - Handling deprecation for ftp.client-write-packet-size
DEBUG - Handling deprecation for dfs.client.write.exclude.nodes.cache.expiry.interval.millis
DEBUG - Handling deprecation for mapreduce.jobhistory.cleaner.enable
DEBUG - Handling deprecation for fs.du.interval
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.retry-delay.max.ms
DEBUG - Handling deprecation for mapreduce.task.profile.reduces
DEBUG - Handling deprecation for ha.health-monitor.connect-retry-interval.ms
DEBUG - Handling deprecation for hadoop.fuse.connection.timeout
DEBUG - Handling deprecation for dfs.permissions.superusergroup
DEBUG - Handling deprecation for mapreduce.jobtracker.jobhistory.task.numberprogresssplits
DEBUG - Handling deprecation for fs.ftp.host.port
DEBUG - Handling deprecation for mapreduce.map.speculative
DEBUG - Handling deprecation for dfs.datanode.data.dir.perm
DEBUG - Handling deprecation for mapreduce.client.submit.file.replication
DEBUG - Handling deprecation for dfs.namenode.startup.delay.block.deletion.sec
DEBUG - Handling deprecation for s3native.blocksize
DEBUG - Handling deprecation for mapreduce.job.ubertask.maxmaps
DEBUG - Handling deprecation for dfs.namenode.replication.min
DEBUG - Handling deprecation for mapreduce.cluster.acls.enabled
DEBUG - Handling deprecation for hadoop.security.uid.cache.secs
DEBUG - Handling deprecation for nfs.allow.insecure.ports
DEBUG - Handling deprecation for yarn.nodemanager.localizer.fetch.thread-count
DEBUG - Handling deprecation for map.sort.class
DEBUG - Handling deprecation for fs.trash.checkpoint.interval
DEBUG - Handling deprecation for mapred.queue.default.acl-administer-jobs
DEBUG - Handling deprecation for yarn.timeline-service.generic-application-history.max-applications
DEBUG - Handling deprecation for dfs.image.transfer.timeout
DEBUG - Handling deprecation for dfs.namenode.name.dir
DEBUG - Handling deprecation for ipc.client.connect.timeout
DEBUG - Handling deprecation for yarn.app.mapreduce.am.staging-dir
DEBUG - Handling deprecation for fs.AbstractFileSystem.file.impl
DEBUG - Handling deprecation for yarn.nodemanager.env-whitelist
DEBUG - Handling deprecation for hadoop.registry.zk.retry.interval.ms
DEBUG - Handling deprecation for yarn.nodemanager.linux-container-executor.cgroups.strict-resource-usage
DEBUG - Handling deprecation for yarn.timeline-service.keytab
DEBUG - Handling deprecation for dfs.image.compression.codec
DEBUG - Handling deprecation for mapreduce.job.reduces
DEBUG - Handling deprecation for mapreduce.job.complete.cancel.delegation.tokens
DEBUG - Handling deprecation for mapreduce.jobhistory.recovery.store.class
DEBUG - Handling deprecation for hadoop.security.group.mapping.ldap.search.filter.user
DEBUG - Handling deprecation for dfs.namenode.enable.retrycache
DEBUG - Handling deprecation for yarn.nodemanager.sleep-delay-before-sigkill.ms
DEBUG - Handling deprecation for mapreduce.jobhistory.joblist.cache.size
DEBUG - Handling deprecation for mapreduce.tasktracker.healthchecker.interval
DEBUG - Handling deprecation for mapreduce.jobtracker.heartbeats.in.second
DEBUG - Handling deprecation for mapreduce.jobtracker.persist.jobstatus.dir
DEBUG - Handling deprecation for dfs.namenode.backup.http-address
DEBUG - Handling deprecation for hadoop.rpc.protection
DEBUG - Handling deprecation for dfs.client.mmap.enabled
DEBUG - Handling deprecation for yarn.app.mapreduce.am.container.log.backups
DEBUG - Handling deprecation for ftp.stream-buffer-size
DEBUG - Handling deprecation for dfs.namenode.https-address
DEBUG - Handling deprecation for yarn.timeline-service.address
DEBUG - Handling deprecation for dfs.ha.log-roll.period
DEBUG - Handling deprecation for yarn.nodemanager.recovery.enabled
DEBUG - Handling deprecation for mapreduce.input.fileinputformat.numinputfiles
DEBUG - Handling deprecation for hadoop.security.groups.negative-cache.secs
DEBUG - Handling deprecation for yarn.resourcemanager.admin.client.thread-count
DEBUG - Handling deprecation for dfs.datanode.fsdatasetcache.max.threads.per.volume
DEBUG - Handling deprecation for file.client-write-packet-size
DEBUG - Handling deprecation for hadoop.http.authentication.simple.anonymous.allowed
DEBUG - Handling deprecation for yarn.timeline-service.leveldb-timeline-store.path
DEBUG - Handling deprecation for yarn.resourcemanager.proxy-user-privileges.enabled
DEBUG - Handling deprecation for dfs.datanode.drop.cache.behind.reads
DEBUG - Handling deprecation for yarn.nodemanager.log.retain-seconds
DEBUG - Handling deprecation for dfs.image.transfer.bandwidthPerSec
DEBUG - Handling deprecation for yarn.resourcemanager.work-preserving-recovery.scheduling-wait-ms
DEBUG - Handling deprecation for hadoop.registry.zk.session.timeout.ms
DEBUG - Handling deprecation for dfs.datanode.slow.io.warning.threshold.ms
DEBUG - Handling deprecation for mapreduce.tasktracker.instrumentation
DEBUG - Handling deprecation for ha.failover-controller.cli-check.rpc-timeout.ms
DEBUG - Handling deprecation for yarn.nodemanager.linux-container-executor.cgroups.hierarchy
DEBUG - Handling deprecation for dfs.namenode.write.stale.datanode.ratio
DEBUG - Handling deprecation for hadoop.security.groups.cache.warn.after.ms
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.fetch.retry.timeout-ms
DEBUG - Handling deprecation for mapreduce.jobhistory.client.thread-count
DEBUG - Handling deprecation for io.mapfile.bloom.size
DEBUG - Handling deprecation for yarn.nodemanager.docker-container-executor.exec-name
DEBUG - Handling deprecation for yarn.resourcemanager.work-preserving-recovery.enabled
DEBUG - Handling deprecation for dfs.ha.fencing.ssh.connect-timeout
DEBUG - Handling deprecation for yarn.resourcemanager.zk-num-retries
DEBUG - Handling deprecation for hadoop.registry.zk.root
DEBUG - Handling deprecation for s3.bytes-per-checksum
DEBUG - Handling deprecation for yarn.app.mapreduce.am.container.log.limit.kb
DEBUG - Handling deprecation for dfs.namenode.edit.log.autoroll.check.interval.ms
DEBUG - Handling deprecation for fs.automatic.close
DEBUG - Handling deprecation for fs.trash.interval
DEBUG - Handling deprecation for dfs.journalnode.https-address
DEBUG - Handling deprecation for yarn.timeline-service.ttl-ms
DEBUG - Handling deprecation for hadoop.security.authentication
DEBUG - Handling deprecation for fs.defaultFS
DEBUG - Handling deprecation for nfs.rtmax
DEBUG - Handling deprecation for hadoop.ssl.server.conf
DEBUG - Handling deprecation for ipc.client.connect.max.retries
DEBUG - Handling deprecation for yarn.resourcemanager.delayed.delegation-token.removal-interval-ms
DEBUG - Handling deprecation for dfs.journalnode.http-address
DEBUG - Handling deprecation for dfs.namenode.xattrs.enabled
DEBUG - Handling deprecation for dfs.datanode.shared.file.descriptor.paths
DEBUG - Handling deprecation for mapreduce.jobtracker.taskscheduler
DEBUG - Handling deprecation for mapreduce.job.speculative.speculativecap
DEBUG - Handling deprecation for yarn.timeline-service.store-class
DEBUG - Handling deprecation for yarn.am.liveness-monitor.expiry-interval-ms
DEBUG - Handling deprecation for mapreduce.output.fileoutputformat.compress
DEBUG - Handling deprecation for dfs.user.home.dir.prefix
DEBUG - Handling deprecation for net.topology.node.switch.mapping.impl
DEBUG - Handling deprecation for dfs.namenode.replication.considerLoad
DEBUG - Handling deprecation for dfs.namenode.fs-limits.min-block-size
DEBUG - Handling deprecation for fs.swift.impl
DEBUG - Handling deprecation for dfs.namenode.audit.loggers
DEBUG - Handling deprecation for mapreduce.job.max.split.locations
DEBUG - Handling deprecation for yarn.resourcemanager.address
DEBUG - Handling deprecation for mapreduce.job.counters.max
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.fetch.retry.enabled
DEBUG - Handling deprecation for dfs.client.block.write.retries
DEBUG - Handling deprecation for dfs.short.circuit.shared.memory.watcher.interrupt.check.ms
DEBUG - Handling deprecation for dfs.namenode.resource.checked.volumes.minimum
DEBUG - Handling deprecation for io.map.index.interval
DEBUG - Handling deprecation for mapred.child.java.opts
DEBUG - Handling deprecation for mapreduce.tasktracker.local.dir.minspacestart
DEBUG - Handling deprecation for mapreduce.client.progressmonitor.pollinterval
DEBUG - Handling deprecation for dfs.client.https.keystore.resource
DEBUG - Handling deprecation for mapreduce.task.profile.map.params
DEBUG - Handling deprecation for mapreduce.jobtracker.tasktracker.maxblacklists
DEBUG - Handling deprecation for mapreduce.job.queuename
DEBUG - Handling deprecation for hadoop.registry.zk.quorum
DEBUG - Handling deprecation for yarn.app.mapreduce.client-am.ipc.max-retries-on-timeouts
DEBUG - Handling deprecation for yarn.nodemanager.localizer.address
DEBUG - Handling deprecation for io.mapfile.bloom.error.rate
DEBUG - Handling deprecation for yarn.nodemanager.delete.thread-count
DEBUG - Handling deprecation for mapreduce.job.split.metainfo.maxsize
DEBUG - Handling deprecation for yarn.scheduler.maximum-allocation-vcores
DEBUG - Handling deprecation for mapred.mapper.new-api
DEBUG - Handling deprecation for mapreduce.job.dir
DEBUG - Handling deprecation for yarn.app.mapreduce.am.resource.mb
DEBUG - Handling deprecation for dfs.datanode.dns.nameserver
DEBUG - Handling deprecation for dfs.client.slow.io.warning.threshold.ms
DEBUG - Handling deprecation for mapreduce.job.reducer.preempt.delay.sec
DEBUG - Handling deprecation for yarn.nodemanager.disk-health-checker.min-free-space-per-disk-mb
DEBUG - Handling deprecation for mapreduce.map.output.compress.codec
DEBUG - Handling deprecation for dfs.namenode.accesstime.precision
DEBUG - Handling deprecation for fs.s3a.connection.maximum
DEBUG - Handling deprecation for mapreduce.map.log.level
DEBUG - Handling deprecation for io.seqfile.compress.blocksize
DEBUG - Handling deprecation for ipc.client.ping
DEBUG - Handling deprecation for mapreduce.tasktracker.taskcontroller
DEBUG - Handling deprecation for hadoop.security.groups.cache.secs
DEBUG - Handling deprecation for dfs.datanode.cache.revocation.timeout.ms
DEBUG - Handling deprecation for dfs.client.context
DEBUG - Handling deprecation for mapreduce.input.lineinputformat.linespermap
DEBUG - Handling deprecation for mapreduce.job.end-notification.max.attempts
DEBUG - Handling deprecation for yarn.nodemanager.linux-container-executor.nonsecure-mode.local-user
DEBUG - Handling deprecation for yarn.nodemanager.webapp.address
DEBUG - Handling deprecation for mapreduce.job.submithostname
DEBUG - Handling deprecation for mapreduce.jobhistory.recovery.enable
DEBUG - Handling deprecation for mapreduce.jobtracker.expire.trackers.interval
DEBUG - Handling deprecation for yarn.resourcemanager.webapp.address
DEBUG - Handling deprecation for hadoop.security.kms.client.encrypted.key.cache.num.refill.threads
DEBUG - Handling deprecation for yarn.nodemanager.health-checker.interval-ms
DEBUG - Handling deprecation for mapreduce.jobhistory.loadedjobs.cache.size
DEBUG - Handling deprecation for hadoop.security.authorization
DEBUG - Handling deprecation for mapreduce.job.map.output.collector.class
DEBUG - Handling deprecation for mapreduce.am.max-attempts
DEBUG - Handling deprecation for fs.ftp.host
DEBUG - Handling deprecation for fs.s3a.attempts.maximum
DEBUG - Handling deprecation for yarn.app.mapreduce.am.scheduler.heartbeat.interval-ms
DEBUG - Handling deprecation for mapreduce.ifile.readahead
DEBUG - Handling deprecation for yarn.resourcemanager.scheduler.monitor.enable
DEBUG - Handling deprecation for yarn.resourcemanager.zk-retry-interval-ms
DEBUG - Handling deprecation for ha.zookeeper.session-timeout.ms
DEBUG - Handling deprecation for mapreduce.tasktracker.taskmemorymanager.monitoringinterval
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.parallelcopies
DEBUG - Handling deprecation for dfs.client.mmap.retry.timeout.ms
DEBUG - Handling deprecation for mapreduce.map.skip.maxrecords
DEBUG - Handling deprecation for mapreduce.job.output.value.class
DEBUG - Handling deprecation for dfs.namenode.avoid.read.stale.datanode
DEBUG - Handling deprecation for dfs.https.enable
DEBUG - Handling deprecation for yarn.timeline-service.webapp.https.address
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.read.timeout
DEBUG - Handling deprecation for dfs.namenode.list.encryption.zones.num.responses
DEBUG - Handling deprecation for yarn.nodemanager.remote-app-log-dir-suffix
DEBUG - Handling deprecation for mapreduce.output.fileoutputformat.compress.codec
DEBUG - Handling deprecation for mapreduce.jobtracker.instrumentation
DEBUG - Handling deprecation for dfs.blockreport.intervalMsec
DEBUG - Handling deprecation for ipc.client.connect.retry.interval
DEBUG - Handling deprecation for mapreduce.reduce.speculative
DEBUG - Handling deprecation for mapreduce.jobhistory.keytab
DEBUG - Handling deprecation for mapreduce.jobhistory.datestring.cache.size
DEBUG - Handling deprecation for dfs.datanode.balance.bandwidthPerSec
DEBUG - Handling deprecation for file.blocksize
DEBUG - Handling deprecation for yarn.resourcemanager.admin.address
DEBUG - Handling deprecation for mapreduce.map.cpu.vcores
DEBUG - Handling deprecation for yarn.nodemanager.container-monitor.procfs-tree.smaps-based-rss.enabled
DEBUG - Handling deprecation for yarn.resourcemanager.configuration.provider-class
DEBUG - Handling deprecation for yarn.resourcemanager.resource-tracker.address
DEBUG - Handling deprecation for mapreduce.tasktracker.local.dir.minspacekill
DEBUG - Handling deprecation for mapreduce.jobtracker.staging.root.dir
DEBUG - Handling deprecation for mapreduce.jobtracker.retiredjobs.cache.size
DEBUG - Handling deprecation for hadoop.registry.rm.enabled
DEBUG - Handling deprecation for ipc.client.connect.max.retries.on.timeouts
DEBUG - Handling deprecation for ha.zookeeper.acl
DEBUG - Handling deprecation for hadoop.security.crypto.codec.classes.aes.ctr.nopadding
DEBUG - Handling deprecation for yarn.nodemanager.local-dirs
DEBUG - Handling deprecation for mapreduce.app-submission.cross-platform
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.connect.timeout
DEBUG - Handling deprecation for dfs.block.access.key.update.interval
DEBUG - Handling deprecation for rpc.metrics.quantile.enable
DEBUG - Handling deprecation for dfs.block.access.token.lifetime
DEBUG - Handling deprecation for mapreduce.job.end-notification.retry.attempts
DEBUG - Handling deprecation for dfs.namenode.fs-limits.max-xattrs-per-inode
DEBUG - Handling deprecation for mapreduce.jobtracker.system.dir
DEBUG - Handling deprecation for dfs.client.file-block-storage-locations.timeout.millis
DEBUG - Handling deprecation for yarn.nodemanager.admin-env
DEBUG - Handling deprecation for mapreduce.jobtracker.jobhistory.block.size
DEBUG - Handling deprecation for yarn.log-aggregation.retain-seconds
DEBUG - Handling deprecation for mapreduce.tasktracker.indexcache.mb
DEBUG - Handling deprecation for yarn.timeline-service.handler-thread-count
DEBUG - Handling deprecation for dfs.namenode.checkpoint.check.period
DEBUG - Handling deprecation for yarn.resourcemanager.hostname
DEBUG - Handling deprecation for dfs.client.block.write.replace-datanode-on-failure.enable
DEBUG - Handling deprecation for net.topology.impl
DEBUG - Handling deprecation for dfs.datanode.directoryscan.interval
DEBUG - Handling deprecation for fs.s3a.multipart.purge.age
DEBUG - Handling deprecation for hadoop.security.java.secure.random.algorithm
DEBUG - Handling deprecation for yarn.nodemanager.container-monitor.interval-ms
DEBUG - Handling deprecation for dfs.default.chunk.view.size
DEBUG - Handling deprecation for fs.s3a.multipart.threshold
DEBUG - Handling deprecation for mapreduce.job.speculative.slownodethreshold
DEBUG - Handling deprecation for mapreduce.job.reduce.slowstart.completedmaps
DEBUG - Handling deprecation for mapred.reducer.new-api
DEBUG - Handling deprecation for hadoop.security.instrumentation.requires.admin
DEBUG - Handling deprecation for io.compression.codec.bzip2.library
DEBUG - Handling deprecation for hadoop.http.authentication.signature.secret.file
DEBUG - Handling deprecation for hadoop.registry.secure
DEBUG - Handling deprecation for dfs.namenode.safemode.min.datanodes
DEBUG - Handling deprecation for yarn.nodemanager.localizer.cache.target-size-mb
DEBUG - Handling deprecation for mapreduce.input.fileinputformat.inputdir
DEBUG - Handling deprecation for mapreduce.reduce.maxattempts
DEBUG - Handling deprecation for dfs.datanode.https.address
DEBUG - Handling deprecation for s3native.replication
DEBUG - Handling deprecation for dfs.namenode.inotify.max.events.per.rpc
DEBUG - Handling deprecation for dfs.namenode.path.based.cache.retry.interval.ms
DEBUG - Handling deprecation for mapreduce.reduce.skip.proc.count.autoincr
DEBUG - Handling deprecation for dfs.datanode.cache.revocation.polling.ms
DEBUG - Handling deprecation for mapreduce.jobhistory.cleaner.interval-ms
DEBUG - Handling deprecation for file.replication
DEBUG - Handling deprecation for hadoop.hdfs.configuration.version
DEBUG - Handling deprecation for ipc.client.idlethreshold
DEBUG - Handling deprecation for hadoop.tmp.dir
DEBUG - Handling deprecation for yarn.resourcemanager.store.class
DEBUG - Handling deprecation for mapreduce.jobhistory.address
DEBUG - Handling deprecation for mapreduce.jobtracker.restart.recover
DEBUG - Handling deprecation for mapreduce.cluster.local.dir
DEBUG - Handling deprecation for yarn.client.nodemanager-client-async.thread-pool-max-size
DEBUG - Handling deprecation for dfs.namenode.decommission.nodes.per.interval
DEBUG - Handling deprecation for mapreduce.job.inputformat.class
DEBUG - Handling deprecation for yarn.nodemanager.resource.cpu-vcores
DEBUG - Handling deprecation for dfs.namenode.reject-unresolved-dn-topology-mapping
DEBUG - Handling deprecation for dfs.namenode.delegation.key.update-interval
DEBUG - Handling deprecation for fs.s3.buffer.dir
DEBUG - Handling deprecation for dfs.client.read.shortcircuit.streams.cache.expiry.ms
DEBUG - Handling deprecation for dfs.namenode.support.allow.format
DEBUG - Handling deprecation for yarn.nodemanager.remote-app-log-dir
DEBUG - Handling deprecation for mapreduce.map.memory.mb
DEBUG - Handling deprecation for dfs.namenode.edit.log.autoroll.multiplier.threshold
DEBUG - Handling deprecation for hadoop.work.around.non.threadsafe.getpwuid
DEBUG - Handling deprecation for mapreduce.task.profile.reduce.params
DEBUG - Handling deprecation for yarn.timeline-service.client.max-retries
DEBUG - Handling deprecation for dfs.ha.automatic-failover.enabled
DEBUG - Handling deprecation for dfs.namenode.edits.noeditlogchannelflush
DEBUG - Handling deprecation for dfs.namenode.stale.datanode.interval
DEBUG - Handling deprecation for mapreduce.shuffle.transfer.buffer.size
DEBUG - Handling deprecation for mapreduce.jobtracker.persist.jobstatus.active
DEBUG - Handling deprecation for dfs.namenode.logging.level
DEBUG - Handling deprecation for yarn.resourcemanager.am-rm-tokens.master-key-rolling-interval-secs
DEBUG - Handling deprecation for yarn.nodemanager.log-dirs
DEBUG - Handling deprecation for ha.health-monitor.sleep-after-disconnect.ms
DEBUG - Handling deprecation for yarn.resourcemanager.fs.state-store.uri
DEBUG - Handling deprecation for dfs.namenode.checkpoint.edits.dir
DEBUG - Handling deprecation for yarn.resourcemanager.keytab
DEBUG - Handling deprecation for hadoop.rpc.socket.factory.class.default
DEBUG - Handling deprecation for yarn.resourcemanager.fail-fast
DEBUG - Handling deprecation for dfs.datanode.http.address
DEBUG - Handling deprecation for mapreduce.task.profile
DEBUG - Handling deprecation for mapreduce.jobhistory.move.interval-ms
DEBUG - Handling deprecation for dfs.namenode.edits.dir
DEBUG - Handling deprecation for dfs.storage.policy.enabled
DEBUG - Handling deprecation for hadoop.security.kms.client.encrypted.key.cache.size
DEBUG - Handling deprecation for hadoop.fuse.timer.period
DEBUG - Handling deprecation for mapreduce.jobhistory.http.policy
DEBUG - Handling deprecation for mapreduce.jobhistory.intermediate-done-dir
DEBUG - Handling deprecation for mapreduce.map.skip.proc.count.autoincr
DEBUG - Handling deprecation for fs.AbstractFileSystem.viewfs.impl
DEBUG - Handling deprecation for mapreduce.job.speculative.slowtaskthreshold
DEBUG - Handling deprecation for yarn.resourcemanager.webapp.delegation-token-auth-filter.enabled
DEBUG - Handling deprecation for s3native.stream-buffer-size
DEBUG - Handling deprecation for yarn.nodemanager.delete.debug-delay-sec
DEBUG - Handling deprecation for dfs.secondary.namenode.kerberos.internal.spnego.principal
DEBUG - Handling deprecation for dfs.datanode.available-space-volume-choosing-policy.balanced-space-threshold
DEBUG - Handling deprecation for fs.s3n.multipart.uploads.block.size
DEBUG - Handling deprecation for dfs.namenode.safemode.threshold-pct
DEBUG - Handling deprecation for mapreduce.ifile.readahead.bytes
DEBUG - Handling deprecation for yarn.scheduler.maximum-allocation-mb
DEBUG - Handling deprecation for ipc.client.fallback-to-simple-auth-allowed
DEBUG - Handling deprecation for fs.har.impl.disable.cache
DEBUG - Handling deprecation for yarn.timeline-service.leveldb-timeline-store.read-cache-size
DEBUG - Handling deprecation for yarn.timeline-service.hostname
DEBUG - Handling deprecation for s3native.bytes-per-checksum
DEBUG - Handling deprecation for mapreduce.job.committer.setup.cleanup.needed
DEBUG - Handling deprecation for yarn.timeline-service.leveldb-timeline-store.ttl-interval-ms
DEBUG - Handling deprecation for fs.s3a.paging.maximum
DEBUG - Handling deprecation for yarn.client.nodemanager-connect.retry-interval-ms
DEBUG - Handling deprecation for yarn.nodemanager.log-aggregation.compression-type
DEBUG - Handling deprecation for yarn.app.mapreduce.am.job.committer.commit-window
DEBUG - Handling deprecation for hadoop.http.authentication.type
DEBUG - Handling deprecation for dfs.client.failover.sleep.base.millis
DEBUG - Handling deprecation for mapreduce.job.submithostaddress
DEBUG - Handling deprecation for yarn.nodemanager.vmem-check-enabled
DEBUG - Handling deprecation for hadoop.jetty.logs.serve.aliases
DEBUG - Handling deprecation for ha.failover-controller.graceful-fence.rpc-timeout.ms
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.input.buffer.percent
DEBUG - Handling deprecation for dfs.datanode.max.transfer.threads
DEBUG - Handling deprecation for mapreduce.reduce.merge.inmem.threshold
DEBUG - Handling deprecation for mapreduce.task.io.sort.mb
DEBUG - Handling deprecation for dfs.namenode.acls.enabled
DEBUG - Handling deprecation for yarn.client.application-client-protocol.poll-interval-ms
DEBUG - Handling deprecation for hadoop.security.kms.client.authentication.retry-count
DEBUG - Handling deprecation for dfs.namenode.handler.count
DEBUG - Handling deprecation for yarn.resourcemanager.connect.max-wait.ms
DEBUG - Handling deprecation for dfs.namenode.retrycache.heap.percent
DEBUG - Handling deprecation for yarn.timeline-service.enabled
DEBUG - Handling deprecation for yarn.nodemanager.linux-container-executor.nonsecure-mode.limit-users
DEBUG - Handling deprecation for hadoop.ssl.client.conf
DEBUG - Handling deprecation for yarn.resourcemanager.container.liveness-monitor.interval-ms
DEBUG - Handling deprecation for yarn.nodemanager.vmem-pmem-ratio
DEBUG - Handling deprecation for mapreduce.client.completion.pollinterval
DEBUG - Handling deprecation for yarn.app.mapreduce.client.max-retries
DEBUG - Handling deprecation for hadoop.ssl.enabled
DEBUG - Handling deprecation for fs.client.resolve.remote.symlinks
DEBUG - Handling deprecation for fs.AbstractFileSystem.hdfs.impl
DEBUG - Handling deprecation for mapreduce.tasktracker.reduce.tasks.maximum
DEBUG - Handling deprecation for yarn.nodemanager.hostname
DEBUG - Handling deprecation for mapreduce.reduce.input.buffer.percent
DEBUG - Handling deprecation for fs.s3a.multipart.purge
DEBUG - Handling deprecation for yarn.app.mapreduce.am.command-opts
DEBUG - Handling deprecation for dfs.namenode.invalidate.work.pct.per.iteration
DEBUG - Handling deprecation for dfs.bytes-per-checksum
DEBUG - Handling deprecation for yarn.resourcemanager.webapp.https.address
DEBUG - Handling deprecation for dfs.replication
DEBUG - Handling deprecation for dfs.datanode.block.id.layout.upgrade.threads
DEBUG - Handling deprecation for mapreduce.shuffle.ssl.file.buffer.size
DEBUG - Handling deprecation for dfs.namenode.list.cache.directives.num.responses
DEBUG - Handling deprecation for dfs.permissions.enabled
DEBUG - Handling deprecation for mapreduce.jobtracker.maxtasks.perjob
DEBUG - Handling deprecation for dfs.datanode.use.datanode.hostname
DEBUG - Handling deprecation for mapreduce.task.userlog.limit.kb
DEBUG - Handling deprecation for dfs.namenode.fs-limits.max-directory-items
DEBUG - Handling deprecation for hadoop.security.kms.client.encrypted.key.cache.low-watermark
DEBUG - Handling deprecation for fs.s3a.buffer.dir
DEBUG - Handling deprecation for s3.client-write-packet-size
DEBUG - Handling deprecation for hadoop.user.group.static.mapping.overrides
DEBUG - Handling deprecation for mapreduce.shuffle.max.threads
DEBUG - Handling deprecation for hadoop.security.kms.client.encrypted.key.cache.expiry
DEBUG - Handling deprecation for dfs.client.failover.sleep.max.millis
DEBUG - Handling deprecation for mapreduce.job.maps
DEBUG - Handling deprecation for dfs.namenode.fs-limits.max-component-length
DEBUG - Handling deprecation for yarn.fail-fast
DEBUG - Handling deprecation for hadoop.ssl.enabled.protocols
DEBUG - Handling deprecation for s3.blocksize
DEBUG - Handling deprecation for mapreduce.map.output.compress
DEBUG - Handling deprecation for dfs.namenode.edits.journal-plugin.qjournal
DEBUG - Handling deprecation for dfs.namenode.datanode.registration.ip-hostname-check
DEBUG - Handling deprecation for yarn.nodemanager.pmem-check-enabled
DEBUG - Handling deprecation for dfs.client.short.circuit.replica.stale.threshold.ms
DEBUG - Handling deprecation for dfs.client.https.need-auth
DEBUG - Handling deprecation for yarn.scheduler.minimum-allocation-mb
DEBUG - Handling deprecation for mapreduce.jobhistory.max-age-ms
DEBUG - Handling deprecation for yarn.timeline-service.http-authentication.type
DEBUG - Handling deprecation for ftp.replication
DEBUG - Handling deprecation for dfs.namenode.secondary.https-address
DEBUG - Handling deprecation for dfs.blockreport.split.threshold
DEBUG - Handling deprecation for mapreduce.input.fileinputformat.split.minsize
DEBUG - Handling deprecation for fs.s3n.block.size
DEBUG - Handling deprecation for mapreduce.job.token.tracking.ids.enabled
DEBUG - Handling deprecation for yarn.ipc.rpc.class
DEBUG - Handling deprecation for dfs.namenode.num.extra.edits.retained
DEBUG - Handling deprecation for yarn.nodemanager.localizer.cache.cleanup.interval-ms
DEBUG - Handling deprecation for hadoop.http.staticuser.user
DEBUG - Handling deprecation for mapreduce.jobhistory.move.thread-count
DEBUG - Handling deprecation for fs.s3a.multipart.size
DEBUG - Handling deprecation for mapreduce.job.jvm.numtasks
DEBUG - Handling deprecation for mapreduce.task.profile.maps
DEBUG - Handling deprecation for dfs.datanode.max.locked.memory
DEBUG - Handling deprecation for dfs.cachereport.intervalMsec
DEBUG - Handling deprecation for mapreduce.shuffle.port
DEBUG - Handling deprecation for yarn.resourcemanager.nodemanager.minimum.version
DEBUG - Handling deprecation for mapreduce.shuffle.connection-keep-alive.timeout
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.merge.percent
DEBUG - Handling deprecation for mapreduce.jobtracker.http.address
DEBUG - Handling deprecation for mapreduce.task.skip.start.attempts
DEBUG - Handling deprecation for yarn.resourcemanager.connect.retry-interval.ms
DEBUG - Handling deprecation for yarn.scheduler.minimum-allocation-vcores
DEBUG - Handling deprecation for mapreduce.task.io.sort.factor
DEBUG - Handling deprecation for dfs.namenode.checkpoint.dir
DEBUG - Handling deprecation for nfs.exports.allowed.hosts
DEBUG - Handling deprecation for tfile.fs.input.buffer.size
DEBUG - Handling deprecation for fs.s3.block.size
DEBUG - Handling deprecation for tfile.io.chunk.size
DEBUG - Handling deprecation for fs.s3n.multipart.copy.block.size
DEBUG - Handling deprecation for io.serializations
DEBUG - Handling deprecation for yarn.resourcemanager.max-completed-applications
DEBUG - Handling deprecation for mapreduce.jobhistory.principal
DEBUG - Handling deprecation for mapreduce.output.fileoutputformat.outputdir
DEBUG - Handling deprecation for yarn.resourcemanager.ha.automatic-failover.zk-base-path
DEBUG - Handling deprecation for mapreduce.reduce.shuffle.fetch.retry.interval-ms
DEBUG - Handling deprecation for mapreduce.job.end-notification.retry.interval
DEBUG - Handling deprecation for dfs.namenode.backup.address
DEBUG - Handling deprecation for fs.s3n.multipart.uploads.enabled
DEBUG - Handling deprecation for io.seqfile.sorter.recordlimit
DEBUG - Handling deprecation for dfs.block.access.token.enable
DEBUG - Handling deprecation for s3native.client-write-packet-size
DEBUG - Handling deprecation for dfs.namenode.fs-limits.max-xattr-size
DEBUG - Handling deprecation for ftp.bytes-per-checksum
DEBUG - Handling deprecation for hadoop.security.group.mapping
DEBUG - Handling deprecation for dfs.client.domain.socket.data.traffic
DEBUG - Handling deprecation for dfs.client.read.shortcircuit.streams.cache.size
DEBUG - Handling deprecation for fs.s3a.connection.timeout
DEBUG - Handling deprecation for mapreduce.job.end-notification.max.retry.interval
DEBUG - Handling deprecation for yarn.acl.enable
DEBUG - Handling deprecation for yarn.nm.liveness-monitor.expiry-interval-ms
DEBUG - Handling deprecation for mapreduce.input.fileinputformat.list-status.num-threads
DEBUG - Handling deprecation for dfs.client.mmap.cache.size
DEBUG - Handling deprecation for mapreduce.tasktracker.map.tasks.maximum
DEBUG - Handling deprecation for yarn.timeline-service.ttl-enable
DEBUG - Handling deprecation for yarn.nodemanager.linux-container-executor.resources-handler.class
DEBUG - Handling deprecation for dfs.namenode.max.objects
DEBUG - Handling deprecation for yarn.resourcemanager.state-store.max-completed-applications
DEBUG - Handling deprecation for dfs.namenode.delegation.token.max-lifetime
DEBUG - Handling deprecation for mapreduce.job.classloader
DEBUG - Handling deprecation for yarn.timeline-service.leveldb-timeline-store.start-time-write-cache-size
DEBUG - Handling deprecation for mapreduce.job.hdfs-servers
DEBUG - Handling deprecation for dfs.datanode.hdfs-blocks-metadata.enabled
DEBUG - Handling deprecation for mapreduce.tasktracker.dns.nameserver
DEBUG - Handling deprecation for dfs.datanode.readahead.bytes
DEBUG - Handling deprecation for dfs.datanode.bp-ready.timeout
DEBUG - Handling deprecation for mapreduce.job.ubertask.maxreduces
DEBUG - Handling deprecation for dfs.image.compress
DEBUG - Handling deprecation for mapreduce.shuffle.ssl.enabled
DEBUG - Handling deprecation for yarn.log-aggregation-enable
DEBUG - Handling deprecation for mapreduce.tasktracker.report.address
DEBUG - Handling deprecation for mapreduce.tasktracker.http.threads
DEBUG - Handling deprecation for dfs.stream-buffer-size
DEBUG - Handling deprecation for tfile.fs.output.buffer.size
DEBUG - Handling deprecation for fs.permissions.umask-mode
DEBUG - Handling deprecation for dfs.client.datanode-restart.timeout
DEBUG - Handling deprecation for dfs.namenode.resource.du.reserved
DEBUG - Handling deprecation for yarn.resourcemanager.am.max-attempts
DEBUG - Handling deprecation for yarn.nodemanager.resource.percentage-physical-cpu-limit
DEBUG - Handling deprecation for ha.failover-controller.graceful-fence.connection.retries
DEBUG - Handling deprecation for dfs.datanode.drop.cache.behind.writes
DEBUG - Handling deprecation for mapreduce.map.output.value.class
DEBUG - Handling deprecation for hadoop.common.configuration.version
DEBUG - Handling deprecation for mapreduce.job.ubertask.enable
DEBUG - Handling deprecation for yarn.app.mapreduce.am.resource.cpu-vcores
DEBUG - Handling deprecation for dfs.namenode.replication.work.multiplier.per.iteration
DEBUG - Handling deprecation for mapreduce.job.acl-modify-job
DEBUG - Handling deprecation for io.seqfile.local.dir
DEBUG - Handling deprecation for yarn.resourcemanager.system-metrics-publisher.enabled
DEBUG - Handling deprecation for fs.s3.sleepTimeSeconds
DEBUG - Handling deprecation for mapreduce.client.output.filter
INFO - The url to track the job: http://localhost:8080/
INFO - Running job: job_local1553403857_0001
INFO - OutputCommitter set in config null
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.mapreduce.Job.updateStatus(Job.java:)
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.mapreduce.Job.updateStatus(Job.java:)
INFO - OutputCommitter is org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter
DEBUG - Starting mapper thread pool executor.
DEBUG - Max local threads:
DEBUG - Map tasks to process:
INFO - Waiting for map tasks
INFO - Starting task: attempt_local1553403857_0001_m_000000_0
DEBUG - currentIndex :
DEBUG - mapreduce.cluster.local.dir for child : /tmp/hadoop-SYJ/mapred/local/localRunner//SYJ/jobcache/job_local1553403857_0001/attempt_local1553403857_0001_m_000000_0
DEBUG - using new api for output committer
INFO - ProcfsBasedProcessTree currently is supported only on Linux.
INFO - Using ResourceCalculatorProcessTree : org.apache.hadoop.yarn.util.WindowsBasedProcessTree@5e2c17f7
INFO - Processing split: file:/c:/wordcount/input/words.txt:+
DEBUG - Trying map output collector class: org.apache.hadoop.mapred.MapTask$MapOutputBuffer
INFO - (EQUATOR) kvi ()
INFO - mapreduce.task.io.sort.mb:
INFO - soft limit at
INFO - bufstart = ; bufvoid =
INFO - kvstart = ; length =
INFO - Map output collector class = org.apache.hadoop.mapred.MapTask$MapOutputBuffer
INFO -
INFO - Starting flush of map output
INFO - Spilling map output
INFO - bufstart = ; bufend = ; bufvoid =
INFO - kvstart = (); kvend = (); length = /
INFO - Finished spill
INFO - Task:attempt_local1553403857_0001_m_000000_0 is done. And is in the process of committing
INFO - map
INFO - Task 'attempt_local1553403857_0001_m_000000_0' done.
INFO - Finishing task: attempt_local1553403857_0001_m_000000_0
INFO - map task executor complete.
DEBUG - Starting reduce thread pool executor.
DEBUG - Max local threads:
DEBUG - Reduce tasks to process:
INFO - Waiting for reduce tasks
INFO - Starting task: attempt_local1553403857_0001_r_000000_0
DEBUG - currentIndex :
DEBUG - mapreduce.cluster.local.dir for child : /tmp/hadoop-SYJ/mapred/local/localRunner//SYJ/jobcache/job_local1553403857_0001/attempt_local1553403857_0001_r_000000_0
DEBUG - using new api for output committer
INFO - ProcfsBasedProcessTree currently is supported only on Linux.
INFO - Using ResourceCalculatorProcessTree : org.apache.hadoop.yarn.util.WindowsBasedProcessTree@41217e67
INFO - Using ShuffleConsumerPlugin: org.apache.hadoop.mapreduce.task.reduce.Shuffle@
INFO - MergerManager: memoryLimit=, maxSingleShuffleLimit=, mergeThreshold=, ioSortFactor=, memToMemMergeOutputsThreshold=
INFO - attempt_local1553403857_0001_r_000000_0 Thread started: EventFetcher for fetching Map Completion Events
DEBUG - Got map completion events from
DEBUG - GetMapEventsThread about to sleep for
DEBUG - LocalFetcher going to fetch: attempt_local1553403857_0001_m_000000_0
DEBUG - attempt_local1553403857_0001_m_000000_0: Proceeding with shuffle since usedMemory () is lesser than memoryLimit ().CommitMemory is ()
INFO - localfetcher# about to shuffle output of map attempt_local1553403857_0001_m_000000_0 decomp: len: to MEMORY
INFO - Read bytes from map-output for attempt_local1553403857_0001_m_000000_0
INFO - closeInMemoryFile -> map-output of size: , inMemoryMapOutputs.size() -> , commitMemory -> , usedMemory ->
DEBUG - map attempt_local1553403857_0001_m_000000_0 done / copied.
INFO - EventFetcher is interrupted.. Returning
INFO - / copied.
INFO - finalMerge called with in-memory map-outputs and on-disk map-outputs
INFO - Merging sorted segments
INFO - Down to the last merge-pass, with segments left of total size: bytes
INFO - Merged segments, bytes to disk to satisfy reduce memory limit
DEBUG - Disk file: /tmp/hadoop-SYJ/mapred/local/localRunner/SYJ/jobcache/job_local1553403857_0001/attempt_local1553403857_0001_r_000000_0/output/map_0.out.merged Length is
INFO - Merging files, bytes from disk
INFO - Merging segments, bytes from memory into reduce
INFO - Merging sorted segments
INFO - Down to the last merge-pass, with segments left of total size: bytes
INFO - / copied.
INFO - mapred.skip.on is deprecated. Instead, use mapreduce.job.skiprecords
INFO - Task:attempt_local1553403857_0001_r_000000_0 is done. And is in the process of committing
INFO - / copied.
INFO - Task attempt_local1553403857_0001_r_000000_0 is allowed to commit now
INFO - Saved output of task 'attempt_local1553403857_0001_r_000000_0' to file:/c:/wordcount/output/_temporary//task_local1553403857_0001_r_000000
INFO - reduce > reduce
INFO - Task 'attempt_local1553403857_0001_r_000000_0' done.
INFO - Finishing task: attempt_local1553403857_0001_r_000000_0
INFO - reduce task executor complete.
DEBUG - Merging data from DeprecatedRawLocalFileStatus{path=file:/c:/wordcount/output/_temporary//task_local1553403857_0001_r_000000; isDirectory=true; modification_time=; access_time=; owner=; group=; permission=rwxrwxrwx; isSymlink=false} to file:/c:/wordcount/output
DEBUG - Merging data from DeprecatedRawLocalFileStatus{path=file:/c:/wordcount/output/_temporary//task_local1553403857_0001_r_000000/part-r-; isDirectory=false; length=; replication=; blocksize=; modification_time=; access_time=; owner=; group=; permission=rw-rw-rw-; isSymlink=false} to file:/c:/wordcount/output/part-r-
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.fs.FileContext.getAbstractFileSystem(FileContext.java:)
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.mapreduce.Job.updateStatus(Job.java:)
INFO - Job job_local1553403857_0001 running in uber mode : false
INFO - map % reduce %
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.mapreduce.Job.getTaskCompletionEvents(Job.java:)
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.mapreduce.Job.updateStatus(Job.java:)
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.mapreduce.Job.updateStatus(Job.java:)
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.mapreduce.Job.getTaskCompletionEvents(Job.java:)
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.mapreduce.Job.updateStatus(Job.java:)
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.mapreduce.Job.updateStatus(Job.java:)
INFO - Job job_local1553403857_0001 completed successfully
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.mapreduce.Job.getCounters(Job.java:)
INFO - Counters:
File System Counters
FILE: Number of bytes read=
FILE: Number of bytes written=
FILE: Number of read operations=
FILE: Number of large read operations=
FILE: Number of write operations=
Map-Reduce Framework
Map input records=
Map output records=
Map output bytes=
Map output materialized bytes=
Input split bytes=
Combine input records=
Combine output records=
Reduce input groups=
Reduce shuffle bytes=
Reduce input records=
Reduce output records=
Spilled Records=
Shuffled Maps =
Failed Shuffles=
Merged Map outputs=
GC time elapsed (ms)=
CPU time spent (ms)=
Physical memory (bytes) snapshot=
Virtual memory (bytes) snapshot=
Total committed heap usage (bytes)=
Shuffle Errors
BAD_ID=
CONNECTION=
IO_ERROR=
WRONG_LENGTH=
WRONG_MAP=
WRONG_REDUCE=
File Input Format Counters
Bytes Read=
File Output Format Counters
Bytes Written=
DEBUG - PrivilegedAction as:SYJ (auth:SIMPLE) from:org.apache.hadoop.mapreduce.Job.updateStatus(Job.java:)

19.到"c:/wordcount"目录下面可以看到生成的output目录,下面有一些输出结果文件,其中"part-r-00000"文件就是程序运算的结果:

如果觉得本文对您有帮助,不妨扫描下方微信二维码打赏点,您的鼓励是我前进最大的动力:

如何在Windows下面运行hadoop的MapReduce程序的更多相关文章

  1. Windows下运行Hadoop

    Windows下运行Hadoop,通常有两种方式:一种是用VM方式安装一个Linux操作系统,这样基本可以实现全Linux环境的Hadoop运行:另一种是通过Cygwin模拟Linux环境.后者的好处 ...

  2. # 如何在Windows下运行Linux程序

    如何在Windows下运行Linux程序 一.搭建 Linux 环境 1.1 安装 VMware Workstation https://www.aliyundrive.com/s/TvuMyFdTs ...

  3. windows环境下Eclipse开发MapReduce程序遇到的四个问题及解决办法

    按此文章<Hadoop集群(第7期)_Eclipse开发环境设置>进行MapReduce开发环境搭建的过程中遇到一些问题,饶了一些弯路,解决办法记录在此: 文档目的: 记录windows环 ...

  4. 用PHP编写Hadoop的MapReduce程序

    用PHP编写Hadoop的MapReduce程序     Hadoop流 虽然Hadoop是用Java写的,但是Hadoop提供了Hadoop流,Hadoop流提供一个API, 允许用户使用任何语言编 ...

  5. Hadoop之MapReduce程序应用三

    摘要:MapReduce程序进行数据去重. 关键词:MapReduce   数据去重 数据源:人工构造日志数据集log-file1.txt和log-file2.txt. log-file1.txt内容 ...

  6. 使用命令行编译打包运行自己的MapReduce程序 Hadoop2.6.0

    使用命令行编译打包运行自己的MapReduce程序 Hadoop2.6.0 网上的 MapReduce WordCount 教程对于如何编译 WordCount.java 几乎是一笔带过… 而有写到的 ...

  7. 使 IIS 6.0 可以在 64 位 Windows 上运行 32 位应用程序 试图加载格式不正确的程序。

    原文 使 IIS 6.0 可以在 64 位 Windows 上运行 32 位应用程序 试图加载格式不正确的程序. win7 64位操作系统上边运行IIS网站应用的时候,提示错误"试图加载格式 ...

  8. 如何在Hadoop的MapReduce程序中处理JSON文件

    简介: 最近在写MapReduce程序处理日志时,需要解析JSON配置文件,简化Java程序和处理逻辑.但是Hadoop本身似乎没有内置对JSON文件的解析功能,我们不得不求助于第三方JSON工具包. ...

  9. 【爬坑】运行 Hadoop 的 MapReduce 示例卡住了

    1. 问题说明 在以伪分布式模式运行 Hadoop 自带的 MapReduce 示例,卡在了 Running job ,如图所示 2. 解决过程 查看日志没得到有用的信息 再次确认配置信息没有错误信息 ...

随机推荐

  1. jquery.validate1.9.0前台验证使用

    一.利用jquery.form插件提交表单方法使用jquery.validate插件 现象:当提交表单时,即使前台未验证通过,也照常提交表单. 解决办法: $('#myForm').submit(fu ...

  2. 分别用Java和JS读取Properties文件内容

    项目中经常用到的配置文件,除了XML文件之外,还会用到Properties文件来存储一些信息,例如国际化的设置.jdbc连接信息的配置等.有时候也会把一些路径或者sql语句放到Properties中, ...

  3. java 中 SVN 设置所有文件及子目录 needs-lock, svn 提交时自动设置 needs-lock, 及版本不一致问题

    摘自: http://my.oschina.net/zhangzhihao/blog/72177 设置后的效果:文件会自动带上svn:needs-lock属性,默认是只读的要签出才能修改以防止修改完后 ...

  4. 【云计算】使用docker搭建nfs实现容器间共享文件

    首先介绍下今天的两个主角:nfs和docker nfs 是什么 NFS(Network File System)即网络文件系统,是FreeBSD支持的文件系统中的一种,它允许网络中的计算机之间通过TC ...

  5. Android选择/拍照 剪裁 base64/16进制/byte上传图片+PHP接收图片

    转载请注明出处:http://blog.csdn.net/iwanghang/article/details/65633129认为博文实用,请点赞,请评论,请关注.谢谢! ~ 老规矩,先上GIF动态图 ...

  6. C#控件一览表

    C#控件一览表 .窗体 .常用属性 ()Name属性:用来获取或设置窗体的名称,在应用程序中可通过Name属性来引用窗体. () WindowState属性: 用来获取或设置窗体的窗口状态. 取值有三 ...

  7. Think Pad T410键盘溅水有惊无险

    昨日不小心单位给配的T410溅水了,由于水不多,用餐巾纸擦干后就晾起来了. 大概过了6小时,心想现在该好了吧,于是按开机键,无效! 当时暗骂Thinkpad给LX做坏了,一点小水都挡不住,还敢号称防洒 ...

  8. PHP phpMyadmin数据库备份太大无法导入怎么

    1 如图所示,phpMyAdmin的数据库最大只能8M,大于这个体积就无法导入 2 你可以从以下网站下载这个软件Navicat for MySQL, http://www.pb86.net/soft/ ...

  9. 探寻不同版本号的SDK对iOS程序的影响

    PDF版本号:http://pan.baidu.com/s/1eQ8DVdo 结论: 同样的代码.使用不同版本号的SDK来编译.会影响MachO头中的值, 从而使程序表现出不同的外观. 代码: - ( ...

  10. tableview的两个重用cell方法

    今天在学习IAP的时候无意间看到原来  tableView: cellForRowAtIndexPath:方法中有两个获得重用cell的方法,一直以来都是用 UITableViewCell  *cel ...