org.apache.hadoop.mapreduce.protocol.ClientProtocol Java Examples

The following examples show how to use org.apache.hadoop.mapreduce.protocol.ClientProtocol. You can vote up the ones you like or vote down the ones you don't like, and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example #1
Source File: TestJob.java    From big-c with Apache License 2.0 6 votes vote down vote up
@Test
public void testJobToString() throws IOException, InterruptedException {
  Cluster cluster = mock(Cluster.class);
  ClientProtocol client = mock(ClientProtocol.class);
  when(cluster.getClient()).thenReturn(client);
  JobID jobid = new JobID("1014873536921", 6);
  JobStatus status = new JobStatus(jobid, 0.0f, 0.0f, 0.0f, 0.0f,
      State.FAILED, JobPriority.NORMAL, "root", "TestJobToString",
      "job file", "tracking url");
  when(client.getJobStatus(jobid)).thenReturn(status);
  when(client.getTaskReports(jobid, TaskType.MAP)).thenReturn(
      new TaskReport[0]);
  when(client.getTaskReports(jobid, TaskType.REDUCE)).thenReturn(
      new TaskReport[0]);
  when(client.getTaskCompletionEvents(jobid, 0, 10)).thenReturn(
      new TaskCompletionEvent[0]);
  Job job = Job.getInstance(cluster, status, new JobConf());
  Assert.assertNotNull(job.toString());
}
 
Example #2
Source File: TestJob.java    From hadoop with Apache License 2.0 6 votes vote down vote up
@Test
public void testJobToString() throws IOException, InterruptedException {
  Cluster cluster = mock(Cluster.class);
  ClientProtocol client = mock(ClientProtocol.class);
  when(cluster.getClient()).thenReturn(client);
  JobID jobid = new JobID("1014873536921", 6);
  JobStatus status = new JobStatus(jobid, 0.0f, 0.0f, 0.0f, 0.0f,
      State.FAILED, JobPriority.NORMAL, "root", "TestJobToString",
      "job file", "tracking url");
  when(client.getJobStatus(jobid)).thenReturn(status);
  when(client.getTaskReports(jobid, TaskType.MAP)).thenReturn(
      new TaskReport[0]);
  when(client.getTaskReports(jobid, TaskType.REDUCE)).thenReturn(
      new TaskReport[0]);
  when(client.getTaskCompletionEvents(jobid, 0, 10)).thenReturn(
      new TaskCompletionEvent[0]);
  Job job = Job.getInstance(cluster, status, new JobConf());
  Assert.assertNotNull(job.toString());
}
 
Example #3
Source File: LocalClientProtocolProvider.java    From hadoop with Apache License 2.0 5 votes vote down vote up
@Override
public ClientProtocol create(Configuration conf) throws IOException {
  String framework =
      conf.get(MRConfig.FRAMEWORK_NAME, MRConfig.LOCAL_FRAMEWORK_NAME);
  if (!MRConfig.LOCAL_FRAMEWORK_NAME.equals(framework)) {
    return null;
  }
  conf.setInt(JobContext.NUM_MAPS, 1);

  return new LocalJobRunner(conf);
}
 
Example #4
Source File: YarnTezClientProtocolProvider.java    From tez with Apache License 2.0 5 votes vote down vote up
@Override
public ClientProtocol create(Configuration conf) throws IOException {
  if (MRConfig.YARN_TEZ_FRAMEWORK_NAME.equals(conf.get(MRConfig.FRAMEWORK_NAME))) {
    return new YARNRunner(conf);
  }
  return null;
}
 
Example #5
Source File: YarnClientProtocolProvider.java    From hadoop with Apache License 2.0 5 votes vote down vote up
@Override
public ClientProtocol create(Configuration conf) throws IOException {
  if (MRConfig.YARN_FRAMEWORK_NAME.equals(conf.get(MRConfig.FRAMEWORK_NAME))) {
    return new YARNRunner(conf);
  }
  return null;
}
 
Example #6
Source File: YarnTezClientProtocolProvider.java    From incubator-tez with Apache License 2.0 5 votes vote down vote up
@Override
public ClientProtocol create(Configuration conf) throws IOException {
  if (MRConfig.YARN_TEZ_FRAMEWORK_NAME.equals(conf.get(MRConfig.FRAMEWORK_NAME))) {
    return new YARNRunner(conf);
  }
  return null;
}
 
Example #7
Source File: LocalClientProtocolProvider.java    From big-c with Apache License 2.0 5 votes vote down vote up
@Override
public ClientProtocol create(Configuration conf) throws IOException {
  String framework =
      conf.get(MRConfig.FRAMEWORK_NAME, MRConfig.LOCAL_FRAMEWORK_NAME);
  if (!MRConfig.LOCAL_FRAMEWORK_NAME.equals(framework)) {
    return null;
  }
  conf.setInt(JobContext.NUM_MAPS, 1);

  return new LocalJobRunner(conf);
}
 
Example #8
Source File: IgniteHadoopClientProtocolProvider.java    From ignite with Apache License 2.0 5 votes vote down vote up
/** {@inheritDoc} */
@Override public void close(ClientProtocol cliProto) throws IOException {
    if (cliProto instanceof HadoopClientProtocol) {
        MapReduceClient cli = ((HadoopClientProtocol)cliProto).client();

        if (cli.release())
            cliMap.remove(cli.cluster(), cli);
    }
}
 
Example #9
Source File: IgniteHadoopClientProtocolProvider.java    From ignite with Apache License 2.0 5 votes vote down vote up
/** {@inheritDoc} */
@Override public ClientProtocol create(InetSocketAddress addr, Configuration conf) throws IOException {
    if (FRAMEWORK_NAME.equals(conf.get(MRConfig.FRAMEWORK_NAME)))
        return createProtocol(addr.getHostString() + ":" + addr.getPort(), conf);

    return null;
}
 
Example #10
Source File: TestJobMonitorAndPrint.java    From hadoop with Apache License 2.0 5 votes vote down vote up
@Before
public void setUp() throws IOException {
  conf = new Configuration();
  clientProtocol = mock(ClientProtocol.class);
  Cluster cluster = mock(Cluster.class);
  when(cluster.getConf()).thenReturn(conf);
  when(cluster.getClient()).thenReturn(clientProtocol);
  JobStatus jobStatus = new JobStatus(new JobID("job_000", 1), 0f, 0f, 0f, 0f, 
      State.RUNNING, JobPriority.HIGH, "tmp-user", "tmp-jobname", 
      "tmp-jobfile", "tmp-url");
  job = Job.getInstance(cluster, jobStatus, conf);
  job = spy(job);
}
 
Example #11
Source File: YarnClientProtocolProvider.java    From big-c with Apache License 2.0 5 votes vote down vote up
@Override
public ClientProtocol create(Configuration conf) throws IOException {
  if (MRConfig.YARN_FRAMEWORK_NAME.equals(conf.get(MRConfig.FRAMEWORK_NAME))) {
    return new YARNRunner(conf);
  }
  return null;
}
 
Example #12
Source File: IgniteHadoopClientProtocolProvider.java    From ignite with Apache License 2.0 5 votes vote down vote up
/** {@inheritDoc} */
@Override public ClientProtocol create(Configuration conf) throws IOException {
    if (FRAMEWORK_NAME.equals(conf.get(MRConfig.FRAMEWORK_NAME))) {
        Collection<String> addrs = conf.getTrimmedStringCollection(MRConfig.MASTER_ADDRESS);

        if (F.isEmpty(addrs))
            throw new IOException("Failed to create client protocol because Ignite node addresses are not " +
                "specified (did you set " + MRConfig.MASTER_ADDRESS + " property?).");

        if (F.contains(addrs, "local"))
            throw new IOException("Local execution mode is not supported, please point " +
                MRConfig.MASTER_ADDRESS + " to real Ignite nodes.");

        Collection<String> addrs0 = new ArrayList<>(addrs.size());

        // Set up port by default if need
        for (String addr : addrs) {
            if (!addr.contains(":"))
                addrs0.add(addr + ':' + ConnectorConfiguration.DFLT_TCP_PORT);
            else
                addrs0.add(addr);
        }

        return new HadoopClientProtocol(conf, client(conf.get(MRConfig.MASTER_ADDRESS), addrs0));
    }

    return null;
}
 
Example #13
Source File: TestJobMonitorAndPrint.java    From big-c with Apache License 2.0 5 votes vote down vote up
@Before
public void setUp() throws IOException {
  conf = new Configuration();
  clientProtocol = mock(ClientProtocol.class);
  Cluster cluster = mock(Cluster.class);
  when(cluster.getConf()).thenReturn(conf);
  when(cluster.getClient()).thenReturn(clientProtocol);
  JobStatus jobStatus = new JobStatus(new JobID("job_000", 1), 0f, 0f, 0f, 0f, 
      State.RUNNING, JobPriority.HIGH, "tmp-user", "tmp-jobname", 
      "tmp-jobfile", "tmp-url");
  job = Job.getInstance(cluster, jobStatus, conf);
  job = spy(job);
}
 
Example #14
Source File: Cluster.java    From big-c with Apache License 2.0 4 votes vote down vote up
private void initialize(InetSocketAddress jobTrackAddr, Configuration conf)
    throws IOException {

  synchronized (frameworkLoader) {
    for (ClientProtocolProvider provider : frameworkLoader) {
      LOG.debug("Trying ClientProtocolProvider : "
          + provider.getClass().getName());
      ClientProtocol clientProtocol = null; 
      try {
        if (jobTrackAddr == null) {
          clientProtocol = provider.create(conf);
        } else {
          clientProtocol = provider.create(jobTrackAddr, conf);
        }

        if (clientProtocol != null) {
          clientProtocolProvider = provider;
          client = clientProtocol;
          LOG.debug("Picked " + provider.getClass().getName()
              + " as the ClientProtocolProvider");
          break;
        }
        else {
          LOG.debug("Cannot pick " + provider.getClass().getName()
              + " as the ClientProtocolProvider - returned null protocol");
        }
      } 
      catch (Exception e) {
        LOG.info("Failed to use " + provider.getClass().getName()
            + " due to error: " + e.getMessage());
      }
    }
  }

  if (null == clientProtocolProvider || null == client) {
    throw new IOException(
        "Cannot initialize Cluster. Please check your configuration for "
            + MRConfig.FRAMEWORK_NAME
            + " and the correspond server addresses.");
  }
}
 
Example #15
Source File: LocalClientProtocolProvider.java    From big-c with Apache License 2.0 4 votes vote down vote up
@Override
public void close(ClientProtocol clientProtocol) {
  // no clean up required
}
 
Example #16
Source File: Cluster.java    From big-c with Apache License 2.0 4 votes vote down vote up
ClientProtocol getClient() {
  return client;
}
 
Example #17
Source File: TestSimulatorJobTracker.java    From RDFS with Apache License 2.0 4 votes vote down vote up
public FakeJobClient(ClientProtocol jobTracker, int numMaps,
    int numReduces) {
  this.jobTracker = jobTracker;
  this.numMaps = numMaps;
  this.numReduces = numReduces;
}
 
Example #18
Source File: YarnTezClientProtocolProvider.java    From incubator-tez with Apache License 2.0 4 votes vote down vote up
@Override
public ClientProtocol create(InetSocketAddress addr, Configuration conf)
    throws IOException {
  return create(conf);
}
 
Example #19
Source File: YarnTezClientProtocolProvider.java    From incubator-tez with Apache License 2.0 4 votes vote down vote up
@Override
public void close(ClientProtocol clientProtocol) throws IOException {
  // nothing to do
}
 
Example #20
Source File: YarnTezClientProtocolProvider.java    From tez with Apache License 2.0 4 votes vote down vote up
@Override
public ClientProtocol create(InetSocketAddress addr, Configuration conf)
    throws IOException {
  return create(conf);
}
 
Example #21
Source File: YarnTezClientProtocolProvider.java    From tez with Apache License 2.0 4 votes vote down vote up
@Override
public void close(ClientProtocol clientProtocol) throws IOException {
  // nothing to do
}
 
Example #22
Source File: JobSubmitter.java    From big-c with Apache License 2.0 4 votes vote down vote up
JobSubmitter(FileSystem submitFs, ClientProtocol submitClient) 
throws IOException {
  this.submitClient = submitClient;
  this.jtFs = submitFs;
}
 
Example #23
Source File: Job.java    From big-c with Apache License 2.0 4 votes vote down vote up
/** Only for mocking via unit tests. */
@Private
public JobSubmitter getJobSubmitter(FileSystem fs, 
    ClientProtocol submitClient) throws IOException {
  return new JobSubmitter(fs, submitClient);
}
 
Example #24
Source File: LocalJobRunner.java    From big-c with Apache License 2.0 4 votes vote down vote up
public long getProtocolVersion(String protocol, long clientVersion) {
  return ClientProtocol.versionID;
}
 
Example #25
Source File: LocalClientProtocolProvider.java    From big-c with Apache License 2.0 4 votes vote down vote up
@Override
public ClientProtocol create(InetSocketAddress addr, Configuration conf) {
  return null; // LocalJobRunner doesn't use a socket
}
 
Example #26
Source File: YarnClientProtocolProvider.java    From big-c with Apache License 2.0 4 votes vote down vote up
@Override
public void close(ClientProtocol clientProtocol) throws IOException {
  // nothing to do
}
 
Example #27
Source File: YarnClientProtocolProvider.java    From big-c with Apache License 2.0 4 votes vote down vote up
@Override
public ClientProtocol create(InetSocketAddress addr, Configuration conf)
    throws IOException {
  return create(conf);
}
 
Example #28
Source File: Cluster.java    From hadoop with Apache License 2.0 4 votes vote down vote up
ClientProtocol getClient() {
  return client;
}
 
Example #29
Source File: Cluster.java    From hadoop with Apache License 2.0 4 votes vote down vote up
private void initialize(InetSocketAddress jobTrackAddr, Configuration conf)
    throws IOException {

  synchronized (frameworkLoader) {
    for (ClientProtocolProvider provider : frameworkLoader) {
      LOG.debug("Trying ClientProtocolProvider : "
          + provider.getClass().getName());
      ClientProtocol clientProtocol = null; 
      try {
        if (jobTrackAddr == null) {
          clientProtocol = provider.create(conf);
        } else {
          clientProtocol = provider.create(jobTrackAddr, conf);
        }

        if (clientProtocol != null) {
          clientProtocolProvider = provider;
          client = clientProtocol;
          LOG.debug("Picked " + provider.getClass().getName()
              + " as the ClientProtocolProvider");
          break;
        }
        else {
          LOG.debug("Cannot pick " + provider.getClass().getName()
              + " as the ClientProtocolProvider - returned null protocol");
        }
      } 
      catch (Exception e) {
        LOG.info("Failed to use " + provider.getClass().getName()
            + " due to error: " + e.getMessage());
      }
    }
  }

  if (null == clientProtocolProvider || null == client) {
    throw new IOException(
        "Cannot initialize Cluster. Please check your configuration for "
            + MRConfig.FRAMEWORK_NAME
            + " and the correspond server addresses.");
  }
}
 
Example #30
Source File: JobSubmitter.java    From hadoop with Apache License 2.0 4 votes vote down vote up
JobSubmitter(FileSystem submitFs, ClientProtocol submitClient) 
throws IOException {
  this.submitClient = submitClient;
  this.jtFs = submitFs;
}