|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Serialization
supports the given class.
RemoteException
.
AccessControlException
with the specified detail message.
Path
to the list of inputs for the map-reduce job.
FileInputFormat.addInputPath(JobConf, Path)
or
FileInputFormat.addInputPaths(JobConf, String)
FileSystemStore
.BufferedFSInputStream
with the specified buffer size,
and saves its argument, the input stream
in
, for later use.
param
, to the IPC server running at
address
, returning the value.
position
.
IOException
or
null pointers.
Writable
class.
JobClient
.
InputSplit
to future operations.
RecordWriter
to future operations.
IOException
IOException
.
MultiFilterRecordReader.emit(org.apache.hadoop.mapred.join.TupleWritable)
every Tuple from the
collector (the outer join of child RRs).
Comparable
.
CompressionOutputStream
to compress data.Configuration
.JobConf
.
JobConf
.
Configuration
.Group
of counters, comprising of counters from a particular
counter Enum
class.Compressor
for use by this CompressionCodec
.
SequenceFile.Reader
returned.
Decompressor
for use by this CompressionCodec
.
FsPermission
object.
PermissionStatus
object.
UnixUserGroupInformation
object.
CompressionInputStream
that will read from the given
InputStream
with the given Decompressor
.
IOException
.
CompressionOutputStream
that will write to the given
OutputStream
.
CompressionOutputStream
that will write to the given
OutputStream
with the given Compressor
.
recordName
.
recordName
.
Thread.setDaemon(boolean)
with true.DataInput
implementation that reads from an in-memory
buffer.DataOutput
implementation that writes to an in-memory
buffer.CompressionInputStream
to compress data.Stringifier
interface which stringifies the objects using base64 encoding of the
serialized version of the objects.WritableComparable
implementation.
Record
implementation.
InputStream
.RawComparator
that uses a Deserializer
to deserialize
the objects to be compared so that the standard Comparator
can
be used to compare them.o
is a ByteWritable with the same value.
o
is a DoubleWritable with the same value.
o
is a FloatWritable with the same value.
o
is a IntWritable with the same value.
o
is a LongWritable with the same value.
o
is an MD5Hash whose digest contains the
same values.
o
is a Text with the same contents.
o
is a UTF8 with the same contents.
o
is a VIntWritable with the same value.
o
is a VLongWritable with the same value.
charToEscape
in the string
with the escape char escapeChar
InputFormat
.OutputFormat
.INode
s and Block
s.FilterFileSystem
contains
some other file system, which it uses as
its basic file system, possibly transforming
the data along the way or providing additional
functionality.what
in the backing
buffer, starting as position start
.
FSInputStream
in a DataInputStream
and buffers input through a BufferedInputStream
.OutputStream
in a DataOutputStream
,
buffers output through a BufferedOutputStream
and creates a checksum
file.FsAction
.
Throwable
into a Runtime Exception.FileSystem
backed by an FTP client provided by Apache Commons Net.GenericOptionsParser
is a utility to parse command line
arguments generic to the Hadoop framework.GenericOptionsParser to parse only the generic Hadoop
arguments.
- GenericOptionsParser(Configuration, Options, String[]) -
Constructor for class org.apache.hadoop.util.GenericOptionsParser
- Create a
GenericOptionsParser
to parse given options as well
as generic Hadoop options.
- GenericsUtil - Class in org.apache.hadoop.util
- Contains utility methods for dealing with Java Generics.
- GenericsUtil() -
Constructor for class org.apache.hadoop.util.GenericsUtil
-
- GenericWritable - Class in org.apache.hadoop.io
- A wrapper for Writable instances.
- GenericWritable() -
Constructor for class org.apache.hadoop.io.GenericWritable
-
- get(String) -
Method in class org.apache.hadoop.conf.Configuration
- Get the value of the
name
property, null
if
no such property exists.
- get(String, String) -
Method in class org.apache.hadoop.conf.Configuration
- Get the value of the
name
property.
- get(int) -
Method in class org.apache.hadoop.dfs.LocatedBlocks
- Get located block.
- get(Configuration) -
Static method in class org.apache.hadoop.fs.FileSystem
- Returns the configured filesystem implementation.
- get(URI, Configuration) -
Static method in class org.apache.hadoop.fs.FileSystem
- Returns the FileSystem for this URI's scheme and authority.
- get(long, Writable) -
Method in class org.apache.hadoop.io.ArrayFile.Reader
- Return the
n
th value in the file.
- get() -
Method in class org.apache.hadoop.io.ArrayWritable
-
- get() -
Method in class org.apache.hadoop.io.BooleanWritable
- Returns the value of the BooleanWritable
- get() -
Method in class org.apache.hadoop.io.BytesWritable
- Get the data from the BytesWritable.
- get() -
Method in class org.apache.hadoop.io.ByteWritable
- Return the value of this ByteWritable.
- get() -
Method in class org.apache.hadoop.io.DoubleWritable
-
- get() -
Method in class org.apache.hadoop.io.FloatWritable
- Return the value of this FloatWritable.
- get() -
Method in class org.apache.hadoop.io.GenericWritable
- Return the wrapped instance.
- get() -
Method in class org.apache.hadoop.io.IntWritable
- Return the value of this IntWritable.
- get() -
Method in class org.apache.hadoop.io.LongWritable
- Return the value of this LongWritable.
- get(WritableComparable, Writable) -
Method in class org.apache.hadoop.io.MapFile.Reader
- Return the value for the named key, or null if none exists.
- get(Object) -
Method in class org.apache.hadoop.io.MapWritable
-
- get() -
Static method in class org.apache.hadoop.io.NullWritable
- Returns the single instance of this class.
- get() -
Method in class org.apache.hadoop.io.ObjectWritable
- Return the instance, or null if none.
- get(Text) -
Method in class org.apache.hadoop.io.SequenceFile.Metadata
-
- get(WritableComparable) -
Method in class org.apache.hadoop.io.SetFile.Reader
- Read the matching key from a set into
key
.
- get(Object) -
Method in class org.apache.hadoop.io.SortedMapWritable
-
- get() -
Method in class org.apache.hadoop.io.TwoDArrayWritable
-
- get() -
Method in class org.apache.hadoop.io.VIntWritable
- Return the value of this VIntWritable.
- get() -
Method in class org.apache.hadoop.io.VLongWritable
- Return the value of this LongWritable.
- get(Class) -
Static method in class org.apache.hadoop.io.WritableComparator
- Get a comparator for a
WritableComparable
implementation.
- get() -
Static method in class org.apache.hadoop.ipc.Server
- Returns the server instance called under or null.
- get(int) -
Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
- Get ith child InputSplit.
- get(int) -
Method in class org.apache.hadoop.mapred.join.TupleWritable
- Get ith Writable from Tuple.
- get() -
Method in class org.apache.hadoop.metrics.util.MetricsIntValue
- Get value
- get() -
Method in class org.apache.hadoop.metrics.util.MetricsLongValue
- Get value
- get(DataInput) -
Static method in class org.apache.hadoop.record.BinaryRecordInput
- Get a thread-local record input for the supplied DataInput.
- get(DataOutput) -
Static method in class org.apache.hadoop.record.BinaryRecordOutput
- Get a thread-local record output for the supplied DataOutput.
- get() -
Method in class org.apache.hadoop.record.Buffer
- Get the data from the Buffer.
- get() -
Method in class org.apache.hadoop.util.Progress
- Returns the overall progress of the root.
- getAbsolutePath(String) -
Method in class org.apache.hadoop.streaming.PathFinder
- Returns the full path name of this file if it is listed in the
path
- getAccessKey() -
Method in class org.apache.hadoop.fs.s3.S3Credentials
-
- getAddress(Configuration) -
Static method in class org.apache.hadoop.mapred.JobTracker
-
- getAllJobs() -
Method in class org.apache.hadoop.mapred.JobClient
- Get the jobs that are submitted.
- getAllJobs() -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getAllStaticResolutions() -
Static method in class org.apache.hadoop.net.NetUtils
- This is used to get all the resolutions that were added using
NetUtils.addStaticResolution(String, String)
.
- getAllTasks() -
Method in class org.apache.hadoop.mapred.JobHistory.JobInfo
- Returns all map and reduce tasks
.
- getApproxChkSumLength(long) -
Static method in class org.apache.hadoop.fs.ChecksumFileSystem
-
- getArchiveClassPaths(Configuration) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- Get the archive entries in classpath as an array of Path
- getArchiveTimestamps(Configuration) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- Get the timestamps of the archives
- getAssignedJobID() -
Method in class org.apache.hadoop.mapred.jobcontrol.Job
-
- getAssignedTracker(String) -
Method in class org.apache.hadoop.mapred.JobTracker
- Deprecated.
- getAssignedTracker(TaskAttemptID) -
Method in class org.apache.hadoop.mapred.JobTracker
- Get tracker name for a given task id.
- getAttribute(String) -
Method in class org.apache.hadoop.mapred.StatusHttpServer
- Get the value in the webapp context.
- getAttribute(String) -
Method in class org.apache.hadoop.metrics.ContextFactory
- Returns the value of the named attribute, or null if there is no
attribute of that name.
- getAttribute(String) -
Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- Convenience method for subclasses to access factory attributes.
- getAttributeNames() -
Method in class org.apache.hadoop.metrics.ContextFactory
- Returns the names of all the factory's attributes.
- getAttributeTable(String) -
Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- Returns an attribute-value map derived from the factory attributes
by finding all factory attributes that begin with
contextName.tableName.
- getAvailable() -
Method in class org.apache.hadoop.fs.DF
-
- getBasePathInJarOut(String) -
Method in class org.apache.hadoop.streaming.JarBuilder
-
- getBaseRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
-
- getBaseRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.mapred.lib.MultipleSequenceFileOutputFormat
-
- getBaseRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.mapred.lib.MultipleTextOutputFormat
-
- getBeginColumn() -
Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
-
- getBeginLine() -
Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
-
- getBlockIndex(BlockLocation[], long) -
Method in class org.apache.hadoop.mapred.FileInputFormat
-
- getBlockInputStream(Block) -
Method in interface org.apache.hadoop.dfs.FSDatasetInterface
- Returns an input stream to read the contents of the specified block
- getBlockInputStream(Block, long) -
Method in interface org.apache.hadoop.dfs.FSDatasetInterface
- Returns an input stream at specified offset of the specified block
- getBlockLocations(String, long, long) -
Method in class org.apache.hadoop.dfs.NameNode
- Get locations of the blocks of the specified file within the specified range.
- getBlockMetaDataInfo(Block) -
Method in class org.apache.hadoop.dfs.DataNode
-
- getBlockReport() -
Method in interface org.apache.hadoop.dfs.FSDatasetInterface
- Returns the block report - the full list of blocks stored
- getBlockReportAverageTime() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getBlockReportAverageTime() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Average time for Block Report Processing in last interval
- getBlockReportMaxTime() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getBlockReportMaxTime() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- The Maximum Block Report Processing Time since reset was called
- getBlockReportMinTime() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getBlockReportMinTime() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- The Minimum Block Report Processing Time since reset was called
- getBlockReportNum() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getBlockReportNum() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Number of block Reports processed in the last interval
- getBlockReportsAverageTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getBlockReportsAverageTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Average time for Block Reports Operation in last interval
- getBlockReportsMaxTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getBlockReportsMaxTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Maximum Block Reports Operation Time since reset was called
- getBlockReportsMinTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getBlockReportsMinTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Minimum Block Reports Operation Time since reset was called
- getBlockReportsNum() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getBlockReportsNum() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of Block Reports sent in last interval
- getBlocks(DatanodeInfo, long) -
Method in class org.apache.hadoop.dfs.NameNode
- return a list of blocks & their locations on
datanode
whose
total size is size
- getBlocks() -
Method in class org.apache.hadoop.fs.s3.INode
-
- getBlockSize() -
Method in class org.apache.hadoop.fs.FileStatus
- Get the block size of the file.
- getBlockSize(Path) -
Method in class org.apache.hadoop.fs.FileSystem
- Deprecated. Use getFileStatus() instead
- getBlocksRead() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getBlocksRead() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of blocks read in the last interval
- getBlocksRemoved() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getBlocksRemoved() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of blocks removed in the last interval
- getBlocksReplicated() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getBlocksReplicated() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of blocks replicated in the last interval
- getBlocksScheduled() -
Method in class org.apache.hadoop.dfs.DatanodeDescriptor
-
- getBlocksTotal() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.FSNamesystemMBean
- Number of allocated blocks in the system
- getBlocksVerified() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getBlocksVerified() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of blocks verified in the last interval
- getBlocksWritten() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getBlocksWritten() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of blocks written in the last interval
- getBlockVerificationFailures() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getBlockVerificationFailures() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of block verification failures in the last interval
- getBoolean(String, boolean) -
Method in class org.apache.hadoop.conf.Configuration
- Get the value of the
name
property as a boolean
.
- getBoundAntProperty(String, String) -
Static method in class org.apache.hadoop.streaming.StreamUtil
-
- getBuildVersion() -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getBuildVersion() -
Static method in class org.apache.hadoop.util.VersionInfo
- Returns the buildVersion which includes version,
revision, user and date.
- getBytes() -
Method in class org.apache.hadoop.io.Text
- Returns the raw bytes; however, only data up to
Text.getLength()
is
valid.
- getBytes() -
Method in class org.apache.hadoop.io.UTF8
- Deprecated. The raw bytes.
- getBytes(String) -
Static method in class org.apache.hadoop.io.UTF8
- Deprecated. Convert a string to a UTF-8 encoded byte array.
- getBytesPerChecksum() -
Method in class org.apache.hadoop.dfs.DataChecksum
-
- getBytesPerSum() -
Method in class org.apache.hadoop.fs.ChecksumFileSystem
- Return the bytes Per Checksum
- getBytesRead() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getBytesRead() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of bytes read in the last interval
- getBytesRead() -
Method in class org.apache.hadoop.fs.FileSystem.Statistics
- Get the total number of bytes read
- getBytesRead() -
Method in interface org.apache.hadoop.io.compress.Compressor
- Return number of uncompressed bytes input so far.
- getBytesRead() -
Method in class org.apache.hadoop.io.compress.lzo.LzoCompressor
- Return number of bytes given to this compressor since last reset.
- getBytesRead() -
Method in class org.apache.hadoop.io.compress.zlib.ZlibCompressor
- Returns the total number of uncompressed bytes input so far.
- getBytesRead() -
Method in class org.apache.hadoop.io.compress.zlib.ZlibDecompressor
- Returns the total number of uncompressed bytes input so far.
- getBytesWritten() -
Method in class org.apache.hadoop.fs.FileSystem.Statistics
- Get the total number of bytes written
- getBytesWritten() -
Method in interface org.apache.hadoop.io.compress.Compressor
- Return number of compressed bytes output so far.
- getBytesWritten() -
Method in class org.apache.hadoop.io.compress.lzo.LzoCompressor
- Return number of bytes consumed by callers of compress since last reset.
- getBytesWritten() -
Method in class org.apache.hadoop.io.compress.zlib.ZlibCompressor
- Returns the total number of compressed bytes output so far.
- getBytesWritten() -
Method in class org.apache.hadoop.io.compress.zlib.ZlibDecompressor
- Returns the total number of compressed bytes output so far.
- getCacheArchives(Configuration) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- Get cache archives set in the Configuration
- getCacheFiles(Configuration) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- Get cache files set in the Configuration
- getCallQueueLen() -
Method in interface org.apache.hadoop.ipc.metrics.RpcMgtMBean
- The number of rpc calls in the queue.
- getCallQueueLen() -
Method in class org.apache.hadoop.ipc.Server
- The number of rpc calls in the queue.
- getCapacity() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.FSDatasetMBean
- Returns total capacity (in bytes) of storage (used and unused)
- getCapacity() -
Method in class org.apache.hadoop.dfs.DatanodeInfo
- The raw capacity.
- getCapacity() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem.DiskStatus
-
- getCapacity() -
Method in class org.apache.hadoop.fs.DF
-
- getCapacity() -
Method in class org.apache.hadoop.io.BytesWritable
- Get the capacity, which is the maximum size that could handled without
resizing the backing storage.
- getCapacity() -
Method in class org.apache.hadoop.record.Buffer
- Get the capacity, which is the maximum count that could handled without
resizing the backing storage.
- getCapacityRemaining() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.FSNamesystemMBean
- Free (unused) storage capacity
- getCapacityTotal() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.FSNamesystemMBean
- Total storage capacity
- getCapacityUsed() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.FSNamesystemMBean
- Used storage capacity
- getCategory(List<List<Pentomino.ColumnName>>) -
Method in class org.apache.hadoop.examples.dancing.Pentomino
- Find whether the solution has the x in the upper left quadrant, the
x-midline, the y-midline or in the center.
- getChannel() -
Method in class org.apache.hadoop.net.SocketInputStream
- Returns underlying channel used by inputstream.
- getChannel() -
Method in class org.apache.hadoop.net.SocketOutputStream
- Returns underlying channel used by this stream.
- getChannelPosition(Block, FSDatasetInterface.BlockWriteStreams) -
Method in interface org.apache.hadoop.dfs.FSDatasetInterface
- Returns the current offset in the data stream.
- getChecksumFile(Path) -
Method in class org.apache.hadoop.fs.ChecksumFileSystem
- Return the name of the checksum file associated with a file.
- getChecksumFileLength(Path, long) -
Method in class org.apache.hadoop.fs.ChecksumFileSystem
- Return the length of the checksum file given the size of the
actual file.
- getChecksumHeaderSize() -
Static method in class org.apache.hadoop.dfs.DataChecksum
-
- getChecksumLength(long, int) -
Static method in class org.apache.hadoop.fs.ChecksumFileSystem
- Calculated the length of the checksum file in bytes.
- getChecksumSize() -
Method in class org.apache.hadoop.dfs.DataChecksum
-
- getChecksumType() -
Method in class org.apache.hadoop.dfs.DataChecksum
-
- getChunkPosition(long) -
Method in class org.apache.hadoop.fs.FSInputChecker
- Return position of beginning of chunk containing pos.
- getClass(String, Class<?>) -
Method in class org.apache.hadoop.conf.Configuration
- Get the value of the
name
property as a Class
.
- getClass(String, Class<? extends U>, Class<U>) -
Method in class org.apache.hadoop.conf.Configuration
- Get the value of the
name
property as a Class
implementing the interface specified by xface
.
- getClass(byte) -
Method in class org.apache.hadoop.io.AbstractMapWritable
-
- getClass(String, Configuration) -
Static method in class org.apache.hadoop.io.WritableName
- Return the class for a name.
- getClass(T) -
Static method in class org.apache.hadoop.util.GenericsUtil
- Returns the Class object (of type
Class<T>
) of the
argument of type T
.
- getClass(T) -
Static method in class org.apache.hadoop.util.ReflectionUtils
- Return the correctly-typed
Class
of the given object.
- getClassByName(String) -
Method in class org.apache.hadoop.conf.Configuration
- Load a class by name.
- getClassByName(String) -
Static method in class org.apache.hadoop.contrib.utils.join.DataJoinJob
-
- getClassLoader() -
Method in class org.apache.hadoop.conf.Configuration
- Get the
ClassLoader
for this job.
- getClassName() -
Method in exception org.apache.hadoop.ipc.RemoteException
-
- getClientVersion() -
Method in exception org.apache.hadoop.ipc.RPC.VersionMismatch
- Get the client's preferred version
- getClosest(WritableComparable, Writable) -
Method in class org.apache.hadoop.io.MapFile.Reader
- Finds the record that is the closest match to the specified key.
- getClosest(WritableComparable, Writable, boolean) -
Method in class org.apache.hadoop.io.MapFile.Reader
- Finds the record that is the closest match to the specified key.
- getClusterNick() -
Method in class org.apache.hadoop.streaming.StreamJob
-
- getClusterStatus() -
Method in class org.apache.hadoop.mapred.JobClient
- Get status information about the Map-Reduce cluster.
- getClusterStatus() -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getCodec(Path) -
Method in class org.apache.hadoop.io.compress.CompressionCodecFactory
- Find the relevant compression codec for the given file based on its
filename suffix.
- getCodecClasses(Configuration) -
Static method in class org.apache.hadoop.io.compress.CompressionCodecFactory
- Get the list of codecs listed in the configuration
- getColumnName(int) -
Method in class org.apache.hadoop.examples.dancing.DancingLinks
- Get the name of a given column as a string
- getCombineOnceOnly() -
Method in class org.apache.hadoop.mapred.JobConf
- Deprecated.
- getCombinerClass() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the user-defined combiner class used to combine map-outputs
before being sent to the reducers.
- getCombinerOutput() -
Method in class org.apache.hadoop.mapred.lib.aggregate.DoubleValueSum
-
- getCombinerOutput() -
Method in class org.apache.hadoop.mapred.lib.aggregate.LongValueMax
-
- getCombinerOutput() -
Method in class org.apache.hadoop.mapred.lib.aggregate.LongValueMin
-
- getCombinerOutput() -
Method in class org.apache.hadoop.mapred.lib.aggregate.LongValueSum
-
- getCombinerOutput() -
Method in class org.apache.hadoop.mapred.lib.aggregate.StringValueMax
-
- getCombinerOutput() -
Method in class org.apache.hadoop.mapred.lib.aggregate.StringValueMin
-
- getCombinerOutput() -
Method in class org.apache.hadoop.mapred.lib.aggregate.UniqValueCount
-
- getCombinerOutput() -
Method in interface org.apache.hadoop.mapred.lib.aggregate.ValueAggregator
-
- getCombinerOutput() -
Method in class org.apache.hadoop.mapred.lib.aggregate.ValueHistogram
-
- getCommandLine() -
Method in class org.apache.hadoop.util.GenericOptionsParser
- Returns the commons-cli
CommandLine
object
to process the parsed arguments.
- getCommandLineConfig() -
Static method in class org.apache.hadoop.mapred.JobClient
- return the command line configuration
- getCommandName() -
Method in class org.apache.hadoop.fs.shell.Command
- Return the command's name excluding the leading character -
- getCommandName() -
Method in class org.apache.hadoop.fs.shell.Count
-
- getComparator() -
Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
- Return comparator defining the ordering for RecordReaders in this
composite.
- getCompressionCodec() -
Method in class org.apache.hadoop.io.SequenceFile.Reader
- Returns the compression codec of data in this file.
- getCompressionCodec() -
Method in class org.apache.hadoop.io.SequenceFile.Writer
- Returns the compression codec of data in this file.
- getCompressionType(Configuration) -
Static method in class org.apache.hadoop.io.SequenceFile
- Deprecated. Use
JobConf.getMapOutputCompressionType()
to get SequenceFile.CompressionType
for intermediate map-outputs or
SequenceFileOutputFormat.getOutputCompressionType(org.apache.hadoop.mapred.JobConf)
to get SequenceFile.CompressionType
for job-outputs.
- getCompressMapOutput() -
Method in class org.apache.hadoop.mapred.JobConf
- Are the outputs of the maps be compressed?
- getCompressor(CompressionCodec) -
Static method in class org.apache.hadoop.io.compress.CodecPool
- Get a
Compressor
for the given CompressionCodec
from the
pool or a new one.
- getCompressorType() -
Method in interface org.apache.hadoop.io.compress.CompressionCodec
- Get the type of
Compressor
needed by this CompressionCodec
.
- getCompressorType() -
Method in class org.apache.hadoop.io.compress.DefaultCodec
-
- getCompressorType() -
Method in class org.apache.hadoop.io.compress.GzipCodec
-
- getCompressorType() -
Method in class org.apache.hadoop.io.compress.LzoCodec
-
- getCompressOutput(JobConf) -
Static method in class org.apache.hadoop.mapred.FileOutputFormat
- Is the job output compressed?
- getCompressOutput(JobConf) -
Static method in class org.apache.hadoop.mapred.OutputFormatBase
- Deprecated. Is the job output compressed?
- getConf() -
Method in interface org.apache.hadoop.conf.Configurable
- Return the configuration used by this object.
- getConf() -
Method in class org.apache.hadoop.conf.Configured
-
- getConf() -
Method in class org.apache.hadoop.dfs.Balancer
- return this balancer's configuration
- getConf() -
Method in class org.apache.hadoop.fs.FilterFileSystem
-
- getConf() -
Method in class org.apache.hadoop.io.AbstractMapWritable
-
- getConf() -
Method in class org.apache.hadoop.io.compress.DefaultCodec
-
- getConf() -
Method in class org.apache.hadoop.io.compress.LzoCodec
-
- getConf() -
Method in class org.apache.hadoop.io.GenericWritable
-
- getConf() -
Method in class org.apache.hadoop.io.ObjectWritable
-
- getConf() -
Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
- Return the configuration used by this object.
- getConf() -
Method in class org.apache.hadoop.mapred.SequenceFileInputFilter.FilterBase
-
- getConf() -
Method in class org.apache.hadoop.net.ScriptBasedMapping
-
- getConf() -
Method in class org.apache.hadoop.net.SocksSocketFactory
-
- getConfiguration() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Get the underlying configuration object.
- getConfResourceAsInputStream(String) -
Method in class org.apache.hadoop.conf.Configuration
- Get an input stream attached to the configuration resource with the
given
name
.
- getConfResourceAsReader(String) -
Method in class org.apache.hadoop.conf.Configuration
- Get a
Reader
attached to the configuration resource with the
given name
.
- getConnectAddress(Server) -
Static method in class org.apache.hadoop.net.NetUtils
- Returns InetSocketAddress that a client can use to
connect to the server.
- getContentSummary(Path) -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
- Return the
ContentSummary
of a given Path
.
- getContentSummary(String) -
Method in class org.apache.hadoop.dfs.NameNode
- Get
ContentSummary
rooted at the specified directory.
- getContentSummary(Path) -
Method in class org.apache.hadoop.fs.FileSystem
- Return the
ContentSummary
of a given Path
.
- getContext(String) -
Method in class org.apache.hadoop.metrics.ContextFactory
- Returns the named MetricsContext instance, constructing it if necessary
using the factory's current configuration attributes.
- getContext(String) -
Static method in class org.apache.hadoop.metrics.MetricsUtil
- Utility method to return the named context.
- getContext() -
Method in class org.apache.hadoop.streaming.PipeMapRed
-
- getContextFactory() -
Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- Returns the factory by which this context was created.
- getContextName() -
Method in interface org.apache.hadoop.metrics.MetricsContext
- Returns the context name.
- getContextName() -
Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- Returns the context name.
- getCopyBlockOpAverageTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getCopyBlockOpAverageTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Average time for CopyBlock Operation in last interval
- getCopyBlockOpMaxTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getCopyBlockOpMaxTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Maximum CopyBlock Operation Time since reset was called
- getCopyBlockOpMinTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getCopyBlockOpMinTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Minimum CopyBlock Operation Time since reset was called
- getCopyBlockOpNum() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getCopyBlockOpNum() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of CopyBlock Operation in last interval
- getCorruptFiles() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return the number of currupted files.
- getCount() -
Method in class org.apache.hadoop.record.Buffer
- Get the current count of the buffer.
- getCounter() -
Method in class org.apache.hadoop.mapred.Counters.Counter
- What is the current value of this counter?
- getCounter(Enum) -
Method in class org.apache.hadoop.mapred.Counters
- Returns current value of the specified counter, or 0 if the counter
does not exist.
- getCounter(String) -
Method in class org.apache.hadoop.mapred.Counters.Group
- Returns the value of the specified counter, or 0 if the counter does
not exist.
- getCounter(int, String) -
Method in class org.apache.hadoop.mapred.Counters.Group
- Deprecated. use
Counters.Group.getCounter(String)
instead
- getCounterForName(String) -
Method in class org.apache.hadoop.mapred.Counters.Group
- Get the counter for the given name and create it if it doesn't exist.
- getCounters() -
Method in interface org.apache.hadoop.mapred.RunningJob
- Gets the counters for this job.
- getCounters() -
Method in class org.apache.hadoop.mapred.TaskReport
- A table of counters.
- getCurrentSegmentGeneration(Directory) -
Static method in class org.apache.hadoop.contrib.index.lucene.LuceneUtil
- Get the generation (N) of the current segments_N file in the directory.
- getCurrentSegmentGeneration(String[]) -
Static method in class org.apache.hadoop.contrib.index.lucene.LuceneUtil
- Get the generation (N) of the current segments_N file from a list of
files.
- getCurrentSplit(JobConf) -
Static method in class org.apache.hadoop.streaming.StreamUtil
-
- getCurrentTrashDir() -
Method in class org.apache.hadoop.fs.FsShell
- Returns the Trash object associated with this shell.
- getCurrentUGI() -
Static method in class org.apache.hadoop.security.UserGroupInformation
-
- getCurrentValue(Writable) -
Method in class org.apache.hadoop.io.SequenceFile.Reader
- Get the 'value' corresponding to the last read 'key'.
- getCurrentValue(Object) -
Method in class org.apache.hadoop.io.SequenceFile.Reader
- Get the 'value' corresponding to the last read 'key'.
- getCurrentValue(V) -
Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
-
- getData() -
Method in class org.apache.hadoop.contrib.utils.join.TaggedMapOutput
-
- getData() -
Method in class org.apache.hadoop.io.DataInputBuffer
-
- getData() -
Method in class org.apache.hadoop.io.DataOutputBuffer
- Returns the current contents of the buffer.
- getData() -
Method in class org.apache.hadoop.io.OutputBuffer
- Returns the current contents of the buffer.
- getDataNode() -
Static method in class org.apache.hadoop.dfs.DataNode
- Return the DataNode object
- getDatanodeReport() -
Method in class org.apache.hadoop.dfs.DatanodeInfo
- A formatted string for reporting the status of the DataNode.
- getDatanodeReport(FSConstants.DatanodeReportType) -
Method in class org.apache.hadoop.dfs.NameNode
-
- getDataNodeStats() -
Method in class org.apache.hadoop.dfs.ChecksumDistributedFileSystem
- Return statistics for each datanode.
- getDataNodeStats() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
- Return statistics for each datanode.
- getDate() -
Static method in class org.apache.hadoop.util.VersionInfo
- The date that Hadoop was compiled.
- getDeclaredClass() -
Method in class org.apache.hadoop.io.ObjectWritable
- Return the class this is meant to be.
- getDecompressor(CompressionCodec) -
Static method in class org.apache.hadoop.io.compress.CodecPool
- Get a
Decompressor
for the given CompressionCodec
from the
pool or a new one.
- getDecompressorType() -
Method in interface org.apache.hadoop.io.compress.CompressionCodec
- Get the type of
Decompressor
needed by this CompressionCodec
.
- getDecompressorType() -
Method in class org.apache.hadoop.io.compress.DefaultCodec
-
- getDecompressorType() -
Method in class org.apache.hadoop.io.compress.GzipCodec
-
- getDecompressorType() -
Method in class org.apache.hadoop.io.compress.LzoCodec
-
- getDefault() -
Static method in class org.apache.hadoop.fs.permission.FsPermission
- Get the default permission.
- getDefaultBlockSize() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
-
- getDefaultBlockSize() -
Method in class org.apache.hadoop.fs.FileSystem
- Return the number of bytes that large input files should be optimally
be split into to minimize i/o time.
- getDefaultBlockSize() -
Method in class org.apache.hadoop.fs.FilterFileSystem
- Return the number of bytes that large input files should be optimally
be split into to minimize i/o time.
- getDefaultBlockSize() -
Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
-
- getDefaultExtension() -
Method in interface org.apache.hadoop.io.compress.CompressionCodec
- Get the default filename extension for this kind of compression.
- getDefaultExtension() -
Method in class org.apache.hadoop.io.compress.DefaultCodec
-
- getDefaultExtension() -
Method in class org.apache.hadoop.io.compress.GzipCodec
-
- getDefaultExtension() -
Method in class org.apache.hadoop.io.compress.LzoCodec
- Get the default filename extension for this kind of compression.
- getDefaultHost(String, String) -
Static method in class org.apache.hadoop.net.DNS
- Returns the default (first) host name associated by the provided
nameserver with the address bound to the specified network interface
- getDefaultHost(String) -
Static method in class org.apache.hadoop.net.DNS
- Returns the default (first) host name associated by the default
nameserver with the address bound to the specified network interface
- getDefaultIP(String) -
Static method in class org.apache.hadoop.net.DNS
- Returns the first available IP address associated with the provided
network interface
- getDefaultMaps() -
Method in class org.apache.hadoop.mapred.JobClient
- Get status information about the max available Maps in the cluster.
- getDefaultReduces() -
Method in class org.apache.hadoop.mapred.JobClient
- Get status information about the max available Reduces in the cluster.
- getDefaultReplication() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
-
- getDefaultReplication() -
Method in class org.apache.hadoop.fs.FileSystem
- Get the default replication.
- getDefaultReplication() -
Method in class org.apache.hadoop.fs.FilterFileSystem
- Get the default replication.
- getDefaultReplication() -
Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
-
- getDefaultSocketFactory(Configuration) -
Static method in class org.apache.hadoop.net.NetUtils
- Get the default socket factory as specified by the configuration
parameter hadoop.rpc.socket.factory.default
- getDefaultUri(Configuration) -
Static method in class org.apache.hadoop.fs.FileSystem
- Get the default filesystem URI from a configuration.
- getDelegate() -
Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
- Obtain an iterator over the child RRs apropos of the value type
ultimately emitted from this join.
- getDelegate() -
Method in class org.apache.hadoop.mapred.join.JoinRecordReader
- Return an iterator wrapping the JoinCollector.
- getDelegate() -
Method in class org.apache.hadoop.mapred.join.MultiFilterRecordReader
- Return an iterator returning a single value from the tuple.
- getDependingJobs() -
Method in class org.apache.hadoop.mapred.jobcontrol.Job
-
- getDescription() -
Method in interface org.apache.hadoop.dfs.Upgradeable
- Description of the upgrade object for displaying.
- getDeserializer(Class<Serializable>) -
Method in class org.apache.hadoop.io.serializer.JavaSerialization
-
- getDeserializer(Class<T>) -
Method in interface org.apache.hadoop.io.serializer.Serialization
-
- getDeserializer(Class<T>) -
Method in class org.apache.hadoop.io.serializer.SerializationFactory
-
- getDeserializer(Class<Writable>) -
Method in class org.apache.hadoop.io.serializer.WritableSerialization
-
- getDfsUsed() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.FSDatasetMBean
- Returns the total space (in bytes) used by dfs datanode
- getDfsUsed() -
Method in class org.apache.hadoop.dfs.DatanodeInfo
- The used space by the data node.
- getDfsUsed() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem.DiskStatus
-
- getDiagnostics() -
Method in class org.apache.hadoop.mapred.TaskReport
- A list of error messages.
- getDigest() -
Method in class org.apache.hadoop.io.MD5Hash
- Returns the digest bytes.
- getDirectory() -
Method in class org.apache.hadoop.contrib.index.mapred.IntermediateForm
- Get the ram directory of the intermediate form.
- getDirectory() -
Method in class org.apache.hadoop.contrib.index.mapred.Shard
- Get the directory where this shard resides.
- getDirectoryCount() -
Method in class org.apache.hadoop.fs.ContentSummary
-
- getDirPath() -
Method in class org.apache.hadoop.fs.DF
-
- getDirPath() -
Method in class org.apache.hadoop.fs.DU
-
- getDiskStatus() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
- Return the disk usage of the filesystem, including total capacity,
used space, and remaining space
- getDisplayName() -
Method in class org.apache.hadoop.mapred.Counters.Counter
- Get the name of the counter.
- getDisplayName() -
Method in class org.apache.hadoop.mapred.Counters.Group
- Returns localized name of the group.
- getDistance(Node, Node) -
Method in class org.apache.hadoop.net.NetworkTopology
- Return the distance between two nodes
It is assumed that the distance from one node to its parent is 1
The distance between two nodes is calculated by summing up their distances
to their closest common ancestor.
- getDistributionPolicyClass() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Get the distribution policy class.
- getDocument() -
Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
- Get the document.
- getDocumentAnalyzerClass() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Get the analyzer class.
- getDoubleValue(Object) -
Method in class org.apache.hadoop.contrib.utils.join.JobBase
-
- getDU(File) -
Static method in class org.apache.hadoop.fs.FileUtil
- Takes an input dir and returns the du on that local directory.
- getEditLogSize() -
Method in class org.apache.hadoop.dfs.NameNode
- Returns the size of the current edit log.
- getElementTypeID() -
Method in class org.apache.hadoop.record.meta.VectorTypeID
-
- getEmptier() -
Method in class org.apache.hadoop.fs.Trash
- Return a
Runnable
that periodically empties the trash of all
users, intended to be run by the superuser.
- getEndColumn() -
Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
-
- getEndLine() -
Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
-
- getEntry(MapFile.Reader[], Partitioner<K, V>, K, V) -
Static method in class org.apache.hadoop.mapred.MapFileOutputFormat
- Get an entry from output generated by this class.
- getError() -
Static method in class org.apache.hadoop.metrics.jvm.EventCounter
-
- getEventId() -
Method in class org.apache.hadoop.mapred.TaskCompletionEvent
- Returns event Id.
- getExceptions() -
Method in exception org.apache.hadoop.io.MultipleIOException
-
- getExcessiveReplicas() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return the number of over-replicated blocks.
- getExcludedHosts() -
Method in class org.apache.hadoop.util.HostsFileReader
-
- getExecString() -
Method in class org.apache.hadoop.fs.DF
-
- getExecString() -
Method in class org.apache.hadoop.fs.DU
-
- getExecString() -
Method in class org.apache.hadoop.util.Shell
- return an array containing the command name & its parameters
- getExecString() -
Method in class org.apache.hadoop.util.Shell.ShellCommandExecutor
-
- getExecutable(JobConf) -
Static method in class org.apache.hadoop.mapred.pipes.Submitter
- Get the URI of the application's executable.
- getExitCode() -
Method in exception org.apache.hadoop.util.Shell.ExitCodeException
-
- getExitCode() -
Method in class org.apache.hadoop.util.Shell
- get the exit code
- getFactor() -
Method in class org.apache.hadoop.io.SequenceFile.Sorter
- Get the number of streams to merge at once.
- getFactory(Class) -
Static method in class org.apache.hadoop.io.WritableFactories
- Define a factory for a class.
- getFactory() -
Static method in class org.apache.hadoop.metrics.ContextFactory
- Returns the singleton ContextFactory instance, constructing it if
necessary.
- getFailedJobs() -
Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
-
- getFatal() -
Static method in class org.apache.hadoop.metrics.jvm.EventCounter
-
- getFieldID() -
Method in class org.apache.hadoop.record.meta.FieldTypeInfo
- get the field's id (name)
- getFieldTypeInfos() -
Method in class org.apache.hadoop.record.meta.RecordTypeInfo
- Return a collection of field type infos
- getFieldTypeInfos() -
Method in class org.apache.hadoop.record.meta.StructTypeID
-
- getFile(String, String) -
Method in class org.apache.hadoop.conf.Configuration
- Get a local file name under a directory named in dirsProp with
the given path.
- getFileBlockLocations(FileStatus, long, long) -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
-
- getFileBlockLocations(Path, long, long) -
Method in class org.apache.hadoop.fs.FileSystem
- Deprecated. use
FileSystem.getFileBlockLocations(FileStatus, long, long)
- getFileBlockLocations(FileStatus, long, long) -
Method in class org.apache.hadoop.fs.FileSystem
- Return an array containing hostnames, offset and size of
portions of the given file.
- getFileBlockLocations(Path, long, long) -
Method in class org.apache.hadoop.fs.FilterFileSystem
- Return an array containing hostnames, offset and size of
portions of the given file.
- getFileBlockLocations(FileStatus, long, long) -
Method in class org.apache.hadoop.fs.FilterFileSystem
-
- getFileBlockLocations(FileStatus, long, long) -
Method in class org.apache.hadoop.fs.HarFileSystem
- get block locations from the underlying fs
- getFileBlockLocations(FileStatus, long, long) -
Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
- Return null if the file doesn't exist; otherwise, get the
locations of the various chunks of the file file from KFS.
- getFileClassPaths(Configuration) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- Get the file entries in classpath as an array of Path
- getFileCount() -
Method in class org.apache.hadoop.fs.ContentSummary
-
- getFileInfo(String) -
Method in class org.apache.hadoop.dfs.NameNode
- Get the file info for a specific file.
- getFileLength() -
Method in class org.apache.hadoop.dfs.LocatedBlocks
-
- getFileName() -
Method in class org.apache.hadoop.metrics.file.FileContext
- Returns the configured file name, or null.
- getFiles(PathFilter) -
Method in class org.apache.hadoop.fs.InMemoryFileSystem
- Deprecated.
- getFileStatus(Path) -
Method in class org.apache.hadoop.dfs.ChecksumDistributedFileSystem
- Returns the stat information about the file.
- getFileStatus(Path) -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
- Returns the stat information about the file.
- getFileStatus(Path) -
Method in class org.apache.hadoop.dfs.HftpFileSystem
-
- getFileStatus(Path) -
Method in class org.apache.hadoop.fs.FileSystem
- Return a file status object that represents the path.
- getFileStatus(Path) -
Method in class org.apache.hadoop.fs.FilterFileSystem
- Get file status.
- getFileStatus(Path) -
Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
-
- getFileStatus(Path) -
Method in class org.apache.hadoop.fs.HarFileSystem
- return the filestatus of files in har archive.
- getFileStatus(Path) -
Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
-
- getFileStatus(Path) -
Method in class org.apache.hadoop.fs.RawLocalFileSystem
-
- getFileStatus(Path) -
Method in class org.apache.hadoop.fs.s3.S3FileSystem
- FileStatus for S3 file systems.
- getFileStatus(Path) -
Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
-
- getFilesTotal() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.FSNamesystemMBean
- Total number of files and directories
- getFilesystem() -
Method in class org.apache.hadoop.fs.DF
-
- getFileSystem(Configuration) -
Method in class org.apache.hadoop.fs.Path
- Return the FileSystem that owns this Path.
- getFilesystemName() -
Method in class org.apache.hadoop.mapred.JobTracker
- Grab the local fs name
- getFileTimestamps(Configuration) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- Get the timestamps of the files
- getFileType() -
Method in class org.apache.hadoop.fs.s3.INode
-
- getFinishTime() -
Method in class org.apache.hadoop.mapred.TaskReport
- Get finish time of task.
- getFlippable() -
Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
-
- getFloat(String, float) -
Method in class org.apache.hadoop.conf.Configuration
- Get the value of the
name
property as a float
.
- getFormattedTimeWithDiff(DateFormat, long, long) -
Static method in class org.apache.hadoop.util.StringUtils
- Formats time in ms and appends difference (finishTime - startTime)
as returned by formatTimeDiff().
- getFs() -
Method in class org.apache.hadoop.mapred.JobClient
- Get a filesystem handle.
- getFSDataset() -
Method in class org.apache.hadoop.dfs.DataNode
- This method is used for testing.
- getFSImageLoadTime() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getFSImageLoadTime() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Time spent loading the FS Image at startup
- getFsImageName() -
Method in class org.apache.hadoop.dfs.NameNode
- Returns the name of the fsImage file
- getFsImageNameCheckpoint() -
Method in class org.apache.hadoop.dfs.NameNode
- Returns the name of the fsImage file uploaded by periodic
checkpointing
- getFSSize() -
Method in class org.apache.hadoop.fs.InMemoryFileSystem
- Deprecated.
- getFSState() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.FSNamesystemMBean
- The state of the file system: Safemode or Operational
- getGeneration() -
Method in class org.apache.hadoop.contrib.index.mapred.Shard
- Get the generation of the Lucene instance.
- getGET_PERMISSION_COMMAND() -
Static method in class org.apache.hadoop.util.Shell
- Return a Unix command to get permission information.
- getGroup() -
Method in class org.apache.hadoop.fs.FileStatus
- Get the group associated with the file.
- getGroup(String) -
Method in class org.apache.hadoop.mapred.Counters
- Returns the named counter group, or an empty group if there is none
with the specified name.
- getGroupAction() -
Method in class org.apache.hadoop.fs.permission.FsPermission
- Return group
FsAction
.
- getGroupName() -
Method in class org.apache.hadoop.fs.permission.PermissionStatus
- Return group name
- getGroupNames() -
Method in class org.apache.hadoop.mapred.Counters
- Returns the names of all counter classes.
- getGroupNames() -
Method in class org.apache.hadoop.security.UnixUserGroupInformation
- Return an array of group names
- getGroupNames() -
Method in class org.apache.hadoop.security.UserGroupInformation
- Get the name of the groups that the user belong to
- getGROUPS_COMMAND() -
Static method in class org.apache.hadoop.util.Shell
- a Unix command to get the current user's groups list
- getHadoopClientHome() -
Method in class org.apache.hadoop.streaming.StreamJob
-
- getHarHash(Path) -
Static method in class org.apache.hadoop.fs.HarFileSystem
- the hash of the path p inside iniside
the filesystem
- getHarVersion() -
Method in class org.apache.hadoop.fs.HarFileSystem
-
- getHeader() -
Method in class org.apache.hadoop.dfs.DataChecksum
-
- getHeader(boolean) -
Static method in class org.apache.hadoop.fs.ContentSummary
- Return the header of the output.
- getHeartbeatsAverageTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getHeartbeatsAverageTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Average time for Heartbeat Operation in last interval
- getHeartbeatsMaxTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getHeartbeatsMaxTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Maximum Heartbeat Operation Time since reset was called
- getHeartbeatsMinTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getHeartbeatsMinTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Minimum Heartbeat Operation Time since reset was called
- getHeartbeatsNum() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getHeartbeatsNum() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of Heartbeat Operation in last interval
- getHomeDirectory() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
- Return the current user's home directory in this filesystem.
- getHomeDirectory() -
Method in class org.apache.hadoop.fs.FileSystem
- Return the current user's home directory in this filesystem.
- getHomeDirectory() -
Method in class org.apache.hadoop.fs.FilterFileSystem
-
- getHomeDirectory() -
Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
-
- getHomeDirectory() -
Method in class org.apache.hadoop.fs.HarFileSystem
- return the top level archive path.
- getHomeDirectory() -
Method in class org.apache.hadoop.fs.RawLocalFileSystem
-
- getHost() -
Method in class org.apache.hadoop.dfs.DatanodeID
-
- getHost() -
Method in class org.apache.hadoop.streaming.Environment
-
- getHostName() -
Method in class org.apache.hadoop.dfs.DatanodeInfo
-
- getHostname() -
Static method in class org.apache.hadoop.util.StringUtils
- Return hostname without throwing exception.
- getHosts() -
Method in class org.apache.hadoop.fs.BlockLocation
- Get the list of hosts (hostname) hosting this block
- getHosts(String, String) -
Static method in class org.apache.hadoop.net.DNS
- Returns all the host names associated by the provided nameserver with the
address bound to the specified network interface
- getHosts(String) -
Static method in class org.apache.hadoop.net.DNS
- Returns all the host names associated by the default nameserver with the
address bound to the specified network interface
- getHosts() -
Method in class org.apache.hadoop.util.HostsFileReader
-
- getId() -
Method in class org.apache.hadoop.fs.s3.Block
-
- getId(Class) -
Method in class org.apache.hadoop.io.AbstractMapWritable
-
- getId() -
Method in class org.apache.hadoop.mapred.ID
- returns the int which represents the identifier
- getID() -
Method in interface org.apache.hadoop.mapred.RunningJob
- Get the job identifier.
- GetImage() -
Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
-
- GetImageServlet - Class in org.apache.hadoop.dfs
- This class is used in Namesystem's jetty to retrieve a file.
- GetImageServlet() -
Constructor for class org.apache.hadoop.dfs.GetImageServlet
-
- getIndexInputFormatClass() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Get the index input format class.
- getIndexInterval() -
Method in class org.apache.hadoop.io.MapFile.Writer
- The number of entries that are added before an index entry is added.
- getIndexMaxFieldLength() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Get the max field length for a Lucene instance.
- getIndexMaxNumSegments() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Get the max number of segments for a Lucene instance.
- getIndexShards() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Get the string representation of a number of shards.
- getIndexShards(IndexUpdateConfiguration) -
Static method in class org.apache.hadoop.contrib.index.mapred.Shard
-
- getIndexUpdaterClass() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Get the index updater class.
- getIndexUseCompoundFile() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Check whether to use the compound file format for a Lucene instance.
- getInfo() -
Static method in class org.apache.hadoop.metrics.jvm.EventCounter
-
- getInfoPort() -
Method in class org.apache.hadoop.dfs.DatanodeID
-
- getInfoPort() -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getInodeLimitText() -
Method in class org.apache.hadoop.dfs.JspHelper
-
- getInputFileBasedOutputFileName(JobConf, String) -
Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
- Generate the outfile name based on a given anme and the input file name.
- getInputFormat() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the
InputFormat
implementation for the map-reduce job,
defaults to TextInputFormat
if not specified explicity.
- getInputPathFilter(JobConf) -
Static method in class org.apache.hadoop.mapred.FileInputFormat
- Get a PathFilter instance of the filter set for the input paths.
- getInputPaths(JobConf) -
Static method in class org.apache.hadoop.mapred.FileInputFormat
- Get the list of input
Path
s for the map-reduce job.
- getInputPaths() -
Method in class org.apache.hadoop.mapred.JobConf
- Deprecated. Use
FileInputFormat.getInputPaths(JobConf)
- getInputSplit() -
Method in interface org.apache.hadoop.mapred.Reporter
- Get the
InputSplit
object for a map.
- getInputStream(Socket) -
Static method in class org.apache.hadoop.net.NetUtils
- Same as getInputStream(socket, socket.getSoTimeout()).
From documentation for NetUtils.getInputStream(Socket, long)
:
Returns InputStream for the socket.
- getInputStream(Socket, long) -
Static method in class org.apache.hadoop.net.NetUtils
- Returns InputStream for the socket.
- getInt(String, int) -
Method in class org.apache.hadoop.conf.Configuration
- Get the value of the
name
property as an int
.
- getInterfaceName() -
Method in exception org.apache.hadoop.ipc.RPC.VersionMismatch
- Get the interface name
- getIOSortMB() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Get the IO sort space in MB.
- getIpcPort() -
Method in class org.apache.hadoop.dfs.DatanodeID
-
- getIPs(String) -
Static method in class org.apache.hadoop.net.DNS
- Returns all the IPs associated with the provided interface, if any, in
textual form.
- getIsJavaMapper(JobConf) -
Static method in class org.apache.hadoop.mapred.pipes.Submitter
- Check whether the job is using a Java Mapper.
- getIsJavaRecordReader(JobConf) -
Static method in class org.apache.hadoop.mapred.pipes.Submitter
- Check whether the job is using a Java RecordReader
- getIsJavaRecordWriter(JobConf) -
Static method in class org.apache.hadoop.mapred.pipes.Submitter
- Will the reduce use a Java RecordWriter?
- getIsJavaReducer(JobConf) -
Static method in class org.apache.hadoop.mapred.pipes.Submitter
- Check whether the job is using a Java Reducer.
- getJar() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the user jar for the map-reduce job.
- getJob(JobID) -
Method in class org.apache.hadoop.mapred.JobClient
- Get an
RunningJob
object to track an ongoing job.
- getJob(String) -
Method in class org.apache.hadoop.mapred.JobClient
- Deprecated. Applications should rather use
JobClient.getJob(JobID)
.
- getJob(String) -
Method in class org.apache.hadoop.mapred.JobTracker
- Deprecated.
- getJob(JobID) -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getJobClient() -
Method in class org.apache.hadoop.mapred.TaskTracker
- The connection to the JobTracker, used by the TaskRunner
for locating remote files.
- getJobConf() -
Method in class org.apache.hadoop.mapred.jobcontrol.Job
-
- getJobCounters(String) -
Method in class org.apache.hadoop.mapred.JobTracker
- Deprecated.
- getJobCounters(JobID) -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getJobEndNotificationURI() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the uri to be invoked in-order to send a notification after the job
has completed (success/failure).
- getJobFile() -
Method in class org.apache.hadoop.mapred.JobProfile
- Get the configuration file for the job.
- getJobFile() -
Method in interface org.apache.hadoop.mapred.RunningJob
- Get the path of the submitted job configuration.
- getJobID() -
Method in class org.apache.hadoop.mapred.jobcontrol.Job
-
- getJobID() -
Method in class org.apache.hadoop.mapred.JobProfile
- Get the job id.
- getJobId() -
Method in class org.apache.hadoop.mapred.JobProfile
- Deprecated. use getJobID() instead
- getJobId() -
Method in class org.apache.hadoop.mapred.JobStatus
- Deprecated. use getJobID instead
- getJobID() -
Method in class org.apache.hadoop.mapred.JobStatus
-
- getJobID() -
Method in interface org.apache.hadoop.mapred.RunningJob
- Deprecated. This method is deprecated and will be removed. Applications should
rather use
RunningJob.getID()
.
- getJobID() -
Method in class org.apache.hadoop.mapred.TaskAttemptID
- Returns the
JobID
object that this task attempt belongs to
- getJobID() -
Method in class org.apache.hadoop.mapred.TaskID
- Returns the
JobID
object that this tip belongs to
- getJobIDsPattern(String, Integer) -
Static method in class org.apache.hadoop.mapred.JobID
- Returns a regex pattern which matches task IDs.
- getJobLocalDir() -
Method in class org.apache.hadoop.mapred.JobConf
- Get job-specific shared directory for use as scratch space
- getJobName() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the user-specified job name.
- getJobName() -
Method in class org.apache.hadoop.mapred.jobcontrol.Job
-
- getJobName() -
Method in class org.apache.hadoop.mapred.JobProfile
- Get the user-specified job name.
- getJobName() -
Method in interface org.apache.hadoop.mapred.RunningJob
- Get the name of the job.
- getJobPriority() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the
JobPriority
for this job.
- getJobProfile(String) -
Method in class org.apache.hadoop.mapred.JobTracker
- Deprecated.
- getJobProfile(JobID) -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getJobStatus(String) -
Method in class org.apache.hadoop.mapred.JobTracker
- Deprecated.
- getJobStatus(JobID) -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getJobTrackerHostPort() -
Method in class org.apache.hadoop.streaming.StreamJob
-
- getJobTrackerMachine() -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getJobTrackerState() -
Method in class org.apache.hadoop.mapred.ClusterStatus
- Get the current state of the
JobTracker
,
as JobTracker.State
- getJournalSyncAverageTime() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getJournalSyncAverageTime() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Average time for Journal Sync in last interval
- getJournalSyncMaxTime() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getJournalSyncMaxTime() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- The Maximum Journal Sync Time since reset was called
- getJournalSyncMinTime() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getJournalSyncMinTime() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- The Minimum Journal Sync Time since reset was called
- getJournalSyncNum() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getJournalSyncNum() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Number of Journal Syncs in the last interval
- getJournalTransactionAverageTime() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getJournalTransactionAverageTime() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Average time for Journal transactions in last interval
- getJournalTransactionMaxTime() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getJournalTransactionMaxTime() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- The Maximum Journal Transaction Time since reset was called
- getJournalTransactionMinTime() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getJournalTransactionMinTime() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- The Minimum Journal Transaction Time since reset was called
- getJournalTransactionNum() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getJournalTransactionNum() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Number of Journal Transactions in the last interval
- getJtIdentifier() -
Method in class org.apache.hadoop.mapred.JobID
-
- getKeepCommandFile(JobConf) -
Static method in class org.apache.hadoop.mapred.pipes.Submitter
- Does the user want to keep the command file for debugging? If this is
true, pipes will write a copy of the command data to a file in the
task directory named "downlink.data", which may be used to run the C++
program under the debugger.
- getKeepFailedTaskFiles() -
Method in class org.apache.hadoop.mapred.JobConf
- Should the temporary files for failed tasks be kept?
- getKeepTaskFilesPattern() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the regular expression that is matched against the task names
to see if we need to keep the files.
- getKey() -
Method in interface org.apache.hadoop.io.SequenceFile.Sorter.RawKeyValueIterator
- Gets the current raw key
- getKey() -
Method in class org.apache.hadoop.io.SequenceFile.Sorter.SegmentDescriptor
- Returns the stored rawKey
- getKeyClass() -
Method in class org.apache.hadoop.io.MapFile.Reader
- Returns the class of keys in this file.
- getKeyClass() -
Method in class org.apache.hadoop.io.SequenceFile.Reader
- Returns the class of keys in this file.
- getKeyClass() -
Method in class org.apache.hadoop.io.SequenceFile.Writer
- Returns the class of keys in this file.
- getKeyClass() -
Method in class org.apache.hadoop.io.WritableComparator
- Returns the WritableComparable implementation class.
- getKeyClass() -
Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
-
- getKeyClass() -
Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
- The class of key that must be passed to
SequenceFileRecordReader.next(Object, Object)
..
- getKeyClassName() -
Method in class org.apache.hadoop.io.SequenceFile.Reader
- Returns the name of the key class.
- getKeyClassName() -
Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
- Retrieve the name of the key class for this SequenceFile.
- getKeyTypeID() -
Method in class org.apache.hadoop.record.meta.MapTypeID
- get the TypeID of the map's key element
- getLastUpdate() -
Method in class org.apache.hadoop.dfs.DatanodeInfo
- The time when this information was accurate.
- getLen() -
Method in class org.apache.hadoop.fs.FileStatus
-
- getLength(Block) -
Method in interface org.apache.hadoop.dfs.FSDatasetInterface
- Returns the specified block's on-disk length (excluding metadata)
- getLength() -
Method in class org.apache.hadoop.dfs.FSDatasetInterface.MetaDataInputStream
-
- getLength() -
Method in class org.apache.hadoop.fs.BlockLocation
- Get the length of the block
- getLength() -
Method in class org.apache.hadoop.fs.ContentSummary
-
- getLength(Path) -
Method in class org.apache.hadoop.fs.FileSystem
- Deprecated. Use getFileStatus() instead
- getLength(Path) -
Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
- Deprecated.
- getLength() -
Method in class org.apache.hadoop.fs.s3.Block
-
- getLength() -
Method in class org.apache.hadoop.io.DataInputBuffer
- Returns the length of the input.
- getLength() -
Method in class org.apache.hadoop.io.DataOutputBuffer
- Returns the length of the valid data currently in the buffer.
- getLength() -
Method in class org.apache.hadoop.io.InputBuffer
- Returns the length of the input.
- getLength() -
Method in class org.apache.hadoop.io.OutputBuffer
- Returns the length of the valid data currently in the buffer.
- getLength() -
Method in class org.apache.hadoop.io.SequenceFile.Writer
- Returns the current length of the output file.
- getLength() -
Method in class org.apache.hadoop.io.Text
- Returns the number of bytes in the byte array
- getLength() -
Method in class org.apache.hadoop.io.UTF8
- Deprecated. The number of bytes in the encoded string.
- getLength() -
Method in class org.apache.hadoop.mapred.FileSplit
- The number of bytes in the file to process.
- getLength() -
Method in interface org.apache.hadoop.mapred.InputSplit
- Get the total number of bytes in the data of the
InputSplit
.
- getLength() -
Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
- Return the aggregate length of all child InputSplits currently added.
- getLength(int) -
Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
- Get the length of ith child InputSplit.
- getLength() -
Method in class org.apache.hadoop.mapred.MultiFileSplit
-
- getLength(int) -
Method in class org.apache.hadoop.mapred.MultiFileSplit
- Returns the length of the ith Path
- getLengths() -
Method in class org.apache.hadoop.mapred.MultiFileSplit
- Returns an array containing the lengths of the files in
the split
- getLevel() -
Method in class org.apache.hadoop.dfs.DatanodeInfo
- Return this node's level in the tree.
- getLevel() -
Method in interface org.apache.hadoop.net.Node
- Return this node's level in the tree.
- getLevel() -
Method in class org.apache.hadoop.net.NodeBase
- Return this node's level in the tree.
- getLinkCount(File) -
Static method in class org.apache.hadoop.fs.FileUtil.HardLink
- Retrieves the number of links to the specified file.
- getListenerAddress() -
Method in class org.apache.hadoop.ipc.Server
- Return the socket (ip+port) on which the RPC server is listening to.
- getListing(String) -
Method in class org.apache.hadoop.dfs.NameNode
-
- getLoadNativeLibraries(JobConf) -
Method in class org.apache.hadoop.util.NativeCodeLoader
- Return if native hadoop libraries, if present, can be used for this job.
- getLocal(Configuration) -
Static method in class org.apache.hadoop.fs.FileSystem
- Get the local file syste
- getLocalAnalysisClass() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Get the local analysis class.
- getLocalCache(URI, Configuration, Path, FileStatus, boolean, long, Path) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- Get the locally cached file or archive; it could either be
previously cached (and valid) or copy it from the
FileSystem
now.
- getLocalCache(URI, Configuration, Path, boolean, long, Path) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- Get the locally cached file or archive; it could either be
previously cached (and valid) or copy it from the
FileSystem
now.
- getLocalCacheArchives(Configuration) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- Return the path array of the localized caches
- getLocalCacheFiles(Configuration) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- Return the path array of the localized files
- getLocalDirs() -
Method in class org.apache.hadoop.mapred.JobConf
-
- getLocalJobFilePath(String) -
Static method in class org.apache.hadoop.mapred.JobHistory.JobInfo
- Deprecated.
- getLocalJobFilePath(JobID) -
Static method in class org.apache.hadoop.mapred.JobHistory.JobInfo
- Get the path of the locally stored job file
- getLocalJobFilePath(String) -
Method in class org.apache.hadoop.mapred.JobTracker
- Deprecated.
- getLocalJobFilePath(JobID) -
Static method in class org.apache.hadoop.mapred.JobTracker
- Get the localized job file path on the job trackers local file system
- getLocalPath(String, String) -
Method in class org.apache.hadoop.conf.Configuration
- Get a local file under a directory named by dirsProp with
the given path.
- getLocalPath(String) -
Method in class org.apache.hadoop.mapred.JobConf
- Constructs a local file name.
- getLocalPathForWrite(String, Configuration) -
Method in class org.apache.hadoop.fs.LocalDirAllocator
- Get a path from the local FS.
- getLocalPathForWrite(String, long, Configuration) -
Method in class org.apache.hadoop.fs.LocalDirAllocator
- Get a path from the local FS.
- getLocalPathToRead(String, Configuration) -
Method in class org.apache.hadoop.fs.LocalDirAllocator
- Get a path from the local FS for reading.
- getLocatedBlocks() -
Method in class org.apache.hadoop.dfs.LocatedBlocks
- Get located blocks.
- getLocation(int) -
Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
- getLocations from ith InputSplit.
- getLocations() -
Method in class org.apache.hadoop.mapred.FileSplit
-
- getLocations() -
Method in interface org.apache.hadoop.mapred.InputSplit
- Get the list of hostnames where the input split is located.
- getLocations() -
Method in class org.apache.hadoop.mapred.join.CompositeInputSplit
- Collect a set of hosts from all child InputSplits.
- getLocations() -
Method in class org.apache.hadoop.mapred.MultiFileSplit
-
- getLong(String, long) -
Method in class org.apache.hadoop.conf.Configuration
- Get the value of the
name
property as a long
.
- getLongValue(Object) -
Method in class org.apache.hadoop.contrib.utils.join.JobBase
-
- getMapCompletionEvents(String, int, int) -
Method in class org.apache.hadoop.mapred.TaskTracker
- Deprecated.
- getMapCompletionEvents(JobID, int, int) -
Method in class org.apache.hadoop.mapred.TaskTracker
-
- getMapDebugScript() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the map task's debug script.
- getMapOutputCompressionType() -
Method in class org.apache.hadoop.mapred.JobConf
- Deprecated.
SequenceFile.CompressionType
is no longer valid for intermediate
map-outputs.
- getMapOutputCompressorClass(Class<? extends CompressionCodec>) -
Method in class org.apache.hadoop.mapred.JobConf
- Get the
CompressionCodec
for compressing the map outputs.
- getMapOutputKeyClass() -
Static method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateMapper
- Get the map output key class.
- getMapOutputKeyClass() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the key class for the map output data.
- getMapOutputValueClass() -
Static method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateMapper
- Get the map output value class.
- getMapOutputValueClass() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the value class for the map output data.
- getMapperClass() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the
Mapper
class for the job.
- getMapredJobID() -
Method in class org.apache.hadoop.mapred.jobcontrol.Job
- Deprecated. use
Job.getAssignedJobID()
instead
- getMapredTempDir() -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateConfiguration
- Get the Map/Reduce temp directory.
- getMapRunnerClass() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the
MapRunnable
class for the job.
- getMapSpeculativeExecution() -
Method in class org.apache.hadoop.mapred.JobConf
- Should speculative execution be used for this job for map tasks?
Defaults to
true
.
- getMapTaskReports(JobID) -
Method in class org.apache.hadoop.mapred.JobClient
- Get the information of the current state of the map tasks of a job.
- getMapTaskReports(String) -
Method in class org.apache.hadoop.mapred.JobClient
- Deprecated. Applications should rather use
JobClient.getMapTaskReports(JobID)
- getMapTaskReports(String) -
Method in class org.apache.hadoop.mapred.JobTracker
- Deprecated.
- getMapTaskReports(JobID) -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getMapTasks() -
Method in class org.apache.hadoop.mapred.ClusterStatus
- Get the number of currently running map tasks in the cluster.
- getMaxDepth(int) -
Static method in class org.apache.hadoop.util.QuickSort
- Deepest recursion before giving up and doing a heapsort.
- getMaxMapAttempts() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the configured number of maximum attempts that will be made to run a
map task, as specified by the
mapred.map.max.attempts
property.
- getMaxMapTaskFailuresPercent() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the maximum percentage of map tasks that can fail without
the job being aborted.
- getMaxMapTasks() -
Method in class org.apache.hadoop.mapred.ClusterStatus
- Get the maximum capacity for running map tasks in the cluster.
- getMaxReduceAttempts() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the configured number of maximum attempts that will be made to run a
reduce task, as specified by the
mapred.reduce.max.attempts
property.
- getMaxReduceTaskFailuresPercent() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the maximum percentage of reduce tasks that can fail without
the job being aborted.
- getMaxReduceTasks() -
Method in class org.apache.hadoop.mapred.ClusterStatus
- Get the maximum capacity for running reduce tasks in the cluster.
- getMaxTaskFailuresPerTracker() -
Method in class org.apache.hadoop.mapred.JobConf
- Expert: Get the maximum no.
- getMaxTime() -
Method in class org.apache.hadoop.metrics.util.MetricsTimeVaryingRate
- The max time for a single operation since the last reset
MetricsTimeVaryingRate.resetMinMax()
- getMemory() -
Method in class org.apache.hadoop.io.SequenceFile.Sorter
- Get the total amount of buffer memory, in bytes.
- getMessage() -
Method in exception org.apache.hadoop.dfs.QuotaExceededException
-
- getMessage() -
Method in exception org.apache.hadoop.mapred.InvalidInputException
- Get a summary message of the problems found.
- getMessage() -
Method in class org.apache.hadoop.mapred.jobcontrol.Job
-
- getMessage() -
Method in exception org.apache.hadoop.record.compiler.generated.ParseException
- This method has the standard behavior when this object has been
created using the standard constructors.
- getMessage() -
Method in error org.apache.hadoop.record.compiler.generated.TokenMgrError
- You can also modify the body of this method to customize your error messages.
- getMetadata() -
Method in class org.apache.hadoop.io.SequenceFile.Metadata
-
- getMetadata() -
Method in class org.apache.hadoop.io.SequenceFile.Reader
- Returns the metadata object of the file
- getMetaDataInputStream(Block) -
Method in interface org.apache.hadoop.dfs.FSDatasetInterface
- Returns metaData of block b as an input stream (and its length)
- getMetaDataLength(Block) -
Method in interface org.apache.hadoop.dfs.FSDatasetInterface
- Returns the length of the metadata file of the specified block
- getMetric(String) -
Method in class org.apache.hadoop.metrics.spi.OutputRecord
- Returns the metric object which can be a Float, Integer, Short or Byte.
- getMetricNames() -
Method in class org.apache.hadoop.metrics.spi.OutputRecord
- Returns the set of metric names.
- getMinTime() -
Method in class org.apache.hadoop.metrics.util.MetricsTimeVaryingRate
- The min time for a single operation since the last reset
MetricsTimeVaryingRate.resetMinMax()
- getMissingIds() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return a list of missing block names (as list of Strings).
- getMissingReplicas() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return the number of under-replicated blocks.
- getMissingSize() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return total size of missing data, in bytes.
- getModificationTime() -
Method in class org.apache.hadoop.fs.FileStatus
- Get the modification time of the file.
- getMount() -
Method in class org.apache.hadoop.fs.DF
-
- getName() -
Method in class org.apache.hadoop.dfs.DatanodeID
-
- getName() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
- Deprecated.
- getName() -
Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
-
- getName() -
Method in class org.apache.hadoop.fs.FileSystem
- Deprecated. call #getUri() instead.
- getName() -
Method in class org.apache.hadoop.fs.FilterFileSystem
- Deprecated. call #getUri() instead.
- getName() -
Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
- Deprecated.
- getName() -
Method in class org.apache.hadoop.fs.Path
- Returns the final component of this path.
- getName() -
Method in class org.apache.hadoop.fs.RawLocalFileSystem
- Deprecated.
- getName() -
Method in class org.apache.hadoop.fs.s3.S3FileSystem
-
- getName(Class) -
Static method in class org.apache.hadoop.io.WritableName
- Return the name for a class.
- getName() -
Method in class org.apache.hadoop.mapred.Counters.Counter
- Get the internal name of the counter.
- getName() -
Method in class org.apache.hadoop.mapred.Counters.Group
- Returns raw name of the group.
- getName() -
Method in interface org.apache.hadoop.net.Node
- Return this node's name
- getName() -
Method in class org.apache.hadoop.net.NodeBase
- Return this node's name
- getName() -
Method in class org.apache.hadoop.record.meta.RecordTypeInfo
- return the name of the record
- getNamed(String, Configuration) -
Static method in class org.apache.hadoop.fs.FileSystem
- Deprecated. call #get(URI,Configuration) instead.
- getNamenode() -
Method in class org.apache.hadoop.dfs.DataNode
- Return the namenode's identifier
- getNameNodeAddr() -
Method in class org.apache.hadoop.dfs.DataNode
-
- getNameNodeAddress() -
Method in class org.apache.hadoop.dfs.NameNode
- Returns the address on which the NameNodes is listening to.
- getNameNodeMetrics() -
Static method in class org.apache.hadoop.dfs.NameNode
-
- getNames() -
Method in class org.apache.hadoop.fs.BlockLocation
- Get the list of names (hostname:port) hosting this block
- getNestedStructTypeInfo(String) -
Method in class org.apache.hadoop.record.meta.RecordTypeInfo
- Return the type info of a nested record.
- getNetworkLocation() -
Method in class org.apache.hadoop.dfs.DatanodeInfo
- rack name
- getNetworkLocation() -
Method in interface org.apache.hadoop.net.Node
- Return the string representation of this node's network location
- getNetworkLocation() -
Method in class org.apache.hadoop.net.NodeBase
- Return this node's network location
- getNewJobId() -
Method in class org.apache.hadoop.mapred.JobTracker
- Allocates a new JobId string.
- getNextToken() -
Method in class org.apache.hadoop.record.compiler.generated.Rcc
-
- getNextToken() -
Method in class org.apache.hadoop.record.compiler.generated.RccTokenManager
-
- getNode(String) -
Method in class org.apache.hadoop.mapred.JobTracker
- Return the Node in the network topology that corresponds to the hostname
- getNode() -
Method in class org.apache.hadoop.mapred.join.Parser.NodeToken
-
- getNode() -
Method in class org.apache.hadoop.mapred.join.Parser.Token
-
- getNode(String) -
Method in class org.apache.hadoop.net.NetworkTopology
- Given a string representation of a node, return its reference
- getNodesAtMaxLevel() -
Method in class org.apache.hadoop.mapred.JobTracker
- Returns a collection of nodes at the max level
- getNullContext(String) -
Static method in class org.apache.hadoop.metrics.ContextFactory
- Returns a "null" context - one which does nothing.
- getNum() -
Method in class org.apache.hadoop.mapred.join.Parser.NumToken
-
- getNum() -
Method in class org.apache.hadoop.mapred.join.Parser.Token
-
- getNumAddBlockOps() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getNumAddBlockOps() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Number of add block operations in the last interval
- getNumber() -
Method in class org.apache.hadoop.metrics.spi.MetricValue
-
- getNumberColumns() -
Method in class org.apache.hadoop.examples.dancing.DancingLinks
- Get the number of columns.
- getNumBytesInSum() -
Method in class org.apache.hadoop.dfs.DataChecksum
-
- getNumCreateFileOps() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getNumCreateFileOps() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Number of file creation operations in the last interval
- getNumDeleteFileOps() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getNumDeleteFileOps() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Number of file deletion operations in the last interval
- getNumFiles(PathFilter) -
Method in class org.apache.hadoop.fs.InMemoryFileSystem
- Deprecated.
- getNumFilesCreated() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getNumFilesCreated() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Number of files created in the last interval
- getNumFilesListed() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
- Deprecated. call getNumGetListingOps() instead
- getNumFilesListed() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Deprecated. Use getNumGetListingOps() instead
- getNumFilesRenamed() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getNumFilesRenamed() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Number of files renamed in the last interval
- getNumGetBlockLocations() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getNumGetBlockLocations() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Number of
NameNode.getBlockLocations(String,long,long)
- getNumGetListingOps() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getNumGetListingOps() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- Number of files listed in the last interval
- getNumMapTasks() -
Method in class org.apache.hadoop.mapred.JobConf
- Get configured the number of reduce tasks for this job.
- getNumOfLeaves() -
Method in class org.apache.hadoop.net.NetworkTopology
- Return the total number of nodes
- getNumOfRacks() -
Method in class org.apache.hadoop.net.NetworkTopology
- Return the total number of racks
- getNumOpenConnections() -
Method in interface org.apache.hadoop.ipc.metrics.RpcMgtMBean
- The number of open RPC conections
- getNumOpenConnections() -
Method in class org.apache.hadoop.ipc.Server
- The number of open RPC conections
- getNumPaths() -
Method in class org.apache.hadoop.mapred.MultiFileSplit
- Returns the number of Paths in the split
- getNumReduceTasks() -
Method in class org.apache.hadoop.mapred.JobConf
- Get configured the number of reduce tasks for this job.
- getNumResolvedTaskTrackers() -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getNumTaskCacheLevels() -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getOffset() -
Method in class org.apache.hadoop.fs.BlockLocation
- Get the start offset of file associated with this block
- getOp() -
Method in class org.apache.hadoop.contrib.index.example.LineDocTextAndOp
- Get the type of the operation.
- getOp() -
Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
- Get the type of operation.
- getOpt(String) -
Method in class org.apache.hadoop.fs.shell.CommandFormat
- Return if the option is set or not
- getOtherAction() -
Method in class org.apache.hadoop.fs.permission.FsPermission
- Return other
FsAction
.
- getOutput() -
Method in class org.apache.hadoop.util.Shell.ShellCommandExecutor
- Get the output of the shell command.
- getOutputCompressionType(JobConf) -
Static method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
- Get the
SequenceFile.CompressionType
for the output SequenceFile
.
- getOutputCompressorClass(JobConf, Class<? extends CompressionCodec>) -
Static method in class org.apache.hadoop.mapred.FileOutputFormat
- Get the
CompressionCodec
for compressing the job outputs.
- getOutputCompressorClass(JobConf, Class<? extends CompressionCodec>) -
Static method in class org.apache.hadoop.mapred.OutputFormatBase
- Deprecated. Get the
CompressionCodec
for compressing the job outputs.
- getOutputFormat() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the
OutputFormat
implementation for the map-reduce job,
defaults to TextOutputFormat
if not specified explicity.
- getOutputKeyClass() -
Static method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateReducer
- Get the reduce output key class.
- getOutputKeyClass() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the key class for the job output data.
- getOutputKeyComparator() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the
RawComparator
comparator used to compare keys.
- getOutputPath(JobConf) -
Static method in class org.apache.hadoop.mapred.FileOutputFormat
- Get the
Path
to the output directory for the map-reduce job.
- getOutputPath() -
Method in class org.apache.hadoop.mapred.JobConf
- Deprecated. Use
FileOutputFormat.getOutputPath(JobConf)
or
FileOutputFormat.getWorkOutputPath(JobConf)
Get the Path
to the output directory for the map-reduce job.
- getOutputStream(Socket) -
Static method in class org.apache.hadoop.net.NetUtils
- Same as getOutputStream(socket, 0).
- getOutputStream(Socket, long) -
Static method in class org.apache.hadoop.net.NetUtils
- Returns OutputStream for the socket.
- getOutputValueClass() -
Static method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateReducer
- Get the reduce output value class.
- getOutputValueClass() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the value class for job outputs.
- getOutputValueGroupingComparator() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the user defined
WritableComparable
comparator for
grouping keys of inputs to the reduce.
- getOwner() -
Method in class org.apache.hadoop.fs.FileStatus
- Get the owner of the file.
- getParameter(ServletRequest, String) -
Static method in class org.apache.hadoop.util.ServletUtil
- Get a parameter from a ServletRequest.
- getParent() -
Method in class org.apache.hadoop.dfs.DatanodeInfo
- Return this node's parent
- getParent() -
Method in class org.apache.hadoop.fs.Path
- Returns the parent of a path or null if at root.
- getParent() -
Method in interface org.apache.hadoop.net.Node
- Return this node's parent
- getParent() -
Method in class org.apache.hadoop.net.NodeBase
- Return this node's parent
- getParentNode(Node, int) -
Static method in class org.apache.hadoop.mapred.JobTracker
-
- getPartition(Shard, IntermediateForm, int) -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdatePartitioner
-
- getPartition(IntWritable, IntWritable, int) -
Method in class org.apache.hadoop.examples.SleepJob
-
- getPartition(K2, V2, int) -
Method in class org.apache.hadoop.mapred.lib.HashPartitioner
- Use
Object.hashCode()
to partition.
- getPartition(K2, V2, int) -
Method in class org.apache.hadoop.mapred.lib.KeyFieldBasedPartitioner
- Use
Object.hashCode()
to partition.
- getPartition(K2, V2, int) -
Method in interface org.apache.hadoop.mapred.Partitioner
- Get the paritition number for a given key (hence record) given the total
number of partitions i.e.
- getPartitionerClass() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the
Partitioner
used to partition Mapper
-outputs
to be sent to the Reducer
s.
- getPath() -
Method in class org.apache.hadoop.fs.FileStatus
-
- getPath() -
Method in class org.apache.hadoop.mapred.FileSplit
- The file containing this split's data.
- getPath(int) -
Method in class org.apache.hadoop.mapred.MultiFileSplit
- Returns the ith Path
- getPath(Node) -
Static method in class org.apache.hadoop.net.NodeBase
- Return this node's path
- getPaths() -
Method in class org.apache.hadoop.mapred.MultiFileSplit
- Returns all the Paths in the split
- getPendingReplicationBlocks() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.FSNamesystemMBean
- Blocks pending to be replicated
- getPercentUsed() -
Method in class org.apache.hadoop.fs.DF
-
- getPercentUsed() -
Method in class org.apache.hadoop.fs.InMemoryFileSystem
- Deprecated.
- getPeriod() -
Method in class org.apache.hadoop.metrics.spi.AbstractMetricsContext
- Returns the timer period.
- getPermission() -
Method in class org.apache.hadoop.fs.FileStatus
- Get FsPermission associated with the file.
- getPermission() -
Method in class org.apache.hadoop.fs.permission.PermissionStatus
- Return permission
- getPlatformName() -
Static method in class org.apache.hadoop.util.PlatformName
- Get the complete platform as per the java-vm.
- getPort() -
Method in class org.apache.hadoop.dfs.DatanodeID
-
- getPort() -
Method in class org.apache.hadoop.mapred.StatusHttpServer
- Get the port that the server is on
- getPos() -
Method in class org.apache.hadoop.contrib.index.example.LineDocRecordReader
-
- getPos() -
Method in class org.apache.hadoop.examples.MultiFileWordCount.MultiFileLineRecordReader
-
- getPos() -
Method in class org.apache.hadoop.fs.BufferedFSInputStream
-
- getPos() -
Method in exception org.apache.hadoop.fs.ChecksumException
-
- getPos() -
Method in class org.apache.hadoop.fs.FSDataInputStream
-
- getPos() -
Method in class org.apache.hadoop.fs.FSDataOutputStream
-
- getPos() -
Method in class org.apache.hadoop.fs.FSInputChecker
-
- getPos() -
Method in class org.apache.hadoop.fs.FSInputStream
- Return the current offset from the start of the file
- getPos() -
Method in class org.apache.hadoop.fs.ftp.FTPInputStream
-
- getPos() -
Method in interface org.apache.hadoop.fs.Seekable
- Return the current offset from the start of the file
- getPos() -
Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
- Unsupported (returns zero in all cases).
- getPos() -
Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
- Request position from proxied RR.
- getPos() -
Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
-
- getPos() -
Method in class org.apache.hadoop.mapred.LineRecordReader
-
- getPos() -
Method in interface org.apache.hadoop.mapred.RecordReader
- Returns the current position in the input.
- getPos() -
Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
-
- getPos() -
Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
-
- getPos() -
Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
-
- getPos() -
Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
- Returns the current position in the input.
- getPosition() -
Method in class org.apache.hadoop.io.DataInputBuffer
- Returns the current position in the input.
- getPosition() -
Method in class org.apache.hadoop.io.InputBuffer
- Returns the current position in the input.
- getPosition() -
Method in class org.apache.hadoop.io.SequenceFile.Reader
- Return the current byte position in the input file.
- getPreferredBlockSize(String) -
Method in class org.apache.hadoop.dfs.NameNode
-
- getPreviousIntervalAverageTime() -
Method in class org.apache.hadoop.metrics.util.MetricsTimeVaryingRate
- The average rate of an operation in the previous interval
- getPreviousIntervalNumOps() -
Method in class org.apache.hadoop.metrics.util.MetricsTimeVaryingRate
- The number of operations in the previous interval
- getPreviousIntervalValue() -
Method in class org.apache.hadoop.metrics.util.MetricsTimeVaryingInt
- The Value at the Previous interval
- getProblems() -
Method in exception org.apache.hadoop.mapred.InvalidInputException
- Get the complete list of the problems reported.
- getProcess() -
Method in class org.apache.hadoop.util.Shell
- get the current sub-process executing the given command
- getProfileEnabled() -
Method in class org.apache.hadoop.mapred.JobConf
- Get whether the task profiling is enabled.
- getProfileParams() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the profiler configuration arguments.
- getProfileTaskRange(boolean) -
Method in class org.apache.hadoop.mapred.JobConf
- Get the range of maps or reduces to profile.
- getProgress() -
Method in class org.apache.hadoop.contrib.index.example.LineDocRecordReader
-
- getProgress() -
Method in class org.apache.hadoop.examples.MultiFileWordCount.MultiFileLineRecordReader
-
- getProgress() -
Method in interface org.apache.hadoop.io.SequenceFile.Sorter.RawKeyValueIterator
- Gets the Progress object; this has a float (0.0 - 1.0)
indicating the bytes processed by the iterator so far
- getProgress() -
Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
- Report progress as the minimum of all child RR progress.
- getProgress() -
Method in class org.apache.hadoop.mapred.join.WrappedRecordReader
- Request progress from proxied RR.
- getProgress() -
Method in class org.apache.hadoop.mapred.KeyValueLineRecordReader
-
- getProgress() -
Method in class org.apache.hadoop.mapred.LineRecordReader
- Get the progress within the split
- getProgress() -
Method in interface org.apache.hadoop.mapred.RecordReader
- How much of the input has the
RecordReader
consumed i.e.
- getProgress() -
Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
- Return the progress within the input split
- getProgress() -
Method in class org.apache.hadoop.mapred.SequenceFileAsTextRecordReader
-
- getProgress() -
Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
- Return the progress within the input split
- getProgress() -
Method in class org.apache.hadoop.mapred.TaskReport
- The amount completed, between zero and one.
- getProgress() -
Method in class org.apache.hadoop.streaming.StreamBaseRecordReader
-
- getProtocolVersion(String, long) -
Method in class org.apache.hadoop.dfs.DataNode
- Return protocol version corresponding to protocol interface.
- getProtocolVersion(String, long) -
Method in class org.apache.hadoop.dfs.NameNode
-
- getProtocolVersion(String, long) -
Method in interface org.apache.hadoop.ipc.VersionedProtocol
- Return protocol version corresponding to protocol interface.
- getProtocolVersion(String, long) -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getProtocolVersion(String, long) -
Method in class org.apache.hadoop.mapred.TaskTracker
-
- getProxy(Class<?>, long, InetSocketAddress, Configuration, SocketFactory) -
Static method in class org.apache.hadoop.ipc.RPC
- Construct a client-side proxy object that implements the named protocol,
talking to a server at the named address.
- getProxy(Class<?>, long, InetSocketAddress, UserGroupInformation, Configuration, SocketFactory) -
Static method in class org.apache.hadoop.ipc.RPC
- Construct a client-side proxy object that implements the named protocol,
talking to a server at the named address.
- getProxy(Class<?>, long, InetSocketAddress, Configuration) -
Static method in class org.apache.hadoop.ipc.RPC
- Construct a client-side proxy object with the default SocketFactory
- getQuota() -
Method in class org.apache.hadoop.fs.ContentSummary
- Return the directory quota
- getRange(String, String) -
Method in class org.apache.hadoop.conf.Configuration
- Parse the given attribute as a set of integer ranges
- getRaw(String) -
Method in class org.apache.hadoop.conf.Configuration
- Get the value of the
name
property, without doing
variable expansion.
- getRawCapacity() -
Method in class org.apache.hadoop.dfs.ChecksumDistributedFileSystem
- Return the total raw capacity of the filesystem, disregarding
replication .
- getRawCapacity() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
- Return the total raw capacity of the filesystem, disregarding
replication .
- getRawFileSystem() -
Method in class org.apache.hadoop.fs.ChecksumFileSystem
- get the raw file system
- getRawUsed() -
Method in class org.apache.hadoop.dfs.ChecksumDistributedFileSystem
- Return the total raw used space in the filesystem, disregarding
replication .
- getRawUsed() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
- Return the total raw used space in the filesystem, disregarding
replication .
- getReadBlockOpAverageTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReadBlockOpAverageTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Average time for ReadBlock Operation in last interval
- getReadBlockOpMaxTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReadBlockOpMaxTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Maximum ReadBlock Operation Time since reset was called
- getReadBlockOpMinTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReadBlockOpMinTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Minimum ReadBlock Operation Time since reset was called
- getReadBlockOpNum() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReadBlockOpNum() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of ReadBlock Operation in last interval
- getReaders(FileSystem, Path, Configuration) -
Static method in class org.apache.hadoop.mapred.MapFileOutputFormat
- Open the output generated by this format.
- getReaders(Configuration, Path) -
Static method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
- Open the output generated by this format.
- getReadMetadataOpAverageTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReadMetadataOpAverageTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Average time for ReadMetadata Operation in last interval
- getReadMetadataOpMaxTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReadMetadataOpMaxTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Maximum ReadMetadata Operation Time since reset was called
- getReadMetadataOpMinTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReadMetadataOpMinTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Minimum ReadMetadata Operation Time since reset was called
- getReadMetadataOpNum() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReadMetadataOpNum() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of ReadMetadata Operation in last interval
- getReadsFromLocalClient() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReadsFromLocalClient() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of reads from local clients in the last interval
- getReadsFromRemoteClient() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReadsFromRemoteClient() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of reads from remote clients in the last interval
- getReadyJobs() -
Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
-
- getRecordName() -
Method in interface org.apache.hadoop.metrics.MetricsRecord
- Returns the record name.
- getRecordName() -
Method in class org.apache.hadoop.metrics.spi.MetricsRecordImpl
- Returns the record name.
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.contrib.index.example.LineDocInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.examples.MultiFileWordCount.MyInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.mapred.FileInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in interface org.apache.hadoop.mapred.InputFormat
- Get the
RecordReader
for the given InputSplit
.
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in interface org.apache.hadoop.mapred.join.ComposableInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
- Construct a CompositeRecordReader for the children of this InputFormat
as defined in the init expression.
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.mapred.KeyValueTextInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.mapred.lib.NLineInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.mapred.MultiFileInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.mapred.SequenceFileAsTextInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.mapred.SequenceFileInputFilter
- Create a record reader for the given split
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.mapred.SequenceFileInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.mapred.TextInputFormat
-
- getRecordReader(InputSplit, JobConf, Reporter) -
Method in class org.apache.hadoop.streaming.StreamInputFormat
-
- getRecordReaderQueue() -
Method in class org.apache.hadoop.mapred.join.CompositeRecordReader
- Return sorted list of RecordReaders for this composite.
- getRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.contrib.index.mapred.IndexUpdateOutputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.mapred.FileOutputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.mapred.lib.MultipleOutputFormat
- Create a composite record writer that can write key/value data to different
output files
- getRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.mapred.lib.NullOutputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.mapred.MapFileOutputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in interface org.apache.hadoop.mapred.OutputFormat
- Get the
RecordWriter
for the given job.
- getRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.mapred.OutputFormatBase
- Deprecated.
- getRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.mapred.SequenceFileOutputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) -
Method in class org.apache.hadoop.mapred.TextOutputFormat
-
- getReduceDebugScript() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the reduce task's debug Script
- getReducerClass() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the
Reducer
class for the job.
- getReduceSpeculativeExecution() -
Method in class org.apache.hadoop.mapred.JobConf
- Should speculative execution be used for this job for reduce tasks?
Defaults to
true
.
- getReduceTaskReports(JobID) -
Method in class org.apache.hadoop.mapred.JobClient
- Get the information of the current state of the reduce tasks of a job.
- getReduceTaskReports(String) -
Method in class org.apache.hadoop.mapred.JobClient
- Deprecated. Applications should rather use
JobClient.getReduceTaskReports(JobID)
- getReduceTaskReports(String) -
Method in class org.apache.hadoop.mapred.JobTracker
- Deprecated.
- getReduceTaskReports(JobID) -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getReduceTasks() -
Method in class org.apache.hadoop.mapred.ClusterStatus
- Get the number of currently running reduce tasks in the cluster.
- getRemaining() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.FSDatasetMBean
- Returns the amount of free storage space (in bytes)
- getRemaining() -
Method in class org.apache.hadoop.dfs.DatanodeInfo
- The raw free space.
- getRemaining() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem.DiskStatus
-
- getRemainingArgs() -
Method in class org.apache.hadoop.util.GenericOptionsParser
- Returns an array of Strings containing only application-specific arguments.
- getRemoteAddress() -
Static method in class org.apache.hadoop.ipc.Server
- Returns remote address as a string when invoked inside an RPC.
- getRemoteIp() -
Static method in class org.apache.hadoop.ipc.Server
- Returns the remote side ip address when invoked inside an RPC
Returns null incase of an error.
- getReplaceBlockOpAverageTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReplaceBlockOpAverageTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Average time for ReplaceBlock Operation in last interval
- getReplaceBlockOpMaxTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReplaceBlockOpMaxTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Maximum ReplaceBlock Operation Time since reset was called
- getReplaceBlockOpMinTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReplaceBlockOpMinTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Minimum ReplaceBlock Operation Time since reset was called
- getReplaceBlockOpNum() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getReplaceBlockOpNum() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of ReplaceBlock Operation in last interval
- getReplication() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return the intended replication factor, against which the over/under-
replicated blocks are counted.
- getReplication() -
Method in class org.apache.hadoop.fs.FileStatus
- Get the replication factor of a file.
- getReplication(Path) -
Method in class org.apache.hadoop.fs.FileSystem
- Deprecated. Use getFileStatus() instead
- getReplication(Path) -
Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
- Deprecated.
- getReplicationFactor() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return the actual replication factor.
- getReport() -
Method in class org.apache.hadoop.contrib.utils.join.JobBase
- log the counters
- getReport() -
Method in class org.apache.hadoop.mapred.lib.aggregate.DoubleValueSum
-
- getReport() -
Method in class org.apache.hadoop.mapred.lib.aggregate.LongValueMax
-
- getReport() -
Method in class org.apache.hadoop.mapred.lib.aggregate.LongValueMin
-
- getReport() -
Method in class org.apache.hadoop.mapred.lib.aggregate.LongValueSum
-
- getReport() -
Method in class org.apache.hadoop.mapred.lib.aggregate.StringValueMax
-
- getReport() -
Method in class org.apache.hadoop.mapred.lib.aggregate.StringValueMin
-
- getReport() -
Method in class org.apache.hadoop.mapred.lib.aggregate.UniqValueCount
-
- getReport() -
Method in interface org.apache.hadoop.mapred.lib.aggregate.ValueAggregator
-
- getReport() -
Method in class org.apache.hadoop.mapred.lib.aggregate.ValueHistogram
-
- getReportDetails() -
Method in class org.apache.hadoop.mapred.lib.aggregate.ValueHistogram
-
- getReportItems() -
Method in class org.apache.hadoop.mapred.lib.aggregate.ValueHistogram
-
- getResource(String) -
Method in class org.apache.hadoop.conf.Configuration
- Get the
URL
for the named resource.
- getRevision() -
Static method in class org.apache.hadoop.util.VersionInfo
- Get the subversion revision number for the root directory
- getRotations() -
Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
-
- getRpcOpsAvgProcessingTime() -
Method in interface org.apache.hadoop.ipc.metrics.RpcMgtMBean
- Average time for RPC Operations in last interval
- getRpcOpsAvgProcessingTimeMax() -
Method in interface org.apache.hadoop.ipc.metrics.RpcMgtMBean
- The Maximum RPC Operation Processing Time since reset was called
- getRpcOpsAvgProcessingTimeMin() -
Method in interface org.apache.hadoop.ipc.metrics.RpcMgtMBean
- The Minimum RPC Operation Processing Time since reset was called
- getRpcOpsAvgQueueTime() -
Method in interface org.apache.hadoop.ipc.metrics.RpcMgtMBean
- The Average RPC Operation Queued Time in the last interval
- getRpcOpsAvgQueueTimeMax() -
Method in interface org.apache.hadoop.ipc.metrics.RpcMgtMBean
- The Maximum RPC Operation Queued Time since reset was called
- getRpcOpsAvgQueueTimeMin() -
Method in interface org.apache.hadoop.ipc.metrics.RpcMgtMBean
- The Minimum RPC Operation Queued Time since reset was called
- getRpcOpsNumber() -
Method in interface org.apache.hadoop.ipc.metrics.RpcMgtMBean
- Number of RPC Operations in the last interval
- getRunnable() -
Method in class org.apache.hadoop.util.Daemon
-
- getRunningJobs() -
Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
-
- getRunningJobs() -
Method in class org.apache.hadoop.mapred.JobTracker
- Version that is called from a timer thread, and therefore needs to be
careful to synchronize.
- getRunState() -
Method in class org.apache.hadoop.mapred.JobStatus
-
- getSafeModeText() -
Method in class org.apache.hadoop.dfs.JspHelper
-
- getSafemodeTime() -
Method in class org.apache.hadoop.dfs.namenode.metrics.NameNodeStatistics
-
- getSafemodeTime() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.NameNodeStatisticsMBean
- The time spent in the Safemode at startup
- getScheduledReplicationBlocks() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.FSNamesystemMBean
- Blocks scheduled for replication
- getSecretAccessKey() -
Method in class org.apache.hadoop.fs.s3.S3Credentials
-
- getSelfAddr() -
Method in class org.apache.hadoop.dfs.DataNode
-
- getSequenceFileOutputKeyClass(JobConf) -
Static method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
- Get the key class for the
SequenceFile
- getSequenceFileOutputValueClass(JobConf) -
Static method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat
- Get the value class for the
SequenceFile
- getSerialization(Class<T>) -
Method in class org.apache.hadoop.io.serializer.SerializationFactory
-
- getSerializedLength() -
Method in class org.apache.hadoop.fs.s3.INode
-
- getSerializer(Class<Serializable>) -
Method in class org.apache.hadoop.io.serializer.JavaSerialization
-
- getSerializer(Class<T>) -
Method in interface org.apache.hadoop.io.serializer.Serialization
-
- getSerializer(Class<T>) -
Method in class org.apache.hadoop.io.serializer.SerializationFactory
-
- getSerializer(Class<Writable>) -
Method in class org.apache.hadoop.io.serializer.WritableSerialization
-
- getServer(Object, String, int, Configuration) -
Static method in class org.apache.hadoop.ipc.RPC
- Construct a server for a protocol implementation instance listening on a
port and address.
- getServer(Object, String, int, int, boolean, Configuration) -
Static method in class org.apache.hadoop.ipc.RPC
- Construct a server for a protocol implementation instance listening on a
port and address.
- getServerAddress(Configuration, String, String, String) -
Static method in class org.apache.hadoop.net.NetUtils
- Deprecated.
- getServerVersion() -
Method in exception org.apache.hadoop.ipc.RPC.VersionMismatch
- Get the server's agreed to version.
- getSessionId() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the user-specified session identifier.
- getShape(boolean, int) -
Method in class org.apache.hadoop.examples.dancing.Pentomino.Piece
-
- getSize() -
Method in class org.apache.hadoop.io.BytesWritable
- Get the current size of the buffer.
- getSize() -
Method in interface org.apache.hadoop.io.SequenceFile.ValueBytes
- Size of stored data.
- getSize() -
Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryOutputFormat.WritableValueBytes
-
- getSocketFactory(Configuration, Class<?>) -
Static method in class org.apache.hadoop.net.NetUtils
- Get the socket factory for the given class according to its
configuration parameter
hadoop.rpc.socket.factory.class.<ClassName>.
- getSocketFactoryFromProperty(Configuration, String) -
Static method in class org.apache.hadoop.net.NetUtils
- Get the socket factory corresponding to the given proxy URI.
- getSpace(int) -
Static method in class org.apache.hadoop.streaming.StreamUtil
-
- getSpeculativeExecution() -
Method in class org.apache.hadoop.mapred.JobConf
- Should speculative execution be used for this job?
Defaults to
true
.
- getSplits(int) -
Method in class org.apache.hadoop.examples.dancing.Pentomino
- Generate a list of prefixes to a given depth
- getSplits(JobConf, int) -
Method in class org.apache.hadoop.mapred.FileInputFormat
- Splits files returned by
FileInputFormat.listStatus(JobConf)
when
they're too big.
- getSplits(JobConf, int) -
Method in interface org.apache.hadoop.mapred.InputFormat
- Logically split the set of input files for the job.
- getSplits(JobConf, int) -
Method in class org.apache.hadoop.mapred.join.CompositeInputFormat
- Build a CompositeInputSplit from the child InputFormats by assigning the
ith split from each child to the ith composite split.
- getSplits(JobConf, int) -
Method in class org.apache.hadoop.mapred.lib.NLineInputFormat
- Logically splits the set of input files for the job, splits N lines
of the input as one split.
- getSplits(JobConf, int) -
Method in class org.apache.hadoop.mapred.MultiFileInputFormat
-
- getStart() -
Method in class org.apache.hadoop.mapred.FileSplit
- The position of the first byte in the file to process.
- getStartTime() -
Method in class org.apache.hadoop.mapred.JobStatus
-
- getStartTime() -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getStartTime() -
Method in class org.apache.hadoop.mapred.TaskReport
- Get start time of task.
- getState() -
Method in class org.apache.hadoop.mapred.jobcontrol.Job
-
- getState() -
Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
-
- getState() -
Method in class org.apache.hadoop.mapred.TaskReport
- The most recent state, reported by a
Reporter
.
- getStaticResolution(String) -
Static method in class org.apache.hadoop.net.NetUtils
- Retrieves the resolved name for the passed host.
- getStatistics(Class<? extends FileSystem>) -
Static method in class org.apache.hadoop.fs.FileSystem
- Get the statistics for a particular file system
- getStats() -
Method in class org.apache.hadoop.dfs.NameNode
-
- getStatusText(boolean) -
Method in class org.apache.hadoop.dfs.UpgradeStatusReport
- Get upgradeStatus data as a text for reporting.
- getStorageID() -
Method in class org.apache.hadoop.dfs.DatanodeID
-
- getStorageInfo() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.FSDatasetMBean
- Returns the storage id of the underlying storage
- getStoredBlock(long) -
Method in interface org.apache.hadoop.dfs.FSDatasetInterface
-
- getStr() -
Method in class org.apache.hadoop.mapred.join.Parser.StrToken
-
- getStr() -
Method in class org.apache.hadoop.mapred.join.Parser.Token
-
- getStringCollection(String) -
Method in class org.apache.hadoop.conf.Configuration
- Get the comma delimited values of the
name
property as
a collection of String
s.
- getStringCollection(String) -
Static method in class org.apache.hadoop.util.StringUtils
- Returns a collection of strings.
- getStrings(String) -
Method in class org.apache.hadoop.conf.Configuration
- Get the comma delimited values of the
name
property as
an array of String
s.
- getStrings(String, String...) -
Method in class org.apache.hadoop.conf.Configuration
- Get the comma delimited values of the
name
property as
an array of String
s.
- getStrings(String) -
Static method in class org.apache.hadoop.util.StringUtils
- Returns an arraylist of strings.
- getSuccessfulJobs() -
Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
-
- GetSuffix(int) -
Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
-
- getSum() -
Method in class org.apache.hadoop.mapred.lib.aggregate.DoubleValueSum
-
- getSum() -
Method in class org.apache.hadoop.mapred.lib.aggregate.LongValueSum
-
- getSymlink(Configuration) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- This method checks to see if symlinks are to be create for the
localized cache files in the current working directory
- getSystemDir() -
Method in class org.apache.hadoop.mapred.JobClient
- Grab the jobtracker system directory path where job-specific files are to be placed.
- getSystemDir() -
Method in class org.apache.hadoop.mapred.JobConf
- Deprecated. Use
JobClient.getSystemDir()
instead.
Get the system directory where job-specific files are to be placed.
- getSystemDir() -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getTabSize(int) -
Method in class org.apache.hadoop.record.compiler.generated.SimpleCharStream
-
- getTag() -
Method in class org.apache.hadoop.contrib.utils.join.TaggedMapOutput
-
- getTag(String) -
Method in class org.apache.hadoop.metrics.spi.OutputRecord
- Returns a tag object which is can be a String, Integer, Short or Byte.
- getTagNames() -
Method in class org.apache.hadoop.metrics.spi.OutputRecord
- Returns the set of tag names
- getTask(String) -
Method in class org.apache.hadoop.mapred.TaskTracker
- Deprecated.
- getTask(TaskAttemptID) -
Method in class org.apache.hadoop.mapred.TaskTracker
- Called upon startup by the child process, to fetch Task data.
- getTaskAttemptId() -
Method in class org.apache.hadoop.mapred.TaskCompletionEvent
- Returns task id.
- getTaskAttemptIDsPattern(String, Integer, Boolean, Integer, Integer) -
Static method in class org.apache.hadoop.mapred.TaskAttemptID
- Returns a regex pattern which matches task attempt IDs.
- getTaskAttempts() -
Method in class org.apache.hadoop.mapred.JobHistory.Task
- Returns all task attempts for this task.
- getTaskCompletionEvents(String, int, int) -
Method in class org.apache.hadoop.mapred.JobTracker
- Deprecated.
- getTaskCompletionEvents(JobID, int, int) -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getTaskCompletionEvents(int) -
Method in interface org.apache.hadoop.mapred.RunningJob
- Get events indicating completion (success/failure) of component tasks.
- getTaskDiagnostics(String, String, String) -
Method in class org.apache.hadoop.mapred.JobTracker
- Deprecated.
- getTaskDiagnostics(TaskAttemptID) -
Method in class org.apache.hadoop.mapred.JobTracker
- Get the diagnostics for a given task
- getTaskID() -
Method in class org.apache.hadoop.mapred.TaskAttemptID
- Returns the
TaskID
object that this task attempt belongs to
- getTaskId() -
Method in class org.apache.hadoop.mapred.TaskCompletionEvent
- Deprecated. use
TaskCompletionEvent.getTaskAttemptId()
instead.
- getTaskId() -
Method in class org.apache.hadoop.mapred.TaskLogAppender
- Getter/Setter methods for log4j.
- getTaskId() -
Method in class org.apache.hadoop.mapred.TaskReport
- Deprecated. use
TaskReport.getTaskID()
instead
- getTaskID() -
Method in class org.apache.hadoop.mapred.TaskReport
- The id of the task.
- getTaskIDsPattern(String, Integer, Boolean, Integer) -
Static method in class org.apache.hadoop.mapred.TaskID
- Returns a regex pattern which matches task IDs.
- getTaskInfo(JobConf) -
Static method in class org.apache.hadoop.streaming.StreamUtil
-
- getTaskLogFile(String, TaskLog.LogName) -
Static method in class org.apache.hadoop.mapred.TaskLog
- Deprecated.
- getTaskLogFile(TaskAttemptID, TaskLog.LogName) -
Static method in class org.apache.hadoop.mapred.TaskLog
-
- getTaskLogLength(JobConf) -
Static method in class org.apache.hadoop.mapred.TaskLog
- Get the desired maximum length of task's logs.
- getTaskOutputFilter(JobConf) -
Static method in class org.apache.hadoop.mapred.JobClient
- Get the task output filter out of the JobConf.
- getTaskOutputFilter() -
Method in class org.apache.hadoop.mapred.JobClient
- Deprecated.
- getTaskOutputPath(JobConf, String) -
Static method in class org.apache.hadoop.mapred.FileOutputFormat
- Helper function to create the task's temporary output directory and
return the path to the task's output file.
- getTaskRunTime() -
Method in class org.apache.hadoop.mapred.TaskCompletionEvent
- Returns time (in millisec) the task took to complete.
- getTaskStatus() -
Method in class org.apache.hadoop.mapred.TaskCompletionEvent
- Returns enum Status.SUCESS or Status.FAILURE.
- getTaskTracker(String) -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getTaskTrackerHttp() -
Method in class org.apache.hadoop.mapred.TaskCompletionEvent
- http location of the tasktracker where this task ran.
- getTaskTrackerMetrics() -
Method in class org.apache.hadoop.mapred.TaskTracker
-
- getTaskTrackerReportAddress() -
Method in class org.apache.hadoop.mapred.TaskTracker
- Return the port at which the tasktracker bound to
- getTaskTrackers() -
Method in class org.apache.hadoop.mapred.ClusterStatus
- Get the number of task trackers in the cluster.
- getTerm() -
Method in class org.apache.hadoop.contrib.index.mapred.DocumentAndOp
- Get the term.
- getText() -
Method in class org.apache.hadoop.contrib.index.example.LineDocTextAndOp
- Get the text that represents a document.
- getText() -
Method in class org.apache.hadoop.contrib.index.mapred.DocumentID
- The text of the document id.
- getTimestamp(Configuration, URI) -
Static method in class org.apache.hadoop.filecache.DistributedCache
- Returns mtime of a given cache file on hdfs.
- getTip(TaskID) -
Method in class org.apache.hadoop.mapred.JobTracker
- Returns specified TaskInProgress, or null.
- getToken(int) -
Method in class org.apache.hadoop.record.compiler.generated.Rcc
-
- getTotalBlocks() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return the total number of blocks in the scanned area.
- getTotalDirs() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return total number of directories encountered during this scan.
- getTotalFiles() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return total number of files encountered during this scan.
- getTotalLoad() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.FSNamesystemMBean
- Total Load on the FSNamesystem
- getTotalLogFileSize() -
Method in class org.apache.hadoop.mapred.TaskLogAppender
-
- getTotalOpenFiles() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return total number of files opened for write encountered during this scan.
- getTotalOpenFilesBlocks() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return the total number of blocks held by open files.
- getTotalOpenFilesSize() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return total size of open files data, in bytes.
- getTotalSize() -
Method in class org.apache.hadoop.dfs.NamenodeFsck.FsckResult
- Return total size of scanned data, in bytes.
- getTotalSubmissions() -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getTrackerIdentifier() -
Method in class org.apache.hadoop.mapred.JobTracker
- Get the unique identifier (ie.
- getTrackerPort() -
Method in class org.apache.hadoop.mapred.JobTracker
-
- getTrackingURL() -
Method in interface org.apache.hadoop.mapred.RunningJob
- Get the URL where some job progress information will be displayed.
- getType() -
Method in interface org.apache.hadoop.dfs.Upgradeable
- Get the type of the software component, which this object is upgrading.
- getType() -
Method in class org.apache.hadoop.mapred.join.Parser.Token
-
- getTypeID() -
Method in class org.apache.hadoop.record.meta.FieldTypeInfo
- get the field's TypeID object
- getTypes() -
Method in class org.apache.hadoop.io.GenericWritable
- Return all classes that may be wrapped.
- getTypeVal() -
Method in class org.apache.hadoop.record.meta.TypeID
- Get the type value.
- getUlimitMemoryCommand(JobConf) -
Static method in class org.apache.hadoop.util.Shell
- Get the Unix command for setting the maximum virtual memory available
to a given child process.
- getUMask(Configuration) -
Static method in class org.apache.hadoop.fs.permission.FsPermission
- Get the user file creation mask (umask)
- getUnderReplicatedBlocks() -
Method in interface org.apache.hadoop.dfs.namenode.metrics.FSNamesystemMBean
- Blocks under replicated
- getUniqueItems() -
Method in class org.apache.hadoop.mapred.lib.aggregate.UniqValueCount
-
- getUpgradeStatus() -
Method in interface org.apache.hadoop.dfs.Upgradeable
- Upgrade status determines a percentage of the work done out of the total
amount required by the upgrade.
- getUpgradeStatus() -
Method in class org.apache.hadoop.dfs.UpgradeStatusReport
- Get upgrade upgradeStatus as a percentage of the total upgrade done.
- getUpgradeStatusReport(boolean) -
Method in interface org.apache.hadoop.dfs.Upgradeable
- Get status report for the upgrade.
- getUpgradeStatusText() -
Method in class org.apache.hadoop.dfs.JspHelper
-
- getUri() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
-
- getUri() -
Method in class org.apache.hadoop.dfs.HftpFileSystem
-
- getUri() -
Method in class org.apache.hadoop.dfs.HsftpFileSystem
-
- getUri() -
Method in class org.apache.hadoop.fs.FileSystem
- Returns a URI whose scheme and authority identify this FileSystem.
- getUri() -
Method in class org.apache.hadoop.fs.FilterFileSystem
- Returns a URI whose scheme and authority identify this FileSystem.
- getUri() -
Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
-
- getUri() -
Method in class org.apache.hadoop.fs.HarFileSystem
- Returns the uri of this filesystem.
- getUri() -
Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
-
- getUri() -
Method in class org.apache.hadoop.fs.RawLocalFileSystem
-
- getUri() -
Method in class org.apache.hadoop.fs.s3.S3FileSystem
-
- getUri() -
Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
-
- getURIs(String, String) -
Method in class org.apache.hadoop.streaming.StreamJob
- get the uris of all the files/caches
- getURL() -
Method in class org.apache.hadoop.mapred.JobProfile
- Get the link to the web-ui for details of the job.
- getUrl() -
Static method in class org.apache.hadoop.util.VersionInfo
- Get the subversion URL for the root Hadoop directory.
- getUsed() -
Method in class org.apache.hadoop.fs.DF
-
- getUsed() -
Method in class org.apache.hadoop.fs.DU
-
- getUsed() -
Method in class org.apache.hadoop.fs.FileSystem
- Return the total size of all files in the filesystem.
- getUser() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the reported username for this job.
- getUser() -
Method in class org.apache.hadoop.mapred.JobProfile
- Get the user id.
- getUser() -
Static method in class org.apache.hadoop.util.VersionInfo
- The user that compiled Hadoop.
- getUserAction() -
Method in class org.apache.hadoop.fs.permission.FsPermission
- Return user
FsAction
.
- getUserName() -
Method in class org.apache.hadoop.fs.permission.PermissionStatus
- Return user name
- getUsername() -
Method in class org.apache.hadoop.mapred.JobStatus
-
- getUserName() -
Method in class org.apache.hadoop.security.UnixUserGroupInformation
- Return the user's name
- getUserName() -
Method in class org.apache.hadoop.security.UserGroupInformation
- Get username
- getVal() -
Method in class org.apache.hadoop.mapred.lib.aggregate.LongValueMax
-
- getVal() -
Method in class org.apache.hadoop.mapred.lib.aggregate.LongValueMin
-
- getVal() -
Method in class org.apache.hadoop.mapred.lib.aggregate.StringValueMax
-
- getVal() -
Method in class org.apache.hadoop.mapred.lib.aggregate.StringValueMin
-
- getValue() -
Method in class org.apache.hadoop.dfs.DataChecksum
-
- getValue() -
Method in interface org.apache.hadoop.io.SequenceFile.Sorter.RawKeyValueIterator
- Gets the current raw value
- getValueClass() -
Method in class org.apache.hadoop.io.ArrayWritable
-
- getValueClass() -
Method in class org.apache.hadoop.io.MapFile.Reader
- Returns the class of values in this file.
- getValueClass() -
Method in class org.apache.hadoop.io.SequenceFile.Reader
- Returns the class of values in this file.
- getValueClass() -
Method in class org.apache.hadoop.io.SequenceFile.Writer
- Returns the class of values in this file.
- getValueClass() -
Method in class org.apache.hadoop.mapred.SequenceFileRecordReader
- The class of value that must be passed to
SequenceFileRecordReader.next(Object, Object)
..
- getValueClassName() -
Method in class org.apache.hadoop.io.SequenceFile.Reader
- Returns the name of the value class.
- getValueClassName() -
Method in class org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat.SequenceFileAsBinaryRecordReader
- Retrieve the name of the value class for this SequenceFile.
- getValueTypeID() -
Method in class org.apache.hadoop.record.meta.MapTypeID
- get the TypeID of the map's value element
- getVersion() -
Method in class org.apache.hadoop.contrib.index.mapred.Shard
- Get the version number of the entire index.
- getVersion() -
Method in interface org.apache.hadoop.dfs.Upgradeable
- Get the layout version of the upgrade object.
- getVersion() -
Method in class org.apache.hadoop.dfs.UpgradeStatusReport
- Get the layout version of the currently running upgrade.
- getVersion() -
Method in interface org.apache.hadoop.fs.s3.FileSystemStore
-
- getVersion() -
Method in class org.apache.hadoop.io.VersionedWritable
- Return the version number of the current implementation.
- getVersion() -
Static method in class org.apache.hadoop.util.VersionInfo
- Get the Hadoop version.
- getVIntSize(long) -
Static method in class org.apache.hadoop.io.WritableUtils
- Get the encoded length if an integer is stored in a variable-length format
- getVIntSize(long) -
Static method in class org.apache.hadoop.record.Utils
- Get the encoded length if an integer is stored in a variable-length format
- getWaitingJobs() -
Method in class org.apache.hadoop.mapred.jobcontrol.JobControl
-
- getWarn() -
Static method in class org.apache.hadoop.metrics.jvm.EventCounter
-
- getWorkingDirectory() -
Method in class org.apache.hadoop.dfs.DistributedFileSystem
-
- getWorkingDirectory() -
Method in class org.apache.hadoop.dfs.HftpFileSystem
-
- getWorkingDirectory() -
Method in class org.apache.hadoop.fs.FileSystem
- Get the current working directory for the given file system
- getWorkingDirectory() -
Method in class org.apache.hadoop.fs.FilterFileSystem
- Get the current working directory for the given file system
- getWorkingDirectory() -
Method in class org.apache.hadoop.fs.ftp.FTPFileSystem
-
- getWorkingDirectory() -
Method in class org.apache.hadoop.fs.HarFileSystem
- return the top level archive.
- getWorkingDirectory() -
Method in class org.apache.hadoop.fs.kfs.KosmosFileSystem
-
- getWorkingDirectory() -
Method in class org.apache.hadoop.fs.RawLocalFileSystem
-
- getWorkingDirectory() -
Method in class org.apache.hadoop.fs.s3.S3FileSystem
-
- getWorkingDirectory() -
Method in class org.apache.hadoop.fs.s3native.NativeS3FileSystem
-
- getWorkingDirectory() -
Method in class org.apache.hadoop.mapred.JobConf
- Get the current working directory for the default file system.
- getWorkOutputPath(JobConf) -
Static method in class org.apache.hadoop.mapred.FileOutputFormat
- Get the
Path
to the task's temporary output directory
for the map-reduce job
Tasks' Side-Effect Files
- getWrappedStream() -
Method in class org.apache.hadoop.fs.FSDataOutputStream
-
- getWriteBlockOpAverageTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getWriteBlockOpAverageTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Average time for WriteBlock Operation in last interval
- getWriteBlockOpMaxTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getWriteBlockOpMaxTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Maximum WriteBlock Operation Time since reset was called
- getWriteBlockOpMinTime() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getWriteBlockOpMinTime() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- The Minimum WriteBlock Operation Time since reset was called
- getWriteBlockOpNum() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getWriteBlockOpNum() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of WriteBlock Operation in last interval
- getWritesFromLocalClient() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getWritesFromLocalClient() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of writes from local clients in the last interval
- getWritesFromRemoteClient() -
Method in class org.apache.hadoop.dfs.datanode.metrics.DataNodeStatistics
-
- getWritesFromRemoteClient() -
Method in interface org.apache.hadoop.dfs.datanode.metrics.DataNodeStatisticsMBean
- Number of writes from remote clients in the last interval
- getXceiverCount() -
Method in class org.apache.hadoop.dfs.DatanodeInfo
- number of active connections
- getZlibCompressor(Configuration) -
Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
- Return the appropriate implementation of the zlib compressor.
- getZlibCompressorType(Configuration) -
Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
- Return the appropriate type of the zlib compressor.
- getZlibDecompressor(Configuration) -
Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
- Return the appropriate implementation of the zlib decompressor.
- getZlibDecompressorType(Configuration) -
Static method in class org.apache.hadoop.io.compress.zlib.ZlibFactory
- Return the appropriate type of the zlib decompressor.
- globStatus(Path) -
Method in class org.apache.hadoop.fs.FileSystem
- Return all the files that match filePattern and are not checksum
files.
- globStatus(Path, PathFilter) -
Method in class org.apache.hadoop.fs.FileSystem
- Return an array of FileStatus objects whose path names match pathPattern
and is accepted by the user-supplied path filter.
- go() -
Method in class org.apache.hadoop.streaming.StreamJob
- This is the method that actually
intializes the job conf and submits the job
to the jobtracker
- goodClassOrNull(String, String) -
Static method in class org.apache.hadoop.streaming.StreamUtil
- It may seem strange to silently switch behaviour when a String
is not a classname; the reason is simplified Usage:
- Grep - Class in org.apache.hadoop.examples
-
- GT_TKN -
Static variable in interface org.apache.hadoop.record.compiler.generated.RccConstants
-
- GzipCodec - Class in org.apache.hadoop.io.compress
- This class creates gzip compressors/decompressors.
- GzipCodec() -
Constructor for class org.apache.hadoop.io.compress.GzipCodec
-
- GzipCodec.GzipInputStream - Class in org.apache.hadoop.io.compress
-
- GzipCodec.GzipInputStream(InputStream) -
Constructor for class org.apache.hadoop.io.compress.GzipCodec.GzipInputStream
-
- GzipCodec.GzipInputStream(DecompressorStream) -
Constructor for class org.apache.hadoop.io.compress.GzipCodec.GzipInputStream
- Allow subclasses to directly set the inflater stream.
- GzipCodec.GzipOutputStream - Class in org.apache.hadoop.io.compress
- A bridge that wraps around a DeflaterOutputStream to make it
a CompressionOutputStream.
- GzipCodec.GzipOutputStream(OutputStream) -
Constructor for class org.apache.hadoop.io.compress.GzipCodec.GzipOutputStream
-
- GzipCodec.GzipOutputStream(CompressorStream) -
Constructor for class org.apache.hadoop.io.compress.GzipCodec.GzipOutputStream
- Allow children types to put a different type in here.
Object.hashCode()
.TaskTracker
and
the JobTracker
.
Enum
type, by the specified amount.
IndexedSorter
algorithms.IndexedSortable
items.JobTracker
.
InputStream
implementation that reads from an in-memory
buffer.InputFormat
describes the input-specification for a
Map-Reduce job.InputSplit
represents the data to be processed by an
individual Mapper
.Mapper
that swaps keys and values.Iterator
to go through the list of String
key-value pairs in the configuration.
Serialization
for Java Serializable
classes.RawComparator
that uses a JavaSerialization
Deserializer
to deserialize objects that are then compared via
their Comparable
interfaces.JobClient
is the primary interface for the user-job to interact
with the JobTracker
.JobConf
, and connect to the
default JobTracker
.
JobProfile
.
JobProfile
the userid, jobid,
job config-file, job-details url and job name.
ArrayFile.Reader.seek(long)
, ArrayFile.Reader.next(Writable)
, or ArrayFile.Reader.get(long,Writable)
.
InputFormat
for plain text files.RunningJob.killTask(TaskAttemptID, boolean)
io.file.buffer.size
specified in the given
Configuration
.
FileInputFormat.listStatus(JobConf)
instead.
f
is a file, this method will make a single call to S3.
Reducer
that sums long values.CompressionCodec
for a streaming
lzo compression/decompression pair.Compressor
based on the lzo algorithm.LzoCompressor.CompressionStrategy
.
Decompressor
based on the lzo algorithm.OutputFormat
that writes MapFile
s.Mapper
and Reducer
implementations.Mapper
s.MapRunnable
implementation.MBeanUtil.registerMBean(String, String, Object)
SegmentDescriptor
FileSystem.mkdirs(Path, FsPermission)
with default permission.
InputFormat
that returns MultiFileSplit
's
in MultiFileInputFormat.getSplits(JobConf, int)
method.WordCount.MapClass
.MultiFileInputFormat
, one should extend it, to return a
(custom) RecordReader
.IOException
into an IOException
FileSystem
for reading and writing files stored on
Amazon S3.true
if a preset dictionary is needed for decompression.
WritableComparable
instance.
key
and
val
.
key
, skipping its
value.
key
and
val
.
SequenceFile.Reader.nextRaw(DataOutputBuffer,SequenceFile.ValueBytes)
.
key
.
FSDataInputStream
returned.
FileSystem
.FileSystem
that uses Amazon S3
as a backing store.FileSystem
for reading and writing files on
Amazon S3.OutputStream
implementation that writes to an in-memory
buffer.<key, value>
pairs output by Mapper
s
and Reducer
s.OutputFormat
describes the output-specification for a
Map-Reduce job.FileOutputFormat
FileSystem
.Comparator
that operates directly on byte representations of
objects.FsPermission
from DataInput
.
PermissionStatus
from DataInput
.
buf
at offset
and checksum into checksum
.
in
.
in
.
For efficiency, implementations should attempt to re-use storage in the existing object where possible.
in
.
in
.
in
.
in
.
in
.
For efficiency, implementations should attempt to re-use storage in the existing object where possible.
in
.
For efficiency, implementations should attempt to re-use storage in the existing object where possible.
in
.
in
.
in
.
CompressedWritable.readFields(DataInput)
.
UserGroupInformation
from conf
conf
The object is expected to store with the property name attr
as a comma separated string that starts
with the user name followed by group names.
len
bytes from
stm
Writable
, String
, primitive type, or an array of
the preceding.
Writable
, String
, primitive type, or an array of
the preceding.
Record
comparison implementation.
RecordReader
reads <key, value> pairs from an
InputSplit
.RecordWriter
writes the output <key, value> pairs
to an output file.Mapper
that extracts text matching a regular expression.RetryPolicy
.Compressor
to the pool.
Decompressor
to the pool.
Tool
by Tool.run(String[])
, after
parsing with the given generic arguments.
Tool
with its Configuration
.
RunningJob
is the user-interface to query for details on a
running Map-Reduce job.FileSystem
backed by
Amazon S3.S3FileSystem
.ugi
as a comma separated string in
conf
as a property attr
The String starts with the user name followed by the default group names,
and other group names.
DNSToSwitchMapping
interface using a
script configured via topology.script.file.name .n
th value.
SequenceFile
s are flat files consisting of binary key/value
pairs.SequenceFile
.RawComparator
.
OutputFormat
that writes keys, values to
SequenceFile
s in binary(raw) formatInputFormat
for SequenceFile
s.OutputFormat
that writes SequenceFile
s.RecordReader
for SequenceFile
s.Serializer
/Deserializer
pair.Serialization
s.io.serializations
property from conf
, which is a comma-delimited list of
classnames.
t
to the underlying output stream.
OutputStream
.value
of the name
property.
name
property to a boolean
.
name
property to the name of a
theClass
implementing the given interface xface
.
SequenceFile.CompressionType
while creating the SequenceFile
or
JobConf.setMapOutputCompressionType(org.apache.hadoop.io.SequenceFile.CompressionType)
to specify the SequenceFile.CompressionType
for intermediate map-outputs or
SequenceFileOutputFormat.setOutputCompressionType(org.apache.hadoop.mapred.JobConf, org.apache.hadoop.io.SequenceFile.CompressionType)
to specify the SequenceFile.CompressionType
for job-outputs.
or
UserGroupInformation
for the current thread
InputFormat
implementation for the map-reduce job.
FileInputFormat.setInputPaths(JobConf, Path...)
or
FileInputFormat.setInputPaths(JobConf, String)
Path
s as the list of inputs
for the map-reduce job.
name
property to an int
.
JobPriority
for this job.
name
property to a long
.
SequenceFile.CompressionType
is no longer valid for intermediate
map-outputs.
CompressionCodec
for the map outputs.
Mapper
class for the job.
Job.setAssignedJobID(JobID)
instead
MapRunnable
class for the job.
SequenceFile.CompressionType
for the output SequenceFile
.
CompressionCodec
to be used to compress job outputs.
CompressionCodec
to be used to compress job outputs.
OutputFormat
implementation for the map-reduce job.
RawComparator
comparator used to compare keys.
Path
of the output directory for the map-reduce job.
FileOutputFormat.setOutputPath(JobConf, Path)
Set the Path
of the output directory for the map-reduce job.
Note:
RawComparator
comparator for
grouping keys in the input to the reduce.
Partitioner
class used to partition
Mapper
-outputs to be sent to the Reducer
s.
Reducer
class for the job.
SequenceFile
SequenceFile
name
property as
as comma delimited values.
TaskCompletionEvent.setTaskID(TaskAttemptID)
instead.
Shell
instead.n
bytes of data from the
input stream.
IndexedSorter.sort(IndexedSortable,int,int)
, but indicate progress
periodically.
IndexedSorter.sort(IndexedSortable,int,int)
, but indicate progress
periodically.
IndexedSorter.sort(IndexedSortable,int,int)
, but indicate progress
periodically.
fileName
attribute,
if specified.
TaskID
.
JobID
.
InputFormat
for plain text files.OutputFormat
that writes plain text files.List<T>
to a an array of
T[]
.
List<T>
to a an array of
T[]
.
Mapper
that maps text values into Tool
s.FileChannel.transferTo(long, long, WritableByteChannel)
.
void
methods, or by
re-throwing the exception for non-void
methods.
Writable
s.charToEscape
in the string
with the escape char escapeChar
Writable
abstract class for storing user and groups information.S3FileSystem
.VersionedWritable.readFields(DataInput)
when the
version of an object being read does not match the current implementation
version as returned by VersionedWritable.getVersion()
.DataInput
and DataOutput
.Writable
which is also Comparable
.WritableComparable
s.WritableComparable
implementation.
Serialization
for Writable
s that delegates to
Writable.write(java.io.DataOutput)
and
Writable.readFields(java.io.DataInput)
.OutputStream
.
out
.
out
.
out
.
len
bytes from the specified byte array
starting at offset off
and generate a checksum for
each data chunk.
out
.
out
.
PermissionStatus
from its base components.
out
.
out
.
out
.
out
.
out
.
CompressedWritable.write(DataOutput)
.
Writable
, String
, primitive type, or an array of
the preceding.
Compressor
based on the popular
zlib compression algorithm.Decompressor
based on the popular
zlib compression algorithm.
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |