Package org.apache.hadoop.hdfs

Examples of org.apache.hadoop.hdfs.DeprecatedUTF8


   * @throws IOException
   */
  @SuppressWarnings("deprecation")
  public static byte[][] readPathComponents(DataInputStream in)
      throws IOException {
    DeprecatedUTF8 ustr = TL_DATA.get().U_STR;
   
    ustr.readFields(in);
    return DFSUtil.bytes2byteArray(ustr.getBytes(),
      ustr.getLength(), (byte) Path.SEPARATOR_CHAR);
  }
View Full Code Here


      return this;
    }

    @Override
    void writeFields(DataOutputStream out) throws IOException {
      DeprecatedUTF8 info[] = new DeprecatedUTF8[] {
        new DeprecatedUTF8(path),
        toLogLong(mtime),
        toLogLong(atime)};
      new ArrayWritable(DeprecatedUTF8.class, info).write(out);
    }
View Full Code Here

      return this;
    }

    @Override
    void writeFields(DataOutputStream out) throws IOException {
      DeprecatedUTF8 info[] = new DeprecatedUTF8[] {
        new DeprecatedUTF8(path),
        new DeprecatedUTF8(value),
        toLogLong(mtime),
        toLogLong(atime)};
      new ArrayWritable(DeprecatedUTF8.class, info).write(out);
      permissionStatus.write(out);
    }
View Full Code Here

      return this;
    }

    @Override
    void writeFields(DataOutputStream out) throws IOException {
      DeprecatedUTF8 info[] = new DeprecatedUTF8[] {
        new DeprecatedUTF8(src),
        new DeprecatedUTF8(dst),
        toLogLong(timestamp)};
      new ArrayWritable(DeprecatedUTF8.class, info).write(out);
      toBytesWritable(options).write(out);
    }
View Full Code Here

      return this;
    }

    @Override
    void writeFields(DataOutputStream out) throws IOException {
      new DeprecatedUTF8(leaseHolder).write(out);
      new DeprecatedUTF8(path).write(out);
      new DeprecatedUTF8(newHolder).write(out);
    }
View Full Code Here

      return this;
    }

    @Override
    void writeFields(DataOutputStream out) throws IOException {
      new DeprecatedUTF8(path).write(out);
      new DeprecatedUTF8(Short.toString(replication)).write(out);
    }
View Full Code Here

    }

    @Override
    void writeFields(DataOutputStream out) throws IOException {
      int size = 1 + srcs.length + 1; // trg, srcs, timestamp
      DeprecatedUTF8 info[] = new DeprecatedUTF8[size];
      int idx = 0;
      info[idx++] = new DeprecatedUTF8(trg);
      for(int i=0; i<srcs.length; i++) {
        info[idx++] = new DeprecatedUTF8(srcs[i]);
      }
      info[idx] = toLogLong(timestamp);
      new ArrayWritable(DeprecatedUTF8.class, info).write(out);
    }
View Full Code Here

      return this;
    }

    @Override
    void writeFields(DataOutputStream out) throws IOException {
      DeprecatedUTF8 info[] = new DeprecatedUTF8[] {
        new DeprecatedUTF8(src),
        new DeprecatedUTF8(dst),
        toLogLong(timestamp)};
      new ArrayWritable(DeprecatedUTF8.class, info).write(out);
    }
View Full Code Here

      return this;
    }

    @Override
    void writeFields(DataOutputStream out) throws IOException {
      DeprecatedUTF8 info[] = new DeprecatedUTF8[] {
        new DeprecatedUTF8(path),
        toLogLong(timestamp)};
      new ArrayWritable(DeprecatedUTF8.class, info).write(out);
    }
View Full Code Here

      return this;
    }

    @Override
    void writeFields(DataOutputStream out) throws IOException {
      DeprecatedUTF8 info[] = new DeprecatedUTF8[] {
        new DeprecatedUTF8(path),
        toLogLong(timestamp), // mtime
        toLogLong(timestamp) // atime, unused at this time
      };
      new ArrayWritable(DeprecatedUTF8.class, info).write(out);
      permissions.write(out);
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hdfs.DeprecatedUTF8

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.