org.apache.hadoop.filecache.DistributedCache.addArchiveToClassPath(Path, Configuration)
|
org.apache.hadoop.hdfs.protocol.ClientProtocol.addBlock(String, String)
use the 3-arg form below
|
org.apache.hadoop.filecache.DistributedCache.addFileToClassPath(Path, Configuration)
|
org.apache.hadoop.http.HttpServer.addInternalServlet(String, String, Class extends HttpServlet>)
this is a temporary method
|
org.apache.hadoop.http.HttpServer.addSslListener(InetSocketAddress, String, String, String)
|
org.apache.hadoop.fs.FsShell.byteDesc(long)
|
org.apache.hadoop.ipc.RPC.call(Method, Object[][], InetSocketAddress[], Configuration)
|
org.apache.hadoop.ipc.Client.call(Writable[], InetSocketAddress[])
|
org.apache.hadoop.ipc.Client.call(Writable[], InetSocketAddress[], Class>, UserGroupInformation)
|
org.apache.hadoop.ipc.Client.call(Writable, InetSocketAddress)
|
org.apache.hadoop.ipc.Client.call(Writable, InetSocketAddress, Class>, UserGroupInformation, int)
|
org.apache.hadoop.ipc.Client.call(Writable, InetSocketAddress, UserGroupInformation)
|
org.apache.hadoop.ipc.Server.call(Writable, long)
|
org.apache.hadoop.hdfs.DistributedFileSystem.cancelDelegationToken(Token)
Use Token.cancel instead.
|
org.apache.hadoop.hdfs.DFSClient.cancelDelegationToken(Token)
Use Token.cancel instead.
|
org.apache.hadoop.mapred.TaskLog.captureOutAndError(List, List, File, File, long, boolean, String)
pidFiles are no more used. Instead pid is exported to
env variable JVM_PID.
|
org.apache.hadoop.mapred.TaskLog.captureOutAndError(List, List, File, File, long, String)
pidFiles are no more used. Instead pid is exported to
env variable JVM_PID.
|
org.apache.hadoop.mapred.OutputCommitter.cleanupJob(JobContext)
|
org.apache.hadoop.mapred.OutputCommitter.cleanupJob(JobContext) |
org.apache.hadoop.mapred.FileOutputCommitter.cleanupJob(JobContext) |
org.apache.hadoop.mapreduce.OutputCommitter.cleanupJob(JobContext)
|
org.apache.hadoop.mapreduce.lib.output.FileOutputCommitter.cleanupJob(JobContext) |
org.apache.hadoop.io.WritableUtils.cloneInto(Writable, Writable)
use ReflectionUtils.cloneInto instead.
|
org.apache.hadoop.util.ReflectionUtils.cloneWritableInto(Writable, Writable) |
org.apache.hadoop.tools.DistCp.copy(Configuration, String, String, Path, boolean, boolean) |
org.apache.hadoop.hdfs.server.namenode.NameNode.create(String, FsPermission, String, boolean, short, long) |
org.apache.hadoop.filecache.DistributedCache.createAllSymlink(Configuration, File, File)
Internal to MapReduce framework. Use DistributedCacheManager
instead.
|
org.apache.hadoop.fs.FileSystem.createNonRecursive(Path, boolean, int, short, long, Progressable)
API only for 0.20-append
|
org.apache.hadoop.fs.FileSystem.createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable)
API only for 0.20-append
|
org.apache.hadoop.io.file.tfile.TFile.Reader.createScanner(byte[], byte[])
|
org.apache.hadoop.io.file.tfile.TFile.Reader.createScanner(RawComparable, RawComparable)
|
org.apache.hadoop.hdfs.server.datanode.DataNode.createSocketAddr(String) |
org.apache.hadoop.mapreduce.lib.db.DBRecordReader.createValue() |
org.apache.hadoop.fs.RawLocalFileSystem.delete(Path) |
org.apache.hadoop.fs.FilterFileSystem.delete(Path) |
org.apache.hadoop.fs.FileSystem.delete(Path)
Use delete(Path, boolean) instead
|
org.apache.hadoop.fs.ftp.FTPFileSystem.delete(Path)
Use delete(Path, boolean) instead
|
org.apache.hadoop.fs.kfs.KosmosFileSystem.delete(Path) |
org.apache.hadoop.fs.s3.S3FileSystem.delete(Path) |
org.apache.hadoop.fs.s3native.NativeS3FileSystem.delete(Path) |
org.apache.hadoop.hdfs.HftpFileSystem.delete(Path) |
org.apache.hadoop.hdfs.DistributedFileSystem.delete(Path) |
org.apache.hadoop.hdfs.DFSClient.delete(String) |
org.apache.hadoop.hdfs.server.namenode.NameNode.delete(String) |
org.apache.hadoop.streaming.UTF8ByteArrayUtils.findByte(byte[], int, int, byte)
|
org.apache.hadoop.streaming.UTF8ByteArrayUtils.findBytes(byte[], int, int, byte[])
|
org.apache.hadoop.mapred.Counters.findCounter(String, int, String) |
org.apache.hadoop.streaming.UTF8ByteArrayUtils.findNthByte(byte[], byte, int)
|
org.apache.hadoop.streaming.UTF8ByteArrayUtils.findNthByte(byte[], int, int, byte, int)
|
org.apache.hadoop.streaming.UTF8ByteArrayUtils.findTab(byte[])
|
org.apache.hadoop.streaming.UTF8ByteArrayUtils.findTab(byte[], int, int)
|
org.apache.hadoop.fs.FileUtil.fullyDelete(FileSystem, Path)
|
org.apache.hadoop.io.BytesWritable.get()
|
org.apache.hadoop.fs.FileSystem.getBlockSize(Path)
Use getFileStatus() instead
|
org.apache.hadoop.streaming.StreamJob.getClusterNick() |
org.apache.hadoop.mapred.JobTracker.getClusterStatus()
|
org.apache.hadoop.io.SequenceFile.getCompressionType(Configuration)
|
org.apache.hadoop.mapred.Counters.Group.getCounter(int, String)
|
org.apache.hadoop.fs.FileSystem.getDefaultBlockSize()
|
org.apache.hadoop.fs.FileSystem.getDefaultReplication()
|
org.apache.hadoop.hdfs.DistributedFileSystem.getDelegationToken(Text) |
org.apache.hadoop.hdfs.server.namenode.FSNamesystem.getDFSNameNodeAddress()
|
org.apache.hadoop.hdfs.DFSClient.getHints(String, long, long)
Use getBlockLocations instead
Get hints about the location of the indicated block(s).
getHints() returns a list of hostnames that store data for
a specific file region. It returns a set of hostnames for
every block within the indicated region.
This function is very useful when writing code that considers
data-placement when performing operations. For example, the
MapReduce system tries to schedule tasks on the same machines
as the data-block the task processes.
|
org.apache.hadoop.mapred.JobClient.getJob(String)
|
org.apache.hadoop.mapred.JobStatus.getJobId()
use getJobID instead
|
org.apache.hadoop.mapred.JobProfile.getJobId()
use getJobID() instead
|
org.apache.hadoop.mapred.RunningJob.getJobID()
This method is deprecated and will be removed. Applications should
rather use RunningJob.getID() .
|
org.apache.hadoop.mapred.JobID.getJobIDsPattern(String, Integer) |
org.apache.hadoop.fs.FileSystem.getLength(Path)
Use getFileStatus() instead
|
org.apache.hadoop.fs.kfs.KosmosFileSystem.getLength(Path) |
org.apache.hadoop.mapred.jobcontrol.Job.getMapredJobID()
|
org.apache.hadoop.mapred.JobClient.getMapTaskReports(String)
|
org.apache.hadoop.mapred.ClusterStatus.getMaxMemory() |
org.apache.hadoop.mapred.JobConf.getMaxPhysicalMemoryForTask()
this variable is deprecated and nolonger in use.
|
org.apache.hadoop.mapred.JobConf.getMaxVirtualMemoryForTask()
|
org.apache.hadoop.fs.FilterFileSystem.getName()
call #getUri() instead.
|
org.apache.hadoop.fs.FileSystem.getName()
call #getUri() instead.
|
org.apache.hadoop.fs.kfs.KosmosFileSystem.getName() |
org.apache.hadoop.hdfs.DistributedFileSystem.getName() |
org.apache.hadoop.fs.FileSystem.getNamed(String, Configuration)
call #get(URI,Configuration) instead.
|
org.apache.hadoop.mapreduce.lib.db.DBRecordReader.getPos() |
org.apache.hadoop.mapred.JobClient.getReduceTaskReports(String)
|
org.apache.hadoop.fs.FileSystem.getReplication(Path)
Use getFileStatus() instead
|
org.apache.hadoop.fs.kfs.KosmosFileSystem.getReplication(Path) |
org.apache.hadoop.net.NetUtils.getServerAddress(Configuration, String, String, String) |
org.apache.hadoop.io.BytesWritable.getSize()
|
org.apache.hadoop.fs.FileSystem.getStatistics()
|
org.apache.hadoop.mapred.TaskAttemptID.getTaskAttemptIDsPattern(String, Integer, Boolean, Integer, Integer) |
org.apache.hadoop.mapred.TaskReport.getTaskId()
|
org.apache.hadoop.mapred.TaskCompletionEvent.getTaskId()
|
org.apache.hadoop.mapred.TaskID.getTaskIDsPattern(String, Integer, Boolean, Integer) |
org.apache.hadoop.mapred.JobClient.getTaskOutputFilter() |
org.apache.hadoop.util.Shell.getUlimitMemoryCommand(Configuration)
|
org.apache.hadoop.mapred.ClusterStatus.getUsedMemory() |
org.apache.hadoop.streaming.StreamJob.go()
|
org.apache.hadoop.fs.FileSystem.isDirectory(Path)
Use getFileStatus() instead
|
org.apache.hadoop.fs.kfs.KosmosFileSystem.isDirectory(Path) |
org.apache.hadoop.hdfs.DFSClient.isDirectory(String)
Use getHdfsFileStatus() instead
|
org.apache.hadoop.fs.kfs.KosmosFileSystem.isFile(Path) |
org.apache.hadoop.mapred.RunningJob.killTask(String, boolean)
|
org.apache.hadoop.fs.FsShell.limitDecimalTo2(double)
|
org.apache.hadoop.fs.kfs.KosmosFileSystem.lock(Path, boolean) |
org.apache.hadoop.mapred.JobHistory.MapAttempt.logFailed(TaskAttemptID, long, String, String)
|
org.apache.hadoop.mapred.JobHistory.ReduceAttempt.logFailed(TaskAttemptID, long, String, String)
|
org.apache.hadoop.mapred.JobHistory.ReduceAttempt.logFinished(TaskAttemptID, long, long, long, String)
|
org.apache.hadoop.mapred.JobHistory.MapAttempt.logFinished(TaskAttemptID, long, String)
|
org.apache.hadoop.mapred.JobHistory.JobInfo.logJobInfo(JobID, long, long, int)
|
org.apache.hadoop.mapred.JobHistory.MapAttempt.logKilled(TaskAttemptID, long, String, String)
|
org.apache.hadoop.mapred.JobHistory.ReduceAttempt.logKilled(TaskAttemptID, long, String, String)
|
org.apache.hadoop.mapred.JobHistory.JobInfo.logStarted(JobID, long, int, int)
|
org.apache.hadoop.mapred.JobHistory.MapAttempt.logStarted(TaskAttemptID, long, String)
|
org.apache.hadoop.mapred.JobHistory.ReduceAttempt.logStarted(TaskAttemptID, long, String)
|
org.apache.hadoop.mapred.JobHistory.MapAttempt.logStarted(TaskAttemptID, long, String, int, String) |
org.apache.hadoop.mapred.JobHistory.ReduceAttempt.logStarted(TaskAttemptID, long, String, int, String) |
org.apache.hadoop.mapred.JobHistory.JobInfo.logSubmitted(JobID, JobConf, String, long)
|
org.apache.hadoop.io.SequenceFile.Reader.next(DataOutputBuffer)
|
org.apache.hadoop.mapreduce.lib.db.DBRecordReader.next(LongWritable, T)
|
org.apache.hadoop.hdfs.server.namenode.FSNamesystem.randomDataNode() |
org.apache.hadoop.mapred.TaskID.read(DataInput) |
org.apache.hadoop.mapred.TaskAttemptID.read(DataInput) |
org.apache.hadoop.mapred.JobID.read(DataInput) |
org.apache.hadoop.streaming.UTF8ByteArrayUtils.readLine(LineReader, Text)
|
org.apache.hadoop.fs.kfs.KosmosFileSystem.release(Path) |
org.apache.hadoop.hdfs.DistributedFileSystem.renewDelegationToken(Token)
Use Token.renew instead.
|
org.apache.hadoop.hdfs.DFSClient.renewDelegationToken(Token)
Use Token.renew instead.
|
org.apache.hadoop.io.SequenceFile.setCompressionType(Configuration, SequenceFile.CompressionType)
|
org.apache.hadoop.mapreduce.Counter.setDisplayName(String) |
org.apache.hadoop.mapred.jobcontrol.Job.setMapredJobID(String)
|
org.apache.hadoop.mapred.JobConf.setMaxPhysicalMemoryForTask(long) |
org.apache.hadoop.mapred.JobConf.setMaxVirtualMemoryForTask(long)
|
org.apache.hadoop.mapred.TaskCompletionEvent.setTaskId(String)
|
org.apache.hadoop.mapred.JobClient.setTaskOutputFilter(JobClient.TaskStatusFilter) |
org.apache.hadoop.streaming.UTF8ByteArrayUtils.splitKeyVal(byte[], int, int, Text, Text, int)
|
org.apache.hadoop.streaming.UTF8ByteArrayUtils.splitKeyVal(byte[], int, int, Text, Text, int, int)
|
org.apache.hadoop.streaming.UTF8ByteArrayUtils.splitKeyVal(byte[], Text, Text, int)
|
org.apache.hadoop.streaming.UTF8ByteArrayUtils.splitKeyVal(byte[], Text, Text, int, int)
|
org.apache.hadoop.mapred.pipes.Submitter.submitJob(JobConf)
|