Uses of Class
org.apache.hadoop.io.Text

Packages that use Text
org.apache.hadoop.io Generic i/o code for use when reading and writing data to the network, to databases, and to files. 
org.apache.hadoop.mapred   
org.apache.hadoop.mapred.lib   
org.apache.hadoop.mapred.lib.aggregate   
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.lib.aggregate   
org.apache.hadoop.mapreduce.lib.fieldsel   
org.apache.hadoop.mapreduce.lib.input   
org.apache.hadoop.mapreduce.lib.map   
org.apache.hadoop.mapreduce.security   
org.apache.hadoop.yarn.client   
org.apache.hadoop.yarn.client.api   
org.apache.hadoop.yarn.security   
org.apache.hadoop.yarn.security.client   
org.apache.hadoop.yarn.util.timeline   
 

Uses of Text in org.apache.hadoop.io
 

Methods in org.apache.hadoop.io with parameters of type Text
 void Text.set(Text other)
          copy a text.
 

Constructors in org.apache.hadoop.io with parameters of type Text
Text(Text utf8)
          Construct from another text.
 

Uses of Text in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred that return Text
 Text SequenceFileAsTextRecordReader.createKey()
           
 Text KeyValueLineRecordReader.createKey()
           
 Text SequenceFileAsTextRecordReader.createValue()
           
 Text KeyValueLineRecordReader.createValue()
           
 

Methods in org.apache.hadoop.mapred that return types with arguments of type Text
 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)
           
 

Methods in org.apache.hadoop.mapred with parameters of type Text
 org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> JobClient.getDelegationToken(Text renewer)
          Get a delegation token for the user from the JobTracker.
 boolean SequenceFileAsTextRecordReader.next(Text key, Text value)
          Read key/value pair in a line.
 boolean KeyValueLineRecordReader.next(Text key, Text value)
          Read key/value pair in a line.
 

Uses of Text in org.apache.hadoop.mapred.lib
 

Methods in org.apache.hadoop.mapred.lib that return types with arguments of type Text
 RecordReader<LongWritable,Text> CombineTextInputFormat.getRecordReader(InputSplit split, JobConf conf, Reporter reporter)
           
 RecordReader<LongWritable,Text> NLineInputFormat.getRecordReader(InputSplit genericSplit, JobConf job, Reporter reporter)
           
 

Methods in org.apache.hadoop.mapred.lib with parameters of type Text
 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)
           
 

Method parameters in org.apache.hadoop.mapred.lib with type arguments of type Text
 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)
           
 

Uses of Text in org.apache.hadoop.mapred.lib.aggregate
 

Fields in org.apache.hadoop.mapred.lib.aggregate declared as Text
static Text ValueAggregatorDescriptor.ONE
           
 

Methods in org.apache.hadoop.mapred.lib.aggregate that return types with arguments of type Text
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)
           
 

Methods in org.apache.hadoop.mapred.lib.aggregate with parameters of type Text
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 ValueAggregatorReducer.reduce(Text key, Iterator<Text> values, OutputCollector<Text,Text> output, Reporter reporter)
           
 void ValueAggregatorMapper.reduce(Text arg0, Iterator<Text> arg1, OutputCollector<Text,Text> arg2, Reporter arg3)
          Do nothing.
 

Method parameters in org.apache.hadoop.mapred.lib.aggregate with type arguments of type Text
 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 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 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 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 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)
           
 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.
 

Uses of Text in org.apache.hadoop.mapreduce
 

Methods in org.apache.hadoop.mapreduce with parameters of type Text
 org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> Cluster.getDelegationToken(Text renewer)
          Get a delegation token for the user from the JobTracker.
 

Uses of Text in org.apache.hadoop.mapreduce.lib.aggregate
 

Fields in org.apache.hadoop.mapreduce.lib.aggregate declared as Text
static Text ValueAggregatorDescriptor.ONE
           
 

Methods in org.apache.hadoop.mapreduce.lib.aggregate that return types with arguments of type Text
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>> 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.
 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.
 

Methods in org.apache.hadoop.mapreduce.lib.aggregate with parameters of type Text
static Map.Entry<Text,Text> ValueAggregatorBaseDescriptor.generateEntry(String type, String id, Text val)
           
 void ValueAggregatorCombiner.reduce(Text key, Iterable<Text> values, org.apache.hadoop.mapreduce.Reducer.Context context)
          Combines values for a given key.
 void ValueAggregatorReducer.reduce(Text key, Iterable<Text> values, org.apache.hadoop.mapreduce.Reducer.Context context)
           
 

Method parameters in org.apache.hadoop.mapreduce.lib.aggregate with type arguments of type Text
 void ValueAggregatorCombiner.reduce(Text key, Iterable<Text> values, org.apache.hadoop.mapreduce.Reducer.Context context)
          Combines values for a given key.
 void ValueAggregatorReducer.reduce(Text key, Iterable<Text> values, org.apache.hadoop.mapreduce.Reducer.Context context)
           
 

Uses of Text in org.apache.hadoop.mapreduce.lib.fieldsel
 

Fields in org.apache.hadoop.mapreduce.lib.fieldsel declared as Text
static Text FieldSelectionHelper.emptyText
           
 

Methods in org.apache.hadoop.mapreduce.lib.fieldsel that return Text
 Text FieldSelectionHelper.getKey()
           
 Text FieldSelectionHelper.getValue()
           
 

Methods in org.apache.hadoop.mapreduce.lib.fieldsel with parameters of type Text
 void FieldSelectionReducer.reduce(Text key, Iterable<Text> values, org.apache.hadoop.mapreduce.Reducer.Context context)
           
 

Method parameters in org.apache.hadoop.mapreduce.lib.fieldsel with type arguments of type Text
 void FieldSelectionReducer.reduce(Text key, Iterable<Text> values, org.apache.hadoop.mapreduce.Reducer.Context context)
           
 

Constructors in org.apache.hadoop.mapreduce.lib.fieldsel with parameters of type Text
FieldSelectionHelper(Text key, Text val)
           
 

Uses of Text in org.apache.hadoop.mapreduce.lib.input
 

Methods in org.apache.hadoop.mapreduce.lib.input that return Text
 Text SequenceFileAsTextRecordReader.getCurrentKey()
           
 Text KeyValueLineRecordReader.getCurrentKey()
           
 Text SequenceFileAsTextRecordReader.getCurrentValue()
           
 Text KeyValueLineRecordReader.getCurrentValue()
           
 

Methods in org.apache.hadoop.mapreduce.lib.input that return types with arguments of type Text
 RecordReader<LongWritable,Text> TextInputFormat.createRecordReader(InputSplit split, 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)
           
 RecordReader<LongWritable,Text> CombineTextInputFormat.createRecordReader(InputSplit split, TaskAttemptContext context)
           
 RecordReader<LongWritable,Text> NLineInputFormat.createRecordReader(InputSplit genericSplit, TaskAttemptContext context)
           
 

Methods in org.apache.hadoop.mapreduce.lib.input with parameters of type Text
static void KeyValueLineRecordReader.setKeyValue(Text key, Text value, byte[] line, int lineLen, int pos)
           
 

Uses of Text in org.apache.hadoop.mapreduce.lib.map
 

Methods in org.apache.hadoop.mapreduce.lib.map with parameters of type Text
 void RegexMapper.map(K key, Text value, org.apache.hadoop.mapreduce.Mapper.Context context)
           
 void TokenCounterMapper.map(Object key, Text value, org.apache.hadoop.mapreduce.Mapper.Context context)
           
 

Uses of Text in org.apache.hadoop.mapreduce.security
 

Methods in org.apache.hadoop.mapreduce.security with parameters of type Text
static byte[] TokenCache.getSecretKey(org.apache.hadoop.security.Credentials credentials, Text alias)
          auxiliary method to get user's secret keys..
 

Uses of Text in org.apache.hadoop.yarn.client
 

Methods in org.apache.hadoop.yarn.client that return Text
static Text ClientRMProxy.getRMDelegationTokenService(Configuration conf)
          Get the token service name to be used for RMDelegationToken.
 

Uses of Text in org.apache.hadoop.yarn.client.api
 

Methods in org.apache.hadoop.yarn.client.api with parameters of type Text
abstract  Token YarnClient.getRMDelegationToken(Text renewer)
           Get a delegation token so as to be able to talk to YARN using those tokens.
 

Uses of Text in org.apache.hadoop.yarn.security
 

Fields in org.apache.hadoop.yarn.security declared as Text
static Text NMTokenIdentifier.KIND
           
static Text ContainerTokenIdentifier.KIND
           
static Text AMRMTokenIdentifier.KIND_NAME
           
 

Methods in org.apache.hadoop.yarn.security that return Text
 Text NMTokenIdentifier.getKind()
           
 Text ContainerTokenIdentifier.getKind()
           
 Text AMRMTokenIdentifier.getKind()
           
 

Methods in org.apache.hadoop.yarn.security with parameters of type Text
 org.apache.hadoop.security.token.Token<ContainerTokenIdentifier> ContainerTokenSelector.selectToken(Text service, Collection<org.apache.hadoop.security.token.Token<? extends org.apache.hadoop.security.token.TokenIdentifier>> tokens)
           
 org.apache.hadoop.security.token.Token<AMRMTokenIdentifier> AMRMTokenSelector.selectToken(Text service, Collection<org.apache.hadoop.security.token.Token<? extends org.apache.hadoop.security.token.TokenIdentifier>> tokens)
           
 

Uses of Text in org.apache.hadoop.yarn.security.client
 

Fields in org.apache.hadoop.yarn.security.client declared as Text
static Text ClientToAMTokenIdentifier.KIND_NAME
           
static Text TimelineDelegationTokenIdentifier.KIND_NAME
           
static Text RMDelegationTokenIdentifier.KIND_NAME
           
 

Methods in org.apache.hadoop.yarn.security.client that return Text
 Text ClientToAMTokenIdentifier.getKind()
           
 Text TimelineDelegationTokenIdentifier.getKind()
           
 Text RMDelegationTokenIdentifier.getKind()
           
 

Methods in org.apache.hadoop.yarn.security.client with parameters of type Text
 org.apache.hadoop.security.token.Token<TimelineDelegationTokenIdentifier> TimelineDelegationTokenSelector.selectToken(Text service, Collection<org.apache.hadoop.security.token.Token<? extends org.apache.hadoop.security.token.TokenIdentifier>> tokens)
           
 org.apache.hadoop.security.token.Token<RMDelegationTokenIdentifier> RMDelegationTokenSelector.selectToken(Text service, Collection<org.apache.hadoop.security.token.Token<? extends org.apache.hadoop.security.token.TokenIdentifier>> tokens)
           
 

Constructors in org.apache.hadoop.yarn.security.client with parameters of type Text
RMDelegationTokenIdentifier(Text owner, Text renewer, Text realUser)
          Create a new delegation token identifier
TimelineDelegationTokenIdentifier(Text owner, Text renewer, Text realUser)
          Create a new timeline delegation token identifier
 

Uses of Text in org.apache.hadoop.yarn.util.timeline
 

Methods in org.apache.hadoop.yarn.util.timeline that return Text
static Text TimelineUtils.buildTimelineTokenService(Configuration conf)
           
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.