Modifier and Type | Field and Description |
---|---|
protected Text |
DataJoinMapperBase.inputTag |
static Text |
DataJoinReducerBase.NUM_OF_VALUES_FIELD |
static Text |
DataJoinReducerBase.SOURCE_TAGS_FIELD |
protected Text |
TaggedMapOutput.tag |
Modifier and Type | Method and Description |
---|---|
protected abstract Text |
DataJoinMapperBase.generateGroupKey(TaggedMapOutput aRecord)
Generate a map output key.
|
protected abstract Text |
DataJoinMapperBase.generateInputTag(String inputFile)
Determine the source tag based on the input file name.
|
Text |
TaggedMapOutput.getTag() |
Modifier and Type | Method and Description |
---|---|
void |
TaggedMapOutput.setTag(Text tag) |
Modifier and Type | Method and Description |
---|---|
Text |
MultiFileWordCount.CombineFileLineRecordReader.getCurrentValue() |
Modifier and Type | Method and Description |
---|---|
RecordReader<MultiFileWordCount.WordOffset,Text> |
MultiFileWordCount.MyInputFormat.createRecordReader(InputSplit split,
TaskAttemptContext context) |
ArrayList<Map.Entry<Text,Text>> |
AggregateWordHistogram.AggregateWordHistogramPlugin.generateKeyValPairs(Object key,
Object val)
Parse the given value, generate an aggregation-id/value pair per word.
|
ArrayList<Map.Entry<Text,Text>> |
AggregateWordHistogram.AggregateWordHistogramPlugin.generateKeyValPairs(Object key,
Object val)
Parse the given value, generate an aggregation-id/value pair per word.
|
ArrayList<Map.Entry<Text,Text>> |
AggregateWordCount.WordCountPlugInClass.generateKeyValPairs(Object key,
Object val) |
ArrayList<Map.Entry<Text,Text>> |
AggregateWordCount.WordCountPlugInClass.generateKeyValPairs(Object key,
Object val) |
Modifier and Type | Method and Description |
---|---|
void |
SecondarySort.MapClass.map(LongWritable inKey,
Text inValue,
Mapper.Context context) |
void |
MultiFileWordCount.MapClass.map(MultiFileWordCount.WordOffset key,
Text value,
Mapper.Context context) |
void |
WordMedian.WordMedianMapper.map(Object key,
Text value,
Mapper.Context context)
Emits a key-value pair for counting the word.
|
void |
WordCount.TokenizerMapper.map(Object key,
Text value,
Mapper.Context context) |
void |
WordMean.WordMeanMapper.map(Object key,
Text value,
Mapper.Context context)
Emits 2 key-value pairs for counting the word and its length.
|
void |
WordStandardDeviation.WordStandardDeviationMapper.map(Object key,
Text value,
Mapper.Context context)
Emits 3 key-value pairs for counting the word, its length, and the
squares of its length.
|
void |
WordCount.IntSumReducer.reduce(Text key,
Iterable<IntWritable> values,
Reducer.Context context) |
void |
WordMean.WordMeanReducer.reduce(Text key,
Iterable<LongWritable> values,
Reducer.Context context)
Sums all the individual values within the iterator and writes them to the
same key.
|
void |
WordStandardDeviation.WordStandardDeviationReducer.reduce(Text key,
Iterable<LongWritable> values,
Reducer.Context context)
Sums all the individual values within the iterator and writes them to the
same key.
|
Modifier and Type | Method and Description |
---|---|
void |
DistributedPentomino.PentMap.map(WritableComparable<?> key,
Text value,
Mapper.Context context)
Break the prefix string into moves (a sequence of integer row ids that
will be selected for each column in order).
|
Modifier and Type | Method and Description |
---|---|
RecordReader<Text,Text> |
TeraInputFormat.createRecordReader(InputSplit split,
TaskAttemptContext context) |
RecordReader<Text,Text> |
TeraInputFormat.createRecordReader(InputSplit split,
TaskAttemptContext context) |
RecordWriter<Text,Text> |
TeraOutputFormat.getRecordWriter(TaskAttemptContext job) |
RecordWriter<Text,Text> |
TeraOutputFormat.getRecordWriter(TaskAttemptContext job) |
Modifier and Type | Method and Description |
---|---|
int |
TeraSort.SimplePartitioner.getPartition(Text key,
Text value,
int numPartitions) |
Modifier and Type | Field and Description |
---|---|
static Text |
HftpFileSystem.TOKEN_KIND |
Modifier and Type | Method and Description |
---|---|
static Text |
HAUtil.buildTokenServiceForLogicalUri(URI uri)
Get the service name used in the delegation token for the given logical
HA service.
|
Text |
NameNodeProxies.ProxyAndInfo.getDelegationTokenService() |
Modifier and Type | Method and Description |
---|---|
Token<DelegationTokenIdentifier> |
DistributedFileSystem.getDelegationToken(Text renewer)
Deprecated.
|
Token<DelegationTokenIdentifier> |
DFSClient.getDelegationToken(Text renewer) |
boolean |
HftpFileSystem.TokenManager.handleKind(Text kind) |
boolean |
DFSClient.Renewer.handleKind(Text kind) |
Constructor and Description |
---|
NameNodeProxies.ProxyAndInfo(PROXYTYPE proxy,
Text dtService) |
Modifier and Type | Method and Description |
---|---|
Token<DelegationTokenIdentifier> |
ClientProtocol.getDelegationToken(Text renewer)
Get a valid Delegation Token.
|
Modifier and Type | Method and Description |
---|---|
Token<DelegationTokenIdentifier> |
ClientNamenodeProtocolTranslatorPB.getDelegationToken(Text renewer) |
Modifier and Type | Method and Description |
---|---|
Text |
BlockTokenIdentifier.getKind() |
protected Text |
BlockTokenIdentifier.Renewer.getKind() |
Modifier and Type | Method and Description |
---|---|
Token<BlockTokenIdentifier> |
BlockTokenSelector.selectToken(Text service,
Collection<Token<? extends TokenIdentifier>> tokens) |
Modifier and Type | Field and Description |
---|---|
static Text |
DelegationTokenIdentifier.HDFS_DELEGATION_KIND |
Modifier and Type | Method and Description |
---|---|
Text |
DelegationTokenIdentifier.getKind() |
Constructor and Description |
---|
DelegationTokenIdentifier(Text owner,
Text renewer,
Text realUser)
Create a new delegation token identifier
|
Modifier and Type | Field and Description |
---|---|
static Text |
WebHdfsFileSystem.TOKEN_KIND
Delegation token kind
|
Modifier and Type | Method and Description |
---|---|
boolean |
WebHdfsFileSystem.DtRenewer.handleKind(Text kind) |
Modifier and Type | Method and Description |
---|---|
Text |
SequenceFile.Metadata.get(Text name) |
Modifier and Type | Method and Description |
---|---|
TreeMap<Text,Text> |
SequenceFile.Metadata.getMetadata() |
TreeMap<Text,Text> |
SequenceFile.Metadata.getMetadata() |
Modifier and Type | Method and Description |
---|---|
Text |
SequenceFile.Metadata.get(Text name) |
void |
Text.set(Text other)
copy a text.
|
void |
SequenceFile.Metadata.set(Text name,
Text value) |
Constructor and Description |
---|
Text(Text utf8)
Construct from another text.
|
Constructor and Description |
---|
SequenceFile.Metadata(TreeMap<Text,Text> arg) |
SequenceFile.Metadata(TreeMap<Text,Text> arg) |
Modifier and Type | Field and Description |
---|---|
static Text |
DelegationTokenIdentifier.KIND_NAME |
Modifier and Type | Method and Description |
---|---|
Text |
DelegationTokenIdentifier.getKind()
Returns the kind,
TOKEN_KIND . |
Constructor and Description |
---|
DelegationTokenIdentifier(Text owner,
Text renewer,
Text realUser)
Create a new delegation token identifier
|
Modifier and Type | Method and Description |
---|---|
Text |
KeyValueLineRecordReader.createKey() |
Text |
SequenceFileAsTextRecordReader.createKey() |
Text |
KeyValueLineRecordReader.createValue() |
Text |
SequenceFileAsTextRecordReader.createValue() |
Text |
LineRecordReader.createValue() |
Modifier and Type | Method and Description |
---|---|
RecordReader<LongWritable,Text> |
TextInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
RecordReader<Text,Text> |
SequenceFileAsTextInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
RecordReader<Text,Text> |
SequenceFileAsTextInputFormat.getRecordReader(InputSplit split,
JobConf job,
Reporter reporter) |
RecordReader<Text,Text> |
KeyValueTextInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
RecordReader<Text,Text> |
KeyValueTextInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
Modifier and Type | Method and Description |
---|---|
Token<DelegationTokenIdentifier> |
YARNRunner.getDelegationToken(Text renewer) |
Token |
ResourceMgrDelegate.getDelegationToken(Text renewer) |
Token<DelegationTokenIdentifier> |
LocalJobRunner.getDelegationToken(Text renewer) |
Token<DelegationTokenIdentifier> |
JobClient.getDelegationToken(Text renewer)
Get a delegation token for the user from the JobTracker.
|
Token |
ResourceMgrDelegate.getRMDelegationToken(Text renewer) |
boolean |
LineRecordReader.next(LongWritable key,
Text value)
Read a line.
|
boolean |
KeyValueLineRecordReader.next(Text key,
Text value)
Read key/value pair in a line.
|
boolean |
SequenceFileAsTextRecordReader.next(Text key,
Text value)
Read key/value pair in a line.
|
Modifier and Type | Method and Description |
---|---|
RecordReader<LongWritable,Text> |
CombineTextInputFormat.getRecordReader(InputSplit split,
JobConf conf,
Reporter reporter) |
RecordReader<LongWritable,Text> |
NLineInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
Modifier and Type | Method and Description |
---|---|
void |
RegexMapper.map(K key,
Text value,
OutputCollector<Text,LongWritable> output,
Reporter reporter) |
void |
TokenCountMapper.map(K key,
Text value,
OutputCollector<Text,LongWritable> output,
Reporter reporter) |
void |
FieldSelectionMapReduce.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter) |
Modifier and Type | Method and Description |
---|---|
void |
RegexMapper.map(K key,
Text value,
OutputCollector<Text,LongWritable> output,
Reporter reporter) |
void |
TokenCountMapper.map(K key,
Text value,
OutputCollector<Text,LongWritable> output,
Reporter reporter) |
void |
FieldSelectionMapReduce.map(K key,
V val,
OutputCollector<Text,Text> output,
Reporter reporter)
The identify function.
|
void |
FieldSelectionMapReduce.map(K key,
V val,
OutputCollector<Text,Text> output,
Reporter reporter)
The identify function.
|
void |
FieldSelectionMapReduce.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter) |
void |
FieldSelectionMapReduce.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter) |
void |
FieldSelectionMapReduce.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter) |
Modifier and Type | Field and Description |
---|---|
static Text |
ValueAggregatorDescriptor.ONE |
Modifier and Type | Method and Description |
---|---|
static Map.Entry<Text,Text> |
ValueAggregatorBaseDescriptor.generateEntry(String type,
String id,
Text val) |
static Map.Entry<Text,Text> |
ValueAggregatorBaseDescriptor.generateEntry(String type,
String id,
Text val) |
Modifier and Type | Method and Description |
---|---|
static Map.Entry<Text,Text> |
ValueAggregatorBaseDescriptor.generateEntry(String type,
String id,
Text val) |
void |
ValueAggregatorCombiner.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter)
Combines values for a given key.
|
void |
ValueAggregatorMapper.reduce(Text arg0,
Iterator<Text> arg1,
OutputCollector<Text,Text> arg2,
Reporter arg3)
Do nothing.
|
void |
ValueAggregatorReducer.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter) |
Modifier and Type | Method and Description |
---|---|
void |
ValueAggregatorCombiner.map(K1 arg0,
V1 arg1,
OutputCollector<Text,Text> arg2,
Reporter arg3)
Do nothing.
|
void |
ValueAggregatorCombiner.map(K1 arg0,
V1 arg1,
OutputCollector<Text,Text> arg2,
Reporter arg3)
Do nothing.
|
void |
ValueAggregatorMapper.map(K1 key,
V1 value,
OutputCollector<Text,Text> output,
Reporter reporter)
the map function.
|
void |
ValueAggregatorMapper.map(K1 key,
V1 value,
OutputCollector<Text,Text> output,
Reporter reporter)
the map function.
|
void |
ValueAggregatorReducer.map(K1 arg0,
V1 arg1,
OutputCollector<Text,Text> arg2,
Reporter arg3)
Do nothing.
|
void |
ValueAggregatorReducer.map(K1 arg0,
V1 arg1,
OutputCollector<Text,Text> arg2,
Reporter arg3)
Do nothing.
|
void |
ValueAggregatorCombiner.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter)
Combines values for a given key.
|
void |
ValueAggregatorCombiner.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter)
Combines values for a given key.
|
void |
ValueAggregatorCombiner.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter)
Combines values for a given key.
|
void |
ValueAggregatorMapper.reduce(Text arg0,
Iterator<Text> arg1,
OutputCollector<Text,Text> arg2,
Reporter arg3)
Do nothing.
|
void |
ValueAggregatorMapper.reduce(Text arg0,
Iterator<Text> arg1,
OutputCollector<Text,Text> arg2,
Reporter arg3)
Do nothing.
|
void |
ValueAggregatorMapper.reduce(Text arg0,
Iterator<Text> arg1,
OutputCollector<Text,Text> arg2,
Reporter arg3)
Do nothing.
|
void |
ValueAggregatorReducer.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter) |
void |
ValueAggregatorReducer.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter) |
void |
ValueAggregatorReducer.reduce(Text key,
Iterator<Text> values,
OutputCollector<Text,Text> output,
Reporter reporter) |
Modifier and Type | Method and Description |
---|---|
Token<DelegationTokenIdentifier> |
Cluster.getDelegationToken(Text renewer)
Get a delegation token for the user from the JobTracker.
|
Modifier and Type | Field and Description |
---|---|
static Text |
ValueAggregatorDescriptor.ONE |
Modifier and Type | Method and Description |
---|---|
static Map.Entry<Text,Text> |
ValueAggregatorBaseDescriptor.generateEntry(String type,
String id,
Text val) |
static Map.Entry<Text,Text> |
ValueAggregatorBaseDescriptor.generateEntry(String type,
String id,
Text val) |
ArrayList<Map.Entry<Text,Text>> |
ValueAggregatorDescriptor.generateKeyValPairs(Object key,
Object val)
Generate a list of aggregation-id/value pairs for
the given key/value pair.
|
ArrayList<Map.Entry<Text,Text>> |
ValueAggregatorDescriptor.generateKeyValPairs(Object key,
Object val)
Generate a list of aggregation-id/value pairs for
the given key/value pair.
|
ArrayList<Map.Entry<Text,Text>> |
ValueAggregatorBaseDescriptor.generateKeyValPairs(Object key,
Object val)
Generate 1 or 2 aggregation-id/value pairs for the given key/value pair.
|
ArrayList<Map.Entry<Text,Text>> |
ValueAggregatorBaseDescriptor.generateKeyValPairs(Object key,
Object val)
Generate 1 or 2 aggregation-id/value pairs for the given key/value pair.
|
ArrayList<Map.Entry<Text,Text>> |
UserDefinedValueAggregatorDescriptor.generateKeyValPairs(Object key,
Object val)
Generate a list of aggregation-id/value pairs for the given
key/value pairs by delegating the invocation to the real object.
|
ArrayList<Map.Entry<Text,Text>> |
UserDefinedValueAggregatorDescriptor.generateKeyValPairs(Object key,
Object val)
Generate a list of aggregation-id/value pairs for the given
key/value pairs by delegating the invocation to the real object.
|
Modifier and Type | Method and Description |
---|---|
static Map.Entry<Text,Text> |
ValueAggregatorBaseDescriptor.generateEntry(String type,
String id,
Text val) |
void |
ValueAggregatorCombiner.reduce(Text key,
Iterable<Text> values,
Reducer.Context context)
Combines values for a given key.
|
void |
ValueAggregatorReducer.reduce(Text key,
Iterable<Text> values,
Reducer.Context context) |
Modifier and Type | Method and Description |
---|---|
void |
ValueAggregatorCombiner.reduce(Text key,
Iterable<Text> values,
Reducer.Context context)
Combines values for a given key.
|
void |
ValueAggregatorReducer.reduce(Text key,
Iterable<Text> values,
Reducer.Context context) |
Modifier and Type | Field and Description |
---|---|
static Text |
FieldSelectionHelper.emptyText |
Modifier and Type | Method and Description |
---|---|
Text |
FieldSelectionHelper.getKey() |
Text |
FieldSelectionHelper.getValue() |
Modifier and Type | Method and Description |
---|---|
void |
FieldSelectionReducer.reduce(Text key,
Iterable<Text> values,
Reducer.Context context) |
Modifier and Type | Method and Description |
---|---|
void |
FieldSelectionReducer.reduce(Text key,
Iterable<Text> values,
Reducer.Context context) |
Constructor and Description |
---|
FieldSelectionHelper(Text key,
Text val) |
Modifier and Type | Method and Description |
---|---|
Text |
KeyValueLineRecordReader.getCurrentKey() |
Text |
SequenceFileAsTextRecordReader.getCurrentKey() |
Text |
KeyValueLineRecordReader.getCurrentValue() |
Text |
SequenceFileAsTextRecordReader.getCurrentValue() |
Text |
LineRecordReader.getCurrentValue() |
Modifier and Type | Method and Description |
---|---|
RecordReader<LongWritable,Text> |
TextInputFormat.createRecordReader(InputSplit split,
TaskAttemptContext context) |
RecordReader<LongWritable,Text> |
CombineTextInputFormat.createRecordReader(InputSplit split,
TaskAttemptContext context) |
RecordReader<LongWritable,Text> |
NLineInputFormat.createRecordReader(InputSplit genericSplit,
TaskAttemptContext context) |
RecordReader<Text,Text> |
SequenceFileAsTextInputFormat.createRecordReader(InputSplit split,
TaskAttemptContext context) |
RecordReader<Text,Text> |
SequenceFileAsTextInputFormat.createRecordReader(InputSplit split,
TaskAttemptContext context) |
RecordReader<Text,Text> |
KeyValueTextInputFormat.createRecordReader(InputSplit genericSplit,
TaskAttemptContext context) |
RecordReader<Text,Text> |
KeyValueTextInputFormat.createRecordReader(InputSplit genericSplit,
TaskAttemptContext context) |
Modifier and Type | Method and Description |
---|---|
static void |
KeyValueLineRecordReader.setKeyValue(Text key,
Text value,
byte[] line,
int lineLen,
int pos) |
Modifier and Type | Method and Description |
---|---|
void |
RegexMapper.map(K key,
Text value,
Mapper.Context context) |
void |
TokenCounterMapper.map(Object key,
Text value,
Mapper.Context context) |
Modifier and Type | Method and Description |
---|---|
Token<DelegationTokenIdentifier> |
ClientProtocol.getDelegationToken(Text renewer)
Get a new delegation token.
|
Modifier and Type | Method and Description |
---|---|
static byte[] |
TokenCache.getSecretKey(Credentials credentials,
Text alias)
auxiliary method to get user's secret keys..
|
Modifier and Type | Field and Description |
---|---|
static Text |
JobTokenIdentifier.KIND_NAME |
Modifier and Type | Method and Description |
---|---|
Text |
JobTokenIdentifier.getJobId()
Get the jobid
|
Text |
JobTokenIdentifier.getKind()
Get the token kind
|
protected Text |
JobTokenIdentifier.Renewer.getKind() |
Modifier and Type | Method and Description |
---|---|
Token<JobTokenIdentifier> |
JobTokenSelector.selectToken(Text service,
Collection<Token<? extends TokenIdentifier>> tokens) |
Constructor and Description |
---|
JobTokenIdentifier(Text jobid)
Create a job token identifier from a jobid
|
Modifier and Type | Field and Description |
---|---|
static Text |
DelegationTokenIdentifier.MAPREDUCE_DELEGATION_KIND |
Modifier and Type | Method and Description |
---|---|
Text |
DelegationTokenIdentifier.getKind() |
Constructor and Description |
---|
DelegationTokenIdentifier(Text owner,
Text renewer,
Text realUser)
Create a new delegation token identifier
|
Modifier and Type | Field and Description |
---|---|
static Text |
MRDelegationTokenIdentifier.KIND_NAME |
Modifier and Type | Method and Description |
---|---|
Text |
MRDelegationTokenIdentifier.getKind() |
protected Text |
MRDelegationTokenIdentifier.Renewer.getKind() |
Constructor and Description |
---|
MRDelegationTokenIdentifier(Text owner,
Text renewer,
Text realUser)
Create a new delegation token identifier
|
Modifier and Type | Method and Description |
---|---|
boolean |
MRDelegationTokenRenewer.handleKind(Text kind) |
Modifier and Type | Method and Description |
---|---|
Token<MRDelegationTokenIdentifier> |
ClientHSTokenSelector.selectToken(Text service,
Collection<Token<? extends TokenIdentifier>> tokens) |
Modifier and Type | Method and Description |
---|---|
static Text |
SecurityUtil.buildTokenService(InetSocketAddress addr)
Construct the service key for a token
|
static Text |
SecurityUtil.buildTokenService(URI uri)
Construct the service key for a token
|
Modifier and Type | Method and Description |
---|---|
void |
Credentials.addSecretKey(Text alias,
byte[] key)
Set the key for an alias
|
boolean |
UserGroupInformation.addToken(Text alias,
Token<? extends TokenIdentifier> token)
Add a named token to this UGI
|
void |
Credentials.addToken(Text alias,
Token<? extends TokenIdentifier> t)
Add a token in the storage (in memory)
|
byte[] |
Credentials.getSecretKey(Text alias)
Returns the key bytes for the alias
|
Token<? extends TokenIdentifier> |
Credentials.getToken(Text alias)
Returns the Token object for the alias
|
Modifier and Type | Method and Description |
---|---|
abstract Text |
TokenIdentifier.getKind()
Get the token kind
|
Text |
Token.getKind()
Get the token kind
|
protected Text |
Token.TrivialRenewer.getKind() |
Text |
Token.getService()
Get the service on which the token is supposed to be used
|
Modifier and Type | Method and Description |
---|---|
abstract boolean |
TokenRenewer.handleKind(Text kind)
Does this renewer handle this kind of token?
|
boolean |
Token.TrivialRenewer.handleKind(Text kind) |
Token<T> |
TokenSelector.selectToken(Text service,
Collection<Token<? extends TokenIdentifier>> tokens) |
void |
Token.setKind(Text newKind)
Set the token kind.
|
void |
Token.setService(Text newService)
Set the service on which the token is supposed to be used
|
Constructor and Description |
---|
Token(byte[] identifier,
byte[] password,
Text kind,
Text service)
Construct a token from the components.
|
Modifier and Type | Method and Description |
---|---|
abstract Text |
AbstractDelegationTokenIdentifier.getKind() |
Text |
AbstractDelegationTokenIdentifier.getOwner() |
Text |
AbstractDelegationTokenIdentifier.getRealUser() |
Text |
AbstractDelegationTokenIdentifier.getRenewer() |
Modifier and Type | Method and Description |
---|---|
Token<TokenIdent> |
AbstractDelegationTokenSelector.selectToken(Text service,
Collection<Token<? extends TokenIdentifier>> tokens) |
Constructor and Description |
---|
AbstractDelegationTokenIdentifier(Text owner,
Text renewer,
Text realUser) |
AbstractDelegationTokenSelector(Text kindName) |
Modifier and Type | Method and Description |
---|---|
Text |
StreamBaseRecordReader.createKey() |
Text |
StreamBaseRecordReader.createValue() |
Modifier and Type | Method and Description |
---|---|
RecordReader<Text,Text> |
StreamInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
RecordReader<Text,Text> |
StreamInputFormat.getRecordReader(InputSplit genericSplit,
JobConf job,
Reporter reporter) |
Modifier and Type | Method and Description |
---|---|
boolean |
StreamXmlRecordReader.next(Text key,
Text value) |
abstract boolean |
StreamBaseRecordReader.next(Text key,
Text value)
Read a record.
|
static int |
StreamKeyValUtil.readLine(LineReader lineReader,
Text out)
Read a utf8 encoded line from a data input stream.
|
static void |
StreamKeyValUtil.splitKeyVal(byte[] utf,
int start,
int length,
Text key,
Text val,
int splitPos)
split a UTF-8 byte array into key and value
assuming that the delimilator is at splitpos.
|
static void |
StreamKeyValUtil.splitKeyVal(byte[] utf,
int start,
int length,
Text key,
Text val,
int splitPos,
int separatorLength)
split a UTF-8 byte array into key and value
assuming that the delimilator is at splitpos.
|
static void |
StreamKeyValUtil.splitKeyVal(byte[] utf,
Text key,
Text val,
int splitPos)
split a UTF-8 byte array into key and value
assuming that the delimilator is at splitpos.
|
static void |
StreamKeyValUtil.splitKeyVal(byte[] utf,
Text key,
Text val,
int splitPos,
int separatorLength)
split a UTF-8 byte array into key and value
assuming that the delimilator is at splitpos.
|
Modifier and Type | Method and Description |
---|---|
Text |
TextOutputReader.getCurrentKey() |
Text |
TextOutputReader.getCurrentValue() |
Modifier and Type | Method and Description |
---|---|
void |
Logalyzer.LogRegexMapper.map(K key,
Text value,
OutputCollector<Text,LongWritable> output,
Reporter reporter) |
Modifier and Type | Method and Description |
---|---|
void |
Logalyzer.LogRegexMapper.map(K key,
Text value,
OutputCollector<Text,LongWritable> output,
Reporter reporter) |
Modifier and Type | Method and Description |
---|---|
RecordReader<Text,FileStatus> |
UniformSizeInputFormat.createRecordReader(InputSplit split,
TaskAttemptContext context)
Implementation of InputFormat::createRecordReader().
|
Modifier and Type | Method and Description |
---|---|
void |
CopyMapper.map(Text relPath,
FileStatus sourceFileStatus,
Mapper.Context context)
Implementation of the Mapper<>::map().
|
Modifier and Type | Method and Description |
---|---|
Text |
TypedBytesWritableInput.readText() |
Text |
TypedBytesWritableInput.readText(Text t) |
Modifier and Type | Method and Description |
---|---|
Text |
TypedBytesWritableInput.readText(Text t) |
void |
TypedBytesWritableOutput.writeText(Text t) |
Modifier and Type | Method and Description |
---|---|
int |
LineReader.readLine(Text str)
Read from the InputStream into the given Text.
|
int |
LineReader.readLine(Text str,
int maxLineLength)
Read from the InputStream into the given Text.
|
int |
LineReader.readLine(Text str,
int maxLineLength,
int maxBytesToConsume)
Read one line from the InputStream into the given Text.
|
Modifier and Type | Method and Description |
---|---|
abstract Token |
YarnClient.getRMDelegationToken(Text renewer)
Get a delegation token so as to be able to talk to YARN using those tokens.
|
Modifier and Type | Method and Description |
---|---|
Token |
YarnClientImpl.getRMDelegationToken(Text renewer) |
Modifier and Type | Field and Description |
---|---|
static Text |
NMTokenIdentifier.KIND |
static Text |
ContainerTokenIdentifier.KIND |
static Text |
AMRMTokenIdentifier.KIND_NAME |
Modifier and Type | Method and Description |
---|---|
Text |
NMTokenIdentifier.getKind() |
Text |
ContainerTokenIdentifier.getKind() |
protected Text |
ContainerTokenIdentifier.Renewer.getKind() |
Text |
AMRMTokenIdentifier.getKind() |
protected Text |
AMRMTokenIdentifier.Renewer.getKind() |
Modifier and Type | Method and Description |
---|---|
Token<ContainerTokenIdentifier> |
ContainerTokenSelector.selectToken(Text service,
Collection<Token<? extends TokenIdentifier>> tokens) |
Token<NMTokenIdentifier> |
NMTokenSelector.selectToken(Text service,
Collection<Token<? extends TokenIdentifier>> tokens) |
Token<AMRMTokenIdentifier> |
AMRMTokenSelector.selectToken(Text service,
Collection<Token<? extends TokenIdentifier>> tokens) |
Modifier and Type | Field and Description |
---|---|
static Text |
RMDelegationTokenIdentifier.KIND_NAME |
static Text |
ClientToAMTokenIdentifier.KIND_NAME |
Modifier and Type | Method and Description |
---|---|
Text |
RMDelegationTokenIdentifier.getKind() |
Text |
ClientToAMTokenIdentifier.getKind() |
protected Text |
ClientToAMTokenIdentifier.Renewer.getKind() |
Modifier and Type | Method and Description |
---|---|
boolean |
RMDelegationTokenIdentifier.Renewer.handleKind(Text kind) |
Token<RMDelegationTokenIdentifier> |
RMDelegationTokenSelector.selectToken(Text service,
Collection<Token<? extends TokenIdentifier>> tokens) |
Token<ClientToAMTokenIdentifier> |
ClientToAMTokenSelector.selectToken(Text service,
Collection<Token<? extends TokenIdentifier>> tokens) |
Constructor and Description |
---|
RMDelegationTokenIdentifier(Text owner,
Text renewer,
Text realUser)
Create a new delegation token identifier
|
Modifier and Type | Field and Description |
---|---|
static Text |
LocalizerTokenIdentifier.KIND |
Modifier and Type | Method and Description |
---|---|
Text |
LocalizerTokenIdentifier.getKind() |
Modifier and Type | Method and Description |
---|---|
Token<LocalizerTokenIdentifier> |
LocalizerTokenSelector.selectToken(Text service,
Collection<Token<? extends TokenIdentifier>> tokens) |
Modifier and Type | Field and Description |
---|---|
static Text |
RMStateStore.AM_CLIENT_TOKEN_MASTER_KEY_NAME |
static Text |
RMStateStore.AM_RM_TOKEN_SERVICE |
Copyright © 2013 Apache Software Foundation. All rights reserved.