source: proiecte/HadoopJUnit/hadoop-0.20.1/src/mapred/org/apache/hadoop/mapreduce/Partitioner.java @ 120

Last change on this file since 120 was 120, checked in by (none), 14 years ago

Added the mail files for the Hadoop JUNit Project

  • Property svn:executable set to *
File size: 1.9 KB
Line 
1/**
2 * Licensed to the Apache Software Foundation (ASF) under one
3 * or more contributor license agreements.  See the NOTICE file
4 * distributed with this work for additional information
5 * regarding copyright ownership.  The ASF licenses this file
6 * to you under the Apache License, Version 2.0 (the
7 * "License"); you may not use this file except in compliance
8 * with the License.  You may obtain a copy of the License at
9 *
10 *     http://www.apache.org/licenses/LICENSE-2.0
11 *
12 * Unless required by applicable law or agreed to in writing, software
13 * distributed under the License is distributed on an "AS IS" BASIS,
14 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
15 * See the License for the specific language governing permissions and
16 * limitations under the License.
17 */
18
19package org.apache.hadoop.mapreduce;
20
21/**
22 * Partitions the key space.
23 *
24 * <p><code>Partitioner</code> controls the partitioning of the keys of the
25 * intermediate map-outputs. The key (or a subset of the key) is used to derive
26 * the partition, typically by a hash function. The total number of partitions
27 * is the same as the number of reduce tasks for the job. Hence this controls
28 * which of the <code>m</code> reduce tasks the intermediate key (and hence the
29 * record) is sent for reduction.</p>
30 *
31 * @see Reducer
32 */
33public abstract class Partitioner<KEY, VALUE> {
34 
35  /**
36   * Get the partition number for a given key (hence record) given the total
37   * number of partitions i.e. number of reduce-tasks for the job.
38   *   
39   * <p>Typically a hash function on a all or a subset of the key.</p>
40   *
41   * @param key the key to be partioned.
42   * @param value the entry value.
43   * @param numPartitions the total number of partitions.
44   * @return the partition number for the <code>key</code>.
45   */
46  public abstract int getPartition(KEY key, VALUE value, int numPartitions);
47 
48}
Note: See TracBrowser for help on using the repository browser.