You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by li...@apache.org on 2014/04/02 23:11:07 UTC

svn commit: r1584194 - in /hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock: ./ HConnectionMockImpl.java HFileReaderMockImpl.java HTableMockImpl.java

Author: liyin
Date: Wed Apr  2 21:11:07 2014
New Revision: 1584194

URL: http://svn.apache.org/r1584194
Log:
[HBASE-10894] Adding mock implementations to the HTableInterface, HConnection and HFile.Reader which Appserver uses to avoid the dependency on the Interfaces.

Author: manukranthk

Summary: This will enable us to upgrade the interfaces without breaking Prometheus.

Test Plan: Simple code gen by eclipse

Reviewers: adela, liyintang

Reviewed By: adela

CC: hbase-eng@

Differential Revision: https://phabricator.fb.com/D1253204

Task ID: 3947783

Added:
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HConnectionMockImpl.java
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HFileReaderMockImpl.java
    hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HTableMockImpl.java

Added: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HConnectionMockImpl.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HConnectionMockImpl.java?rev=1584194&view=auto
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HConnectionMockImpl.java (added)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HConnectionMockImpl.java Wed Apr  2 21:11:07 2014
@@ -0,0 +1,330 @@
+/**
+ * Copyright 2010 The Apache Software Foundation
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.hadoop.hbase.mock;
+
+import java.io.IOException;
+import java.util.ArrayList;
+import java.util.Collection;
+import java.util.List;
+import java.util.Map;
+import java.util.concurrent.ExecutorService;
+
+import org.apache.hadoop.conf.Configuration;
+import org.apache.hadoop.hbase.HRegionInfo;
+import org.apache.hadoop.hbase.HRegionLocation;
+import org.apache.hadoop.hbase.HServerAddress;
+import org.apache.hadoop.hbase.HTableDescriptor;
+import org.apache.hadoop.hbase.MasterNotRunningException;
+import org.apache.hadoop.hbase.client.Delete;
+import org.apache.hadoop.hbase.client.Get;
+import org.apache.hadoop.hbase.client.HConnection;
+import org.apache.hadoop.hbase.client.HRegionFailureInfo;
+import org.apache.hadoop.hbase.client.MultiPut;
+import org.apache.hadoop.hbase.client.Mutation;
+import org.apache.hadoop.hbase.client.OperationContext;
+import org.apache.hadoop.hbase.client.Put;
+import org.apache.hadoop.hbase.client.Result;
+import org.apache.hadoop.hbase.client.RowMutations;
+import org.apache.hadoop.hbase.client.ServerCallable;
+import org.apache.hadoop.hbase.ipc.HBaseRPCOptions;
+import org.apache.hadoop.hbase.ipc.HMasterInterface;
+import org.apache.hadoop.hbase.ipc.HRegionInterface;
+import org.apache.hadoop.hbase.util.StringBytes;
+import org.apache.hadoop.hbase.zookeeper.ZooKeeperWrapper;
+
+public class HConnectionMockImpl implements HConnection {
+
+  @Override
+  public void close() throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public ZooKeeperWrapper getZooKeeperWrapper() throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HMasterInterface getMaster() throws MasterNotRunningException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public boolean isMasterRunning() {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public boolean tableExists(StringBytes tableName)
+      throws MasterNotRunningException {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public boolean isTableEnabled(StringBytes tableName) throws IOException {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public boolean isTableDisabled(StringBytes tableName) throws IOException {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public boolean isTableAvailable(StringBytes tableName) throws IOException {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public HTableDescriptor[] listTables() throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HTableDescriptor getHTableDescriptor(StringBytes tableName)
+      throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HRegionLocation locateRegion(StringBytes tableName, byte[] row)
+      throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public void clearRegionCache() {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public HRegionLocation relocateRegion(StringBytes tableName, byte[] row)
+      throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HRegionInterface getHRegionConnection(HServerAddress regionServer,
+      HBaseRPCOptions options) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HRegionInterface getHRegionConnection(HServerAddress regionServer,
+      boolean getMaster, HBaseRPCOptions options) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HRegionInterface getHRegionConnection(HServerAddress regionServer)
+      throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HRegionInterface getHRegionConnection(HServerAddress regionServer,
+      boolean getMaster) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HRegionLocation getRegionLocation(StringBytes tableName, byte[] row,
+      boolean reload) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public <T> T getRegionServerWithRetries(ServerCallable<T> callable)
+      throws IOException, RuntimeException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public <T> T getRegionServerWithoutRetries(ServerCallable<T> callable)
+      throws IOException, RuntimeException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public <T> T getRegionServerWithoutRetries(ServerCallable<T> callable,
+      boolean instantiateRegionLocation) throws IOException, RuntimeException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public Result[] processBatchOfGets(List<Get> actions, StringBytes tableName,
+      HBaseRPCOptions options) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public int processBatchOfRows(ArrayList<Put> list, StringBytes tableName,
+      HBaseRPCOptions options) throws IOException {
+    // TODO Auto-generated method stub
+    return 0;
+  }
+
+  @Override
+  public int processBatchOfDeletes(List<Delete> list, StringBytes tableName,
+      HBaseRPCOptions options) throws IOException {
+    // TODO Auto-generated method stub
+    return 0;
+  }
+
+  @Override
+  public void processBatchOfPuts(List<Put> list, StringBytes tableName,
+      HBaseRPCOptions options) throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public int processBatchOfRowMutations(List<RowMutations> list,
+      StringBytes tableName, HBaseRPCOptions options) throws IOException {
+    // TODO Auto-generated method stub
+    return 0;
+  }
+
+  @Override
+  public void processBatchedGets(List<Get> actions, StringBytes tableName,
+      ExecutorService pool, Result[] results, HBaseRPCOptions options)
+      throws IOException, InterruptedException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void processBatchedMutations(List<Mutation> actions,
+      StringBytes tableName, ExecutorService pool, List<Mutation> failures,
+      HBaseRPCOptions options) throws IOException, InterruptedException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public List<Put> processListOfMultiPut(List<MultiPut> mputs,
+      StringBytes tableName, HBaseRPCOptions options,
+      Map<String, HRegionFailureInfo> failureInfo) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public void deleteCachedLocation(StringBytes tableName, byte[] row,
+      HServerAddress oldLoc) {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void setRegionCachePrefetch(StringBytes tableName, boolean enable) {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public boolean getRegionCachePrefetch(StringBytes tableName) {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public void prewarmRegionCache(StringBytes tableName,
+      Map<HRegionInfo, HServerAddress> regions) {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void startBatchedLoad(StringBytes tableName) {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void endBatchedLoad(StringBytes tableName, HBaseRPCOptions options)
+      throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public List<OperationContext> getAndResetOperationContext() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public void resetOperationContext() {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public Configuration getConf() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public void flushRegionAndWait(HRegionInfo regionInfo, HServerAddress addr,
+      long acceptableWindowForLastFlush, long maximumWaitTime)
+      throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public String getServerConfProperty(String prop) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public Collection<HRegionLocation> getCachedHRegionLocations(
+      StringBytes tableName, boolean forceRefresh) {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+}

Added: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HFileReaderMockImpl.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HFileReaderMockImpl.java?rev=1584194&view=auto
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HFileReaderMockImpl.java (added)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HFileReaderMockImpl.java Wed Apr  2 21:11:07 2014
@@ -0,0 +1,240 @@
+/**
+ * Copyright 2010 The Apache Software Foundation
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.hadoop.hbase.mock;
+
+import java.io.DataInput;
+import java.io.IOException;
+import java.nio.ByteBuffer;
+import java.util.Map;
+
+import org.apache.hadoop.fs.Path;
+import org.apache.hadoop.hbase.KeyValueContext;
+import org.apache.hadoop.hbase.io.encoding.DataBlockEncoding;
+import org.apache.hadoop.hbase.io.hfile.BlockType;
+import org.apache.hadoop.hbase.io.hfile.Compression.Algorithm;
+import org.apache.hadoop.hbase.io.hfile.FixedFileTrailer;
+import org.apache.hadoop.hbase.io.hfile.HFile.Reader;
+import org.apache.hadoop.hbase.io.hfile.HFileBlock;
+import org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader;
+import org.apache.hadoop.hbase.io.hfile.HFileScanner;
+import org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics;
+import org.apache.hadoop.io.RawComparator;
+
+public class HFileReaderMockImpl implements Reader {
+
+  @Override
+  public void close() throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public HFileBlock readBlock(long offset, long onDiskBlockSize,
+      boolean cacheBlock, boolean isCompaction, boolean cacheOnPreload,
+      BlockType expectedBlockType, DataBlockEncoding expectedDataBlockEncoding,
+      KeyValueContext kvContext) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public String getTableName() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public SchemaMetrics getSchemaMetrics() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public String getName() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public String getColumnFamilyName() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public RawComparator<byte[]> getComparator() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HFileScanner getScanner(boolean cacheBlocks, boolean isCompaction) {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HFileScanner getScanner(boolean cacheBlocks, boolean isCompaction,
+      boolean preloadBlocks) {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public ByteBuffer getMetaBlock(String metaBlockName, boolean cacheBlock)
+      throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public Map<byte[], byte[]> loadFileInfo() throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public byte[] getLastKey() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public byte[] midkey() throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public long length() {
+    // TODO Auto-generated method stub
+    return 0;
+  }
+
+  @Override
+  public long getEntries() {
+    // TODO Auto-generated method stub
+    return 0;
+  }
+
+  @Override
+  public byte[] getFirstKey() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public long indexSize() {
+    // TODO Auto-generated method stub
+    return 0;
+  }
+
+  @Override
+  public byte[] getFirstRowKey() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public byte[] getLastRowKey() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public FixedFileTrailer getTrailer() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public BlockIndexReader getDataBlockIndexReader() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HFileScanner getScanner(boolean cacheBlocks) {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public Algorithm getCompressionAlgorithm() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public DataInput getGeneralBloomFilterMetadata() throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public DataInput getDeleteBloomFilterMetadata() throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public DataInput getDeleteColumnBloomFilterMetadata() throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public DataInput getRowKeyPrefixBloomFilterMetadata() throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public Path getPath() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public void close(boolean evictOnClose) throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void close(boolean evictL1OnClose, boolean evictL2OnClose)
+      throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public DataBlockEncoding getEncodingOnDisk() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public String toShortString() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+}

Added: hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HTableMockImpl.java
URL: http://svn.apache.org/viewvc/hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HTableMockImpl.java?rev=1584194&view=auto
==============================================================================
--- hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HTableMockImpl.java (added)
+++ hbase/branches/0.89-fb/src/test/java/org/apache/hadoop/hbase/mock/HTableMockImpl.java Wed Apr  2 21:11:07 2014
@@ -0,0 +1,240 @@
+/**
+ * Copyright 2010 The Apache Software Foundation
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.hadoop.hbase.mock;
+
+import java.io.IOException;
+import java.util.Collection;
+import java.util.List;
+
+import org.apache.hadoop.conf.Configuration;
+import org.apache.hadoop.hbase.HRegionLocation;
+import org.apache.hadoop.hbase.HTableDescriptor;
+import org.apache.hadoop.hbase.client.Delete;
+import org.apache.hadoop.hbase.client.Get;
+import org.apache.hadoop.hbase.client.HTableInterface;
+import org.apache.hadoop.hbase.client.Mutation;
+import org.apache.hadoop.hbase.client.Put;
+import org.apache.hadoop.hbase.client.Result;
+import org.apache.hadoop.hbase.client.ResultScanner;
+import org.apache.hadoop.hbase.client.RowLock;
+import org.apache.hadoop.hbase.client.RowMutations;
+import org.apache.hadoop.hbase.client.Scan;
+
+public class HTableMockImpl implements HTableInterface {
+
+  @Override
+  public byte[] getTableName() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public Configuration getConfiguration() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public HTableDescriptor getTableDescriptor() throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public boolean exists(Get get) throws IOException {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public Result get(Get get) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public Result[] get(List<Get> gets) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public Result getRowOrBefore(byte[] row, byte[] family) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public ResultScanner getScanner(Scan scan) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public ResultScanner getScanner(byte[] family) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public ResultScanner getScanner(byte[] family, byte[] qualifier)
+      throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public void put(Put put) throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void put(List<Put> puts) throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public boolean checkAndPut(byte[] row, byte[] family, byte[] qualifier,
+      byte[] value, Put put) throws IOException {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public void delete(Delete delete) throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void delete(List<Delete> deletes) throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public boolean checkAndDelete(byte[] row, byte[] family, byte[] qualifier,
+      byte[] value, Delete delete) throws IOException {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public long incrementColumnValue(byte[] row, byte[] family, byte[] qualifier,
+      long amount) throws IOException {
+    // TODO Auto-generated method stub
+    return 0;
+  }
+
+  @Override
+  public long incrementColumnValue(byte[] row, byte[] family, byte[] qualifier,
+      long amount, boolean writeToWAL) throws IOException {
+    // TODO Auto-generated method stub
+    return 0;
+  }
+
+  @Override
+  public void mutateRow(RowMutations arm) throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void mutateRow(List<RowMutations> armList) throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public boolean isAutoFlush() {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public void flushCommits() throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void close() throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public RowLock lockRow(byte[] row) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public void unlockRow(RowLock rl) throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public void setProfiling(boolean prof) {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public boolean getProfiling() {
+    // TODO Auto-generated method stub
+    return false;
+  }
+
+  @Override
+  public void setTag(String tag) {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public String getTag() {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public Result[] batchGet(List<Get> actions) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+
+  @Override
+  public void batchMutate(List<Mutation> actions) throws IOException {
+    // TODO Auto-generated method stub
+
+  }
+
+  @Override
+  public Collection<HRegionLocation> getCachedHRegionLocations(
+      boolean forceRefresh) throws IOException {
+    // TODO Auto-generated method stub
+    return null;
+  }
+}