Package org.apache.hadoop.hive.ql.lockmgr

Examples of org.apache.hadoop.hive.ql.lockmgr.LockException


        }
      }

    } catch (Exception e) {
      LOG.error("Failed to create ZooKeeper object: ", e);
      throw new LockException(ErrorMsg.ZOOKEEPER_CLIENT_COULD_NOT_BE_INITIALIZED.getMsg());
    }
  }
View Full Code Here


            LOG.error("Serious Zookeeper exception: ", e);
            break;
          }
        }
        if (tryNum >= numRetriesForLock) {
          throw new LockException(e1);
        }
      }
    } while (tryNum < numRetriesForLock);

    return ret;
View Full Code Here

        }
        unlockPrimitive(conf, zkpClient, hiveLock, parent);
        break;
      } catch (Exception e) {
        if (tryNum >= numRetriesForUnLock) {
          throw new LockException(e);
        }
      }
    } while (tryNum < numRetriesForUnLock);

    return;
View Full Code Here

      } catch (KeeperException.NoNodeException e) {
        LOG.debug("Node " + name + " previously deleted when attempting to delete.");
      }
    } catch (Exception e) {
      LOG.error("Failed to release ZooKeeper lock: ", e);
      throw new LockException(e);
    }
  }
View Full Code Here

        removeAllRedundantNodes();
      }

    } catch (Exception e) {
      LOG.error("Failed to close zooKeeper client: " + e);
      throw new LockException(e);
    }
  }
View Full Code Here

      }

      return new HiveLockObject(partn, data);
    } catch (Exception e) {
      LOG.error("Failed to create ZooKeeper object: " + e);
      throw new LockException(e);
    }
  }
View Full Code Here

  @Override
  public void prepareRetry() throws LockException {
    try {
      renewZookeeperInstance(sessionTimeout, quorumServers);
    } catch (Exception e) {
      throw new LockException(e);
    }
  }
View Full Code Here

      }


    } catch (Exception e) {
      LOG.error("Failed to create ZooKeeper object: " + e);
      throw new LockException(ErrorMsg.ZOOKEEPER_CLIENT_COULD_NOT_BE_INITIALIZED.getMsg());
    }
  }
View Full Code Here

          return null;
        }
      }
    } catch (Exception e) {
      LOG.error("Failed to get ZooKeeper lock: " + e);
      throw new LockException(e);
    }

    return new ZooKeeperHiveLock(res, key, mode);
  }
View Full Code Here

      {
        zkpClient.delete(name, -1);
      }
    } catch (Exception e) {
      LOG.error("Failed to release ZooKeeper lock: " + e);
      throw new LockException(e);
    }
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hive.ql.lockmgr.LockException

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.